From b0c810d730be907a90035adc1391f92d7e4a18a6 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Mon, 17 Apr 2023 23:45:45 +0200 Subject: [PATCH 01/87] feat: support running tests using VM context --- packages/vite-node/package.json | 1 + packages/vite-node/rollup.config.js | 1 + packages/vite-node/src/client.ts | 159 ++++++- packages/vite-node/src/types.ts | 3 + packages/vitest/package.json | 1 + packages/vitest/rollup.config.js | 2 + .../vitest/src/integrations/env/happy-dom.ts | 22 + packages/vitest/src/integrations/env/jsdom.ts | 47 ++ packages/vitest/src/integrations/env/node.ts | 17 + packages/vitest/src/integrations/vi.ts | 4 +- packages/vitest/src/node/pool.ts | 9 + packages/vitest/src/node/pools/vm.ts | 158 +++++++ packages/vitest/src/runtime/entry-vm.ts | 26 ++ packages/vitest/src/runtime/entry.ts | 85 +--- packages/vitest/src/runtime/execute.ts | 4 +- packages/vitest/src/runtime/runners/index.ts | 84 ++++ packages/vitest/src/runtime/vm.ts | 134 ++++++ packages/vitest/src/types/config.ts | 2 +- packages/vitest/src/types/general.ts | 9 + packages/vitest/suppress-warnings.cjs | 1 + pnpm-lock.yaml | 440 +++++++++++++++--- test/core/test/happy-dom.test.ts | 9 +- 22 files changed, 1050 insertions(+), 168 deletions(-) create mode 100644 packages/vitest/src/node/pools/vm.ts create mode 100644 packages/vitest/src/runtime/entry-vm.ts create mode 100644 packages/vitest/src/runtime/runners/index.ts create mode 100644 packages/vitest/src/runtime/vm.ts diff --git a/packages/vite-node/package.json b/packages/vite-node/package.json index f0f31f22ef74..fbf355035c25 100644 --- a/packages/vite-node/package.json +++ b/packages/vite-node/package.json @@ -87,6 +87,7 @@ "devDependencies": { "@jridgewell/trace-mapping": "^0.3.18", "@types/debug": "^4.1.8", + "import-meta-resolve": "^2.2.2", "rollup": "^2.79.1" } } diff --git a/packages/vite-node/rollup.config.js b/packages/vite-node/rollup.config.js index 7397ba5b4a25..9fb7fb22a736 100644 --- a/packages/vite-node/rollup.config.js +++ b/packages/vite-node/rollup.config.js @@ -29,6 +29,7 @@ const external = [ 'vite/types/hot', 'node:url', 'node:events', + 'node:vm', ] const plugins = [ diff --git a/packages/vite-node/src/client.ts b/packages/vite-node/src/client.ts index d2814e122f00..18edd5a3993c 100644 --- a/packages/vite-node/src/client.ts +++ b/packages/vite-node/src/client.ts @@ -4,7 +4,10 @@ import { createRequire } from 'node:module' import { dirname } from 'node:path' import { fileURLToPath, pathToFileURL } from 'node:url' import vm from 'node:vm' +import { readFile } from 'node:fs/promises' import { resolve } from 'pathe' +import { hasESMSyntax } from 'mlly' +import { resolve as resolveModule } from 'import-meta-resolve' import createDebug from 'debug' import { VALID_ID_PREFIX, cleanUrl, isInternalRequest, isNodeBuiltin, isPrimitive, normalizeModuleId, normalizeRequestId, slash, toFilePath } from './utils' import type { HotContext, ModuleCache, ViteNodeRunnerOptions } from './types' @@ -181,10 +184,12 @@ export class ViteNodeRunner { * Keys of the map are filepaths, or plain package names */ moduleCache: ModuleCacheMap + externalCache: ModuleCacheMap constructor(public options: ViteNodeRunnerOptions) { this.root = options.root ?? process.cwd() this.moduleCache = options.moduleCache ?? new ModuleCacheMap() + this.externalCache = options.externalCache ?? new ModuleCacheMap() this.debug = options.debug ?? (typeof process !== 'undefined' ? !!process.env.VITE_NODE_DEBUG_RUNNER : false) } @@ -309,7 +314,7 @@ export class ViteNodeRunner { if (externalize) { debugNative(externalize) - const exports = await this.interopedImport(externalize) + const { exports } = await this.interopedImport(externalize) mod.exports = exports return exports } @@ -416,18 +421,77 @@ export class ViteNodeRunner { if (transformed[0] === '#') transformed = transformed.replace(/^\#\!.*/, s => ' '.repeat(s.length)) + await this.runModule(context, transformed) + + return exports + } + + async runModule(context: Record, transformed: string) { + const vmContext = this.options.context // add 'use strict' since ESM enables it by default const codeDefinition = `'use strict';async (${Object.keys(context).join(',')})=>{{` const code = `${codeDefinition}${transformed}\n}}` - const fn = vm.runInThisContext(code, { - filename: __filename, + const options = { + filename: context.__filename, lineOffset: 0, columnOffset: -codeDefinition.length, - }) + } + + if (vmContext) { + const fn = vm.runInContext(code, vmContext, { + ...options, + // if we encountered an import, it's not inlined + importModuleDynamically: this.importModuleDynamically.bind(this) as any, + }) + await fn(...Object.values(context)) + } + else { + const fn = vm.runInThisContext(code, options) + await fn(...Object.values(context)) + } + } - await fn(...Object.values(context)) + async importModuleDynamically(specifier: string, script: vm.Script) { + const vmContext = this.options.context + if (!vmContext) + throw new Error('[vite-node] importModuleDynamically is not supported without a context') - return exports + // @ts-expect-error - private API + const moduleUrl = await resolveModule(specifier, script.identifier) + return this.createModule(moduleUrl.toString()) + } + + private async createModule(identifier: string) { + const vmContext = this.options.context! + const { format, module } = await this.interopedImport(identifier) + if (format === 'esm') + return module + const moduleKeys = Object.keys(module) + const importModuleDynamically = this.importModuleDynamically.bind(this) + const m: any = new vm.SyntheticModule( + // TODO: fix "default" shenanigans + Array.from(new Set([...moduleKeys, 'default'])), + () => { + for (const key of moduleKeys) + m.setExport(key, module[key]) + if (format === 'cjs' && !moduleKeys.includes('default')) + m.setExport('default', module) + }, + { + context: vmContext, + identifier, + // @ts-expect-error actually supported + importModuleDynamically, + }, + ) + + if (m.status === 'unlinked') + await m.link(importModuleDynamically) + + if (m.status === 'linked') + await m.evaluate() + + return m } prepareContext(context: Record) { @@ -446,18 +510,89 @@ export class ViteNodeRunner { return !path.endsWith('.mjs') && 'default' in mod } + async externalizedImport(identifier: string) { + const vmContext = this.options.context + + if (!vmContext || isNodeBuiltin(identifier)) + return { format: 'builtin', module: await import(identifier) } + + const importModuleDynamically = this.importModuleDynamically.bind(this) as any + const fileUrl = identifier.startsWith('file:') ? identifier : pathToFileURL(identifier).toString() + const pathUrl = identifier.startsWith('file:') ? fileURLToPath(identifier) : identifier + + // TODO: dependencies are in the loop + const mod = this.externalCache.get(pathUrl) + + if (mod.promise) + return await mod.promise + + const content = await readFile(pathUrl, 'utf-8') + + // TODO: dirty check + if (!hasESMSyntax(content)) { + const cjsModule = `(function (exports, require, module, __filename, __dirname) { ${content} })` + const fn = vm.runInContext(cjsModule, vmContext, { + filename: pathUrl, + }) + const exports = mod.exports ??= (mod.exports = {}) + const module = { exports } + const require = createRequire(fileUrl) + const __dirname = dirname(pathUrl) + fn(module.exports, require, module, pathUrl, __dirname) + return { format: 'cjs', module: exports } + } + + const m = new vm.SourceTextModule( + content, + { + identifier: fileUrl, + context: vmContext, + importModuleDynamically, + initializeImportMeta(meta, mod) { + meta.url = mod.identifier + }, + }, + ) + + const promise = new Promise((resolve) => { + const result = { format: 'esm', module: m } + const finish = () => resolve(result) + if (m.status === 'unlinked') { + m.link(importModuleDynamically).then(() => { + if (m.status === 'linked') + m.evaluate().then(finish) + else + finish() + }) + } + else { + finish() + } + }) + + mod.promise = promise + + return await promise + } + /** * Import a module and interop it */ async interopedImport(path: string) { - const importedModule = await import(path) + const { format, module: importedModule } = await this.externalizedImport(path) - if (!this.shouldInterop(path, importedModule)) - return importedModule + let namespace + if (importedModule instanceof vm.Module) + namespace = importedModule.namespace + else + namespace = importedModule - const { mod, defaultExport } = interopModule(importedModule) + if (!this.shouldInterop(path, namespace)) + return { format, exports: namespace, module: importedModule } - return new Proxy(mod, { + const { mod, defaultExport } = interopModule(namespace) + + const exports = new Proxy(mod, { get(mod, prop) { if (prop === 'default') return defaultExport @@ -481,6 +616,8 @@ export class ViteNodeRunner { } }, }) + + return { format, exports, module: importedModule } } } diff --git a/packages/vite-node/src/types.ts b/packages/vite-node/src/types.ts index 18d6016a5377..5ca54827de35 100644 --- a/packages/vite-node/src/types.ts +++ b/packages/vite-node/src/types.ts @@ -1,3 +1,4 @@ +import type { Context } from 'node:vm' import type { ViteHotContext } from 'vite/types/hot' import type { EncodedSourceMap } from '@jridgewell/trace-mapping' import type { ModuleCacheMap, ViteNodeRunner } from './client' @@ -76,9 +77,11 @@ export interface ViteNodeRunnerOptions { createHotContext?: CreateHotContextFunction base?: string moduleCache?: ModuleCacheMap + externalCache?: ModuleCacheMap interopDefault?: boolean requestStubs?: Record debug?: boolean + context?: Context } export interface ViteNodeResolveId { diff --git a/packages/vitest/package.json b/packages/vitest/package.json index 7d21ab7d2fb6..89272d8530d4 100644 --- a/packages/vitest/package.json +++ b/packages/vitest/package.json @@ -147,6 +147,7 @@ "cac": "^6.7.14", "chai": "^4.3.7", "debug": "^4.3.4", + "import-meta-resolve": "^2.2.2", "local-pkg": "^0.4.3", "magic-string": "^0.30.1", "pathe": "^1.1.1", diff --git a/packages/vitest/rollup.config.js b/packages/vitest/rollup.config.js index 63d3cb65766b..403c0b30e683 100644 --- a/packages/vitest/rollup.config.js +++ b/packages/vitest/rollup.config.js @@ -24,9 +24,11 @@ const entries = [ 'src/runners.ts', 'src/environments.ts', 'src/runtime/worker.ts', + 'src/runtime/vm.ts', 'src/runtime/child.ts', 'src/runtime/loader.ts', 'src/runtime/entry.ts', + 'src/runtime/entry-vm.ts', 'src/integrations/spy.ts', 'src/coverage.ts', 'src/public/utils.ts', diff --git a/packages/vitest/src/integrations/env/happy-dom.ts b/packages/vitest/src/integrations/env/happy-dom.ts index 0a0cb1cc89b0..5e05d0e527bf 100644 --- a/packages/vitest/src/integrations/env/happy-dom.ts +++ b/packages/vitest/src/integrations/env/happy-dom.ts @@ -5,6 +5,28 @@ import { populateGlobal } from './utils' export default ({ name: 'happy-dom', transformMode: 'web', + async setupVm() { + const { Window } = await importModule('happy-dom') as typeof import('happy-dom') + const win = new Window() + + win.global = win.window + Object.defineProperty(win.document, 'defaultView', { + value: win.window, + configurable: true, + }) + + return { + getGlobal() { + return win.globalThis + }, + getVmContext() { + return win + }, + teardown() { + win.happyDOM.cancelAsync() + }, + } + }, async setup(global) { // happy-dom v3 introduced a breaking change to Window, but // provides GlobalWindow as a way to use previous behaviour diff --git a/packages/vitest/src/integrations/env/jsdom.ts b/packages/vitest/src/integrations/env/jsdom.ts index f197e9c3444e..2964a5b92453 100644 --- a/packages/vitest/src/integrations/env/jsdom.ts +++ b/packages/vitest/src/integrations/env/jsdom.ts @@ -29,6 +29,53 @@ function catchWindowErrors(window: Window) { export default ({ name: 'jsdom', transformMode: 'web', + async setupVm(_: any, { jsdom = {} }) { + const { + CookieJar, + JSDOM, + ResourceLoader, + VirtualConsole, + } = await importModule('jsdom') as typeof import('jsdom') + const { + html = '', + userAgent, + url = 'http://localhost:3000', + contentType = 'text/html', + pretendToBeVisual = true, + includeNodeLocations = false, + runScripts = 'dangerously', + resources, + console = false, + cookieJar = false, + ...restOptions + } = jsdom as any + const dom = new JSDOM( + html, + { + pretendToBeVisual, + resources: resources ?? (userAgent ? new ResourceLoader({ userAgent }) : undefined), + runScripts, + url, + virtualConsole: (console && global.console) ? new VirtualConsole().sendTo(global.console) : undefined, + cookieJar: cookieJar ? new CookieJar() : undefined, + includeNodeLocations, + contentType, + userAgent, + ...restOptions, + }, + ) + return { + getGlobal() { + return dom.window + }, + getVmContext() { + return dom.getInternalVMContext() + }, + teardown() { + dom.window.close() + }, + } + }, async setup(global, { jsdom = {} }) { const { CookieJar, diff --git a/packages/vitest/src/integrations/env/node.ts b/packages/vitest/src/integrations/env/node.ts index ef1a01cb1523..b1dcf84a7d57 100644 --- a/packages/vitest/src/integrations/env/node.ts +++ b/packages/vitest/src/integrations/env/node.ts @@ -1,9 +1,26 @@ import { Console } from 'node:console' +import { importModule } from 'local-pkg' import type { Environment } from '../../types' export default ({ name: 'node', transformMode: 'ssr', + async setupVm() { + const vm = await importModule('node:vm') + const global = {} // TODO: copy more globals + const context = vm.createContext(global) + return { + getGlobal() { + return global + }, + getVmContext() { + return context + }, + teardown() { + // + }, + } + }, async setup(global) { global.console.Console = Console return { diff --git a/packages/vitest/src/integrations/vi.ts b/packages/vitest/src/integrations/vi.ts index 1fcc6f30d553..a463a33865f3 100644 --- a/packages/vitest/src/integrations/vi.ts +++ b/packages/vitest/src/integrations/vi.ts @@ -163,10 +163,10 @@ function createVitest(): VitestUtils { // @ts-expect-error injected by vite-nide ? __vitest_mocker__ : new Proxy({}, { - get(name) { + get(_, name) { throw new Error( 'Vitest mocker was not initialized in this environment. ' - + `vi.${name}() is forbidden.`, + + `vi.${String(name)}() is forbidden.`, ) }, }) diff --git a/packages/vitest/src/node/pool.ts b/packages/vitest/src/node/pool.ts index dcfa13a14bd6..1f9810e762e2 100644 --- a/packages/vitest/src/node/pool.ts +++ b/packages/vitest/src/node/pool.ts @@ -7,6 +7,7 @@ import type { Vitest } from './core' import { createChildProcessPool } from './pools/child' import { createThreadsPool } from './pools/threads' import { createBrowserPool } from './pools/browser' +import { createVmPool } from './pools/vm' import type { WorkspaceProject } from './workspace' export type WorkspaceSpec = [project: WorkspaceProject, testFile: string] @@ -30,6 +31,7 @@ export function createPool(ctx: Vitest): ProcessPool { child_process: null, threads: null, browser: null, + vm: null, } function getDefaultPoolName(project: WorkspaceProject) { @@ -67,6 +69,7 @@ export function createPool(ctx: Vitest): ProcessPool { suppressLoaderWarningsPath, '--experimental-loader', loaderPath, + ...conditions, ] : [ ...execArgv, @@ -86,6 +89,7 @@ export function createPool(ctx: Vitest): ProcessPool { child_process: [] as WorkspaceSpec[], threads: [] as WorkspaceSpec[], browser: [] as WorkspaceSpec[], + vm: [] as WorkspaceSpec[], } for (const spec of files) { @@ -102,6 +106,11 @@ export function createPool(ctx: Vitest): ProcessPool { return pools.browser.runTests(files, invalidate) } + if (pool === 'vm') { + pools.vm ??= createVmPool(ctx, options) + return pools.vm.runTests(files, invalidate) + } + if (pool === 'threads') { pools.threads ??= createThreadsPool(ctx, options) return pools.threads.runTests(files, invalidate) diff --git a/packages/vitest/src/node/pools/vm.ts b/packages/vitest/src/node/pools/vm.ts new file mode 100644 index 000000000000..8a52d60290e5 --- /dev/null +++ b/packages/vitest/src/node/pools/vm.ts @@ -0,0 +1,158 @@ +import { MessageChannel } from 'node:worker_threads' +import { cpus } from 'node:os' +import { pathToFileURL } from 'node:url' +import { createBirpc } from 'birpc' +import { resolve } from 'pathe' +import type { Options as TinypoolOptions } from 'tinypool' +import Tinypool from 'tinypool' +import { distDir, rootDir } from '../../paths' +import type { ContextTestEnvironment, ResolvedConfig, RuntimeRPC, Vitest, WorkerContext } from '../../types' +import type { PoolProcessOptions, ProcessPool, RunWithFiles } from '../pool' +import { groupFilesByEnv } from '../../utils/test-helpers' +import { AggregateError } from '../../utils/base' +import type { WorkspaceProject } from '../workspace' +import { createMethodsRPC } from './rpc' + +const workerPath = pathToFileURL(resolve(distDir, './vm.js')).href +const suppressLoaderWarningsPath = resolve(rootDir, './suppress-warnings.cjs') + +function createWorkerChannel(project: WorkspaceProject) { + const channel = new MessageChannel() + const port = channel.port2 + const workerPort = channel.port1 + + createBirpc<{}, RuntimeRPC>( + createMethodsRPC(project), + { + post(v) { + try { + port.postMessage(v) + } + catch {} + }, + on(fn) { + port.on('message', fn) + }, + }, + ) + + return { workerPort, port } +} + +export function createVmPool(ctx: Vitest, { execArgv, env }: PoolProcessOptions): ProcessPool { + const threadsCount = ctx.config.watch + ? Math.max(Math.floor(cpus().length / 2), 1) + : Math.max(cpus().length - 1, 1) + + const maxThreads = ctx.config.maxThreads ?? threadsCount + const minThreads = ctx.config.minThreads ?? threadsCount + + const options: TinypoolOptions = { + filename: workerPath, + // TODO: investigate further + // It seems atomics introduced V8 Fatal Error https://github.com/vitest-dev/vitest/issues/1191 + useAtomics: ctx.config.useAtomics ?? false, + + maxThreads, + minThreads, + + env, + execArgv: [ + '--experimental-vm-modules', + '--require', + suppressLoaderWarningsPath, + ...execArgv, + ], + + terminateTimeout: ctx.config.teardownTimeout, + } + + if (ctx.config.singleThread) { + options.concurrentTasksPerWorker = 1 + options.maxThreads = 1 + options.minThreads = 1 + } + + const pool = new Tinypool(options) + + const runWithFiles = (name: string): RunWithFiles => { + let id = 0 + + async function runFiles(project: WorkspaceProject, config: ResolvedConfig, files: string[], environment: ContextTestEnvironment, invalidates: string[] = []) { + ctx.state.clearFiles(project, files) + const { workerPort, port } = createWorkerChannel(project) + const workerId = ++id + const data: WorkerContext = { + port: workerPort, + config, + files, + invalidates, + environment, + workerId, + } + try { + await pool.run(data, { transferList: [workerPort], name }) + } + catch (error) { + // Worker got stuck and won't terminate - this may cause process to hang + if (error instanceof Error && /Failed to terminate worker/.test(error.message)) + ctx.state.addProcessTimeoutCause(`Failed to terminate worker while running ${files.join(', ')}.`) + else + throw error + } + finally { + port.close() + workerPort.close() + } + } + + const Sequencer = ctx.config.sequence.sequencer + const sequencer = new Sequencer(ctx) + + return async (specs, invalidates) => { + const configs = new Map() + const getConfig = (project: WorkspaceProject): ResolvedConfig => { + if (configs.has(project)) + return configs.get(project)! + + const config = project.getSerializableConfig() + configs.set(project, config) + return config + } + + const workspaceMap = new Map() + for (const [project, file] of specs) { + const workspaceFiles = workspaceMap.get(file) ?? [] + workspaceFiles.push(project) + workspaceMap.set(file, workspaceFiles) + } + + // it's possible that project defines a file that is also defined by another project + const { shard } = ctx.config + + if (shard) + specs = await sequencer.shard(specs) + + specs = await sequencer.sort(specs) + + const filesByEnv = await groupFilesByEnv(specs) + const promises = Object.values(filesByEnv).flat() + const results = await Promise.allSettled(promises + .map(({ file, environment, project }) => runFiles(project, getConfig(project), [file], environment, invalidates))) + + const errors = results.filter((r): r is PromiseRejectedResult => r.status === 'rejected').map(r => r.reason) + if (errors.length > 0) + throw new AggregateError(errors, 'Errors occurred while running tests. For more information, see serialized error.') + } + } + + return { + runTests: runWithFiles('run'), + close: async () => { + // node before 16.17 has a bug that causes FATAL ERROR because of the race condition + const nodeVersion = Number(process.version.match(/v(\d+)\.(\d+)/)?.[0].slice(1)) + if (nodeVersion >= 16.17) + await pool.destroy() + }, + } +} diff --git a/packages/vitest/src/runtime/entry-vm.ts b/packages/vitest/src/runtime/entry-vm.ts new file mode 100644 index 000000000000..7a7ba1720c03 --- /dev/null +++ b/packages/vitest/src/runtime/entry-vm.ts @@ -0,0 +1,26 @@ +import { startTests } from '@vitest/runner' +import { setupChaiConfig } from '../integrations/chai' +import { startCoverageInsideWorker, stopCoverageInsideWorker } from '../integrations/coverage' +import type { ContextTestEnvironment, ResolvedConfig } from '../types' +import { getWorkerState } from '../utils/global' +import type { VitestExecutor } from './execute' +import { resolveTestRunner } from './runners' + +export async function run(files: string[], config: ResolvedConfig, environment: ContextTestEnvironment, executor: VitestExecutor): Promise { + const workerState = getWorkerState() + + await startCoverageInsideWorker(config.coverage, executor) + + if (config.chaiConfig) + setupChaiConfig(config.chaiConfig) + + const runner = await resolveTestRunner(config, executor) + + workerState.durations.prepare = performance.now() - workerState.durations.prepare + + await startTests(files, runner) + + await stopCoverageInsideWorker(config.coverage, executor) + + workerState.environmentTeardownRun = true +} diff --git a/packages/vitest/src/runtime/entry.ts b/packages/vitest/src/runtime/entry.ts index a2c9edaeaa76..fca980972d9e 100644 --- a/packages/vitest/src/runtime/entry.ts +++ b/packages/vitest/src/runtime/entry.ts @@ -1,92 +1,13 @@ import { performance } from 'node:perf_hooks' -import type { VitestRunner, VitestRunnerConstructor } from '@vitest/runner' import { startTests } from '@vitest/runner' -import { resolve } from 'pathe' import type { ResolvedConfig, ResolvedTestEnvironment } from '../types' import { getWorkerState, resetModules } from '../utils' import { vi } from '../integrations/vi' -import { distDir } from '../paths' -import { startCoverageInsideWorker, stopCoverageInsideWorker, takeCoverageInsideWorker } from '../integrations/coverage' +import { startCoverageInsideWorker, stopCoverageInsideWorker } from '../integrations/coverage' import { setupChaiConfig } from '../integrations/chai' import { setupGlobalEnv, withEnv } from './setup.node' -import { rpc } from './rpc' import type { VitestExecutor } from './execute' - -const runnersFile = resolve(distDir, 'runners.js') - -async function getTestRunnerConstructor(config: ResolvedConfig, executor: VitestExecutor): Promise { - if (!config.runner) { - const { VitestTestRunner, NodeBenchmarkRunner } = await executor.executeFile(runnersFile) - return (config.mode === 'test' ? VitestTestRunner : NodeBenchmarkRunner) as VitestRunnerConstructor - } - const mod = await executor.executeId(config.runner) - if (!mod.default && typeof mod.default !== 'function') - throw new Error(`Runner must export a default function, but got ${typeof mod.default} imported from ${config.runner}`) - return mod.default as VitestRunnerConstructor -} - -async function getTestRunner(config: ResolvedConfig, executor: VitestExecutor): Promise { - const TestRunner = await getTestRunnerConstructor(config, executor) - const testRunner = new TestRunner(config) - - // inject private executor to every runner - Object.defineProperty(testRunner, '__vitest_executor', { - value: executor, - enumerable: false, - configurable: false, - }) - - if (!testRunner.config) - testRunner.config = config - - if (!testRunner.importFile) - throw new Error('Runner must implement "importFile" method.') - - // patch some methods, so custom runners don't need to call RPC - const originalOnTaskUpdate = testRunner.onTaskUpdate - testRunner.onTaskUpdate = async (task) => { - const p = rpc().onTaskUpdate(task) - await originalOnTaskUpdate?.call(testRunner, task) - return p - } - - const originalOnCollected = testRunner.onCollected - testRunner.onCollected = async (files) => { - const state = getWorkerState() - files.forEach((file) => { - file.prepareDuration = state.durations.prepare - file.environmentLoad = state.durations.environment - // should be collected only for a single test file in a batch - state.durations.prepare = 0 - state.durations.environment = 0 - }) - rpc().onCollected(files) - await originalOnCollected?.call(testRunner, files) - } - - const originalOnAfterRun = testRunner.onAfterRun - testRunner.onAfterRun = async (files) => { - const coverage = await takeCoverageInsideWorker(config.coverage, executor) - rpc().onAfterSuiteRun({ coverage }) - await originalOnAfterRun?.call(testRunner, files) - } - - const originalOnAfterRunTest = testRunner.onAfterRunTest - testRunner.onAfterRunTest = async (test) => { - if (config.bail && test.result?.state === 'fail') { - const previousFailures = await rpc().getCountOfFailedTests() - const currentFailures = 1 + previousFailures - - if (currentFailures >= config.bail) { - rpc().onCancel('test-failure') - testRunner.onCancel?.('test-failure') - } - } - await originalOnAfterRunTest?.call(testRunner, test) - } - - return testRunner -} +import { resolveTestRunner } from './runners' // browser shouldn't call this! export async function run(files: string[], config: ResolvedConfig, environment: ResolvedTestEnvironment, executor: VitestExecutor): Promise { @@ -98,7 +19,7 @@ export async function run(files: string[], config: ResolvedConfig, environment: if (config.chaiConfig) setupChaiConfig(config.chaiConfig) - const runner = await getTestRunner(config, executor) + const runner = await resolveTestRunner(config, executor) workerState.onCancel.then(reason => runner.onCancel?.(reason)) workerState.durations.prepare = performance.now() - workerState.durations.prepare diff --git a/packages/vitest/src/runtime/execute.ts b/packages/vitest/src/runtime/execute.ts index cbce90c327e6..96fc755ea692 100644 --- a/packages/vitest/src/runtime/execute.ts +++ b/packages/vitest/src/runtime/execute.ts @@ -1,4 +1,5 @@ import { pathToFileURL } from 'node:url' +import type { Context } from 'node:vm' import { ModuleCacheMap, ViteNodeRunner } from 'vite-node/client' import { isInternalRequest, isNodeBuiltin, isPrimitive } from 'vite-node/utils' import type { ViteNodeRunnerOptions } from 'vite-node' @@ -36,7 +37,7 @@ let _viteNode: { export const moduleCache = new ModuleCacheMap() export const mockMap: MockMap = new Map() -export async function startViteNode(ctx: ContextRPC) { +export async function startViteNode(ctx: ContextRPC, vmContext?: Context) { if (_viteNode) return _viteNode @@ -80,6 +81,7 @@ export async function startViteNode(ctx: ContextRPC) { moduleDirectories: config.deps.moduleDirectories, root: config.root, base: config.base, + context: vmContext, }) const environment = await loadEnvironment(ctx.environment.name, executor) diff --git a/packages/vitest/src/runtime/runners/index.ts b/packages/vitest/src/runtime/runners/index.ts new file mode 100644 index 000000000000..761c431147e7 --- /dev/null +++ b/packages/vitest/src/runtime/runners/index.ts @@ -0,0 +1,84 @@ +import type { VitestRunner, VitestRunnerConstructor } from '@vitest/runner' +import { resolve } from 'pathe' +import type { ResolvedConfig } from '../../types/config' +import type { VitestExecutor } from '../execute' +import { distDir } from '../../paths' +import { getWorkerState } from '../../utils/global' +import { rpc } from '../rpc' +import { takeCoverageInsideWorker } from '../../integrations/coverage' + +const runnersFile = resolve(distDir, 'runners.js') + +async function getTestRunnerConstructor(config: ResolvedConfig, executor: VitestExecutor): Promise { + if (!config.runner) { + const { VitestTestRunner, NodeBenchmarkRunner } = await executor.executeFile(runnersFile) + return (config.mode === 'test' ? VitestTestRunner : NodeBenchmarkRunner) as VitestRunnerConstructor + } + const mod = await executor.executeId(config.runner) + if (!mod.default && typeof mod.default !== 'function') + throw new Error(`Runner must export a default function, but got ${typeof mod.default} imported from ${config.runner}`) + return mod.default as VitestRunnerConstructor +} + +export async function resolveTestRunner(config: ResolvedConfig, executor: VitestExecutor): Promise { + const TestRunner = await getTestRunnerConstructor(config, executor) + const testRunner = new TestRunner(config) + + // inject private executor to every runner + Object.defineProperty(testRunner, '__vitest_executor', { + value: executor, + enumerable: false, + configurable: false, + }) + + if (!testRunner.config) + testRunner.config = config + + if (!testRunner.importFile) + throw new Error('Runner must implement "importFile" method.') + + // patch some methods, so custom runners don't need to call RPC + const originalOnTaskUpdate = testRunner.onTaskUpdate + testRunner.onTaskUpdate = async (task) => { + const p = rpc().onTaskUpdate(task) + await originalOnTaskUpdate?.call(testRunner, task) + return p + } + + const originalOnCollected = testRunner.onCollected + testRunner.onCollected = async (files) => { + const state = getWorkerState() + files.forEach((file) => { + file.prepareDuration = state.durations.prepare + file.environmentLoad = state.durations.environment + // should be collected only for a single test file in a batch + state.durations.prepare = 0 + state.durations.environment = 0 + }) + rpc().onCollected(files) + await originalOnCollected?.call(testRunner, files) + } + + const originalOnAfterRun = testRunner.onAfterRun + testRunner.onAfterRun = async (files) => { + const coverage = await takeCoverageInsideWorker(config.coverage, executor) + rpc().onAfterSuiteRun({ coverage }) + await originalOnAfterRun?.call(testRunner, files) + } + + const originalOnAfterRunTest = testRunner.onAfterRunTest + testRunner.onAfterRunTest = async (test) => { + if (config.bail && test.result?.state === 'fail') { + const previousFailures = await rpc().getCountOfFailedTests() + const currentFailures = 1 + previousFailures + + if (currentFailures >= config.bail) { + rpc().onCancel('test-failure') + testRunner.onCancel?.('test-failure') + } + } + await originalOnAfterRunTest?.call(testRunner, test) + } + + return testRunner +} diff --git a/packages/vitest/src/runtime/vm.ts b/packages/vitest/src/runtime/vm.ts new file mode 100644 index 000000000000..8dacb28531a0 --- /dev/null +++ b/packages/vitest/src/runtime/vm.ts @@ -0,0 +1,134 @@ +import { pathToFileURL } from 'node:url' +import { ModuleCacheMap } from 'vite-node/client' +import type { BirpcReturn } from 'birpc' +import { createBirpc } from 'birpc' +import { relative, resolve } from 'pathe' +import { processError } from '@vitest/runner/utils' +import { isPrimitive } from '@vitest/utils' +import { installSourcemapsSupport } from 'vite-node/source-map' +import type { RuntimeRPC, WorkerContext, WorkerGlobalState } from '../types' +import { distDir } from '../paths' +import { environments } from '../integrations/env' +import { VitestSnapshotEnvironment } from '../integrations/snapshot/environments/node' +import { createVitestExecutor } from './execute' + +let rpc: BirpcReturn + +const caches: Record }> = {} + +// TODO: currently expect only one file in this function, which makes sense because the function itself is called for each file separately +export async function run(ctx: WorkerContext) { + const file = ctx.files[0] + const cache = caches[file] || {} + const moduleCache = cache.moduleCache ??= new ModuleCacheMap() + cache.moduleCache = moduleCache + const mockMap = cache.mockMap ?? new Map() + cache.mockMap = mockMap + caches[file] = cache + const { config, port } = ctx + rpc = createBirpc( + {}, + { + eventNames: ['onUserConsoleLog', 'onFinished', 'onCollected', 'onWorkerExit'], + post(v) { port.postMessage(v) }, + on(fn) { port.addListener('message', fn) }, + }, + ) + const __vitest_worker__: WorkerGlobalState = { + ctx, + moduleCache, + config, + mockMap, + durations: { + environment: 0, + prepare: performance.now(), + }, + rpc, + } + + installSourcemapsSupport({ + getSourceMap: source => moduleCache.getSourceMap(source), + }) + + const processExit = process.exit + + process.exit = (code = process.exitCode || 0): never => { + const error = new Error(`process.exit called with "${code}"`) + rpc.onWorkerExit(error, code) + return processExit(code) + } + + function catchError(err: unknown, type: string) { + const worker = __vitest_worker__ + const error = processError(err) + if (!isPrimitive(error)) { + error.VITEST_TEST_NAME = worker.current?.name + if (worker.filepath) + error.VITEST_TEST_PATH = relative(config.root, worker.filepath) + error.VITEST_AFTER_ENV_TEARDOWN = worker.environmentTeardownRun + } + rpc.onUnhandledError(error, type) + } + + process.on('uncaughtException', e => catchError(e, 'Uncaught Exception')) + process.on('unhandledRejection', e => catchError(e, 'Unhandled Rejection')) + + config.snapshotOptions.snapshotEnvironment = new VitestSnapshotEnvironment() + + const environment = environments[ctx.environment.name as 'happy-dom'] + + const vm = await environment.setupVm!({}, ctx.environment.options || {}) + + // @ts-expect-error untyped global + globalThis.__vitest_environment__ = config.environment + // @ts-expect-error untyped global + globalThis.__vitest_worker__ = __vitest_worker__ + + const context = vm.getVmContext() + + context.__vitest_worker__ = __vitest_worker__ + context.__vitest_environment__ = config.environment + // TODO: copy more globals + context.process = process + context.performance = performance + context.setImmediate = setImmediate + context.clearImmediate = clearImmediate + context.setTimeout = setTimeout + context.clearTimeout = clearTimeout + context.global = context + context.console = console + + if (ctx.invalidates) { + ctx.invalidates.forEach((fsPath) => { + moduleCache.delete(fsPath) + moduleCache.delete(`mock:${fsPath}`) + }) + } + ctx.files.forEach(i => moduleCache.delete(i)) + + const executor = await createVitestExecutor({ + fetchModule(id) { + return rpc.fetch(id, ctx.environment.name) + }, + resolveId(id, importer) { + return rpc.resolveId(id, importer, ctx.environment.name) + }, + moduleCache, + mockMap, + interopDefault: config.deps.interopDefault, + root: config.root, + base: config.base, + context, + }) + + context.__vitest_mocker__ = executor.mocker + + const { run } = await executor.executeId(pathToFileURL(resolve(distDir, 'entry-vm.js')).href) + + try { + await run(ctx.files, ctx.config, ctx.environment, executor) + } + finally { + await vm.teardown({}) + } +} diff --git a/packages/vitest/src/types/config.ts b/packages/vitest/src/types/config.ts index 92e20d67f886..234e2b4bdd7a 100644 --- a/packages/vitest/src/types/config.ts +++ b/packages/vitest/src/types/config.ts @@ -19,7 +19,7 @@ export type { SequenceHooks, SequenceSetupFiles } from '@vitest/runner' export type BuiltinEnvironment = 'node' | 'jsdom' | 'happy-dom' | 'edge-runtime' // Record is used, so user can get intellisense for builtin environments, but still allow custom environments export type VitestEnvironment = BuiltinEnvironment | (string & Record) -export type VitestPool = 'browser' | 'threads' | 'child_process' +export type VitestPool = 'browser' | 'threads' | 'child_process' | 'vm' export type CSSModuleScopeStrategy = 'stable' | 'scoped' | 'non-scoped' export type ApiConfig = Pick diff --git a/packages/vitest/src/types/general.ts b/packages/vitest/src/types/general.ts index 7e8da33bdbcd..75ea208968cc 100644 --- a/packages/vitest/src/types/general.ts +++ b/packages/vitest/src/types/general.ts @@ -1,3 +1,5 @@ +import type { Context } from 'node:vm' + export type { ErrorWithDiff, ParsedStack } from '@vitest/utils' export type Awaitable = T | PromiseLike @@ -21,9 +23,16 @@ export interface EnvironmentReturn { teardown: (global: any) => Awaitable } +export interface VmEnvironmentReturn { + getGlobal(): Context + getVmContext(): Context + teardown: (global: any) => Awaitable +} + export interface Environment { name: string transformMode?: 'web' | 'ssr' + setupVm?(global: any, options: Record): Awaitable setup(global: any, options: Record): Awaitable } diff --git a/packages/vitest/suppress-warnings.cjs b/packages/vitest/suppress-warnings.cjs index 9bc4cbb0fdc5..f3cdeef0c4c6 100644 --- a/packages/vitest/suppress-warnings.cjs +++ b/packages/vitest/suppress-warnings.cjs @@ -5,6 +5,7 @@ const ignoreWarnings = new Set([ '--experimental-loader is an experimental feature. This feature could change at any time', 'Custom ESM Loaders is an experimental feature. This feature could change at any time', 'Custom ESM Loaders is an experimental feature and might change at any time', + 'VM Modules is an experimental feature and might change at any time', ]) const { emit } = process diff --git a/pnpm-lock.yaml b/pnpm-lock.yaml index 03eaff59afa4..a20d733fcd5a 100644 --- a/pnpm-lock.yaml +++ b/pnpm-lock.yaml @@ -328,7 +328,7 @@ importers: version: 20.4.1 '@types/react': specifier: latest - version: 18.2.14 + version: 18.0.36 '@vitejs/plugin-react': specifier: latest version: 4.0.3(vite@4.3.9) @@ -614,11 +614,11 @@ importers: specifier: ^18.0.8 version: 18.0.8 '@vitejs/plugin-react': - specifier: latest - version: 4.0.3(vite@4.3.9) - '@vitest/coverage-v8': - specifier: latest - version: link:../../packages/coverage-v8 + specifier: ^2.2.0 + version: 2.2.0(vite@4.2.1) + '@vitest/coverage-c8': + specifier: ^0.24.5 + version: 0.24.5 '@vitest/ui': specifier: latest version: link:../../packages/ui @@ -672,8 +672,8 @@ importers: specifier: latest version: 22.1.0 msw: - specifier: ^1.2.1 - version: 1.2.1(typescript@5.1.6) + specifier: ^0.49.2 + version: 0.49.2(typescript@5.0.3) vite: specifier: ^4.3.9 version: 4.3.9(@types/node@18.16.19) @@ -803,11 +803,11 @@ importers: specifier: latest version: 22.1.0 unplugin-auto-import: - specifier: latest - version: 0.16.4(@vueuse/core@10.2.1)(rollup@3.26.0) + specifier: ^0.11.1 + version: 0.11.2(esbuild@0.17.15)(rollup@3.20.2)(vite@4.2.1) unplugin-vue-components: - specifier: latest - version: 0.25.1(rollup@3.26.0)(vue@3.3.4) + specifier: ^0.22.4 + version: 0.22.4(esbuild@0.17.15)(rollup@3.20.2)(vite@4.2.1)(vue@3.2.47) vite: specifier: ^4.3.9 version: 4.3.9(@types/node@18.16.19) @@ -1236,8 +1236,11 @@ importers: specifier: ^0.3.18 version: 0.3.18 '@types/debug': - specifier: ^4.1.8 - version: 4.1.8 + specifier: ^4.1.7 + version: 4.1.7 + import-meta-resolve: + specifier: ^2.2.2 + version: 2.2.2 rollup: specifier: ^2.79.1 version: 2.79.1 @@ -1289,6 +1292,9 @@ importers: debug: specifier: ^4.3.4 version: 4.3.4(supports-color@8.1.1) + import-meta-resolve: + specifier: ^2.2.2 + version: 2.2.2 local-pkg: specifier: ^0.4.3 version: 0.4.3 @@ -2340,6 +2346,51 @@ packages: transitivePeerDependencies: - supports-color + /@babel/core@7.19.6: + resolution: {integrity: sha512-D2Ue4KHpc6Ys2+AxpIx1BZ8+UegLLLE2p3KJEuJRKmokHOtl49jQ5ny1773KsGLZs8MQvBidAF6yWUJxRqtKtg==} + engines: {node: '>=6.9.0'} + dependencies: + '@ampproject/remapping': 2.2.0 + '@babel/code-frame': 7.18.6 + '@babel/generator': 7.20.7 + '@babel/helper-compilation-targets': 7.20.7(@babel/core@7.19.6) + '@babel/helper-module-transforms': 7.20.11 + '@babel/helpers': 7.20.7 + '@babel/parser': 7.20.7 + '@babel/template': 7.20.7 + '@babel/traverse': 7.20.12 + '@babel/types': 7.21.3 + convert-source-map: 1.9.0 + debug: 4.3.4(supports-color@8.1.1) + gensync: 1.0.0-beta.2 + json5: 2.2.3 + semver: 6.3.0 + transitivePeerDependencies: + - supports-color + dev: true + + /@babel/core@7.20.12: + resolution: {integrity: sha512-XsMfHovsUYHFMdrIHkZphTN/2Hzzi78R08NuHfDBehym2VsPDL6Zn/JAD/JQdnRvbSsbQc4mVaU1m6JgtTEElg==} + engines: {node: '>=6.9.0'} + dependencies: + '@ampproject/remapping': 2.2.0 + '@babel/code-frame': 7.18.6 + '@babel/generator': 7.20.7 + '@babel/helper-compilation-targets': 7.20.7(@babel/core@7.20.12) + '@babel/helper-module-transforms': 7.20.11 + '@babel/helpers': 7.20.7 + '@babel/parser': 7.20.7 + '@babel/template': 7.20.7 + '@babel/traverse': 7.20.12 + '@babel/types': 7.21.3 + convert-source-map: 1.9.0 + debug: 4.3.4(supports-color@8.1.1) + gensync: 1.0.0-beta.2 + json5: 2.2.3 + semver: 6.3.0 + transitivePeerDependencies: + - supports-color + /@babel/core@7.20.5: resolution: {integrity: sha512-UdOWmk4pNWTm/4DlPUl/Pt4Gz4rcEMb7CY0Y3eJl5Yz1vI8ZJGmHWaVE55LoxRjdpx0z259GE9U5STA9atUinQ==} engines: {node: '>=6.9.0'} @@ -2443,8 +2494,22 @@ packages: semver: 6.3.0 dev: true - /@babel/helper-compilation-targets@7.22.5(@babel/core@7.20.5): - resolution: {integrity: sha512-Ji+ywpHeuqxB8WDxraCiqR0xfhYjiDE/e6k7FuIaANnoOFxAHskHChz4vA1mJC9Lbm01s1PVAGhQY4FUKSkGZw==} + /@babel/helper-compilation-targets@7.20.7(@babel/core@7.19.6): + resolution: {integrity: sha512-4tGORmfQcrc+bvrjb5y3dG9Mx1IOZjsHqQVUz7XCNHO+iTmqxWnVg3KRygjGmpRLJGdQSKuvFinbIb0CnZwHAQ==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0 + dependencies: + '@babel/compat-data': 7.20.10 + '@babel/core': 7.19.6 + '@babel/helper-validator-option': 7.18.6 + browserslist: 4.21.3 + lru-cache: 5.1.1 + semver: 6.3.0 + dev: true + + /@babel/helper-compilation-targets@7.20.7(@babel/core@7.20.12): + resolution: {integrity: sha512-4tGORmfQcrc+bvrjb5y3dG9Mx1IOZjsHqQVUz7XCNHO+iTmqxWnVg3KRygjGmpRLJGdQSKuvFinbIb0CnZwHAQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0 @@ -3464,6 +3529,25 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true + /@babel/plugin-syntax-jsx@7.18.6(@babel/core@7.19.6): + resolution: {integrity: sha512-6mmljtAedFGTWu2p/8WIORGwy+61PLgOMPOdazc7YoJ9ZCWUyFy3A6CpPkRKLKD1ToAesxX8KGEViAiLo9N+7Q==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.19.6 + '@babel/helper-plugin-utils': 7.20.2 + dev: true + + /@babel/plugin-syntax-jsx@7.18.6(@babel/core@7.20.12): + resolution: {integrity: sha512-6mmljtAedFGTWu2p/8WIORGwy+61PLgOMPOdazc7YoJ9ZCWUyFy3A6CpPkRKLKD1ToAesxX8KGEViAiLo9N+7Q==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.20.12 + '@babel/helper-plugin-utils': 7.20.2 + /@babel/plugin-syntax-jsx@7.18.6(@babel/core@7.20.5): resolution: {integrity: sha512-6mmljtAedFGTWu2p/8WIORGwy+61PLgOMPOdazc7YoJ9ZCWUyFy3A6CpPkRKLKD1ToAesxX8KGEViAiLo9N+7Q==} engines: {node: '>=6.9.0'} @@ -4249,7 +4333,17 @@ packages: '@babel/plugin-transform-react-jsx': 7.19.0(@babel/core@7.18.13) dev: true - /@babel/plugin-transform-react-jsx-development@7.18.6(@babel/core@7.22.5): + /@babel/plugin-transform-react-jsx-development@7.18.6(@babel/core@7.19.6): + resolution: {integrity: sha512-SA6HEjwYFKF7WDjWcMcMGUimmw/nhNRDWxr+KaLSCrkD/LMDBvWRmHAYgE1HDeF8KUuI8OAu+RT6EOtKxSW2qA==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.19.6 + '@babel/plugin-transform-react-jsx': 7.19.0(@babel/core@7.19.6) + dev: true + + /@babel/plugin-transform-react-jsx-development@7.18.6(@babel/core@7.20.12): resolution: {integrity: sha512-SA6HEjwYFKF7WDjWcMcMGUimmw/nhNRDWxr+KaLSCrkD/LMDBvWRmHAYgE1HDeF8KUuI8OAu+RT6EOtKxSW2qA==} engines: {node: '>=6.9.0'} peerDependencies: @@ -4259,8 +4353,28 @@ packages: '@babel/plugin-transform-react-jsx': 7.19.0(@babel/core@7.22.5) dev: true - /@babel/plugin-transform-react-jsx-self@7.22.5(@babel/core@7.22.5): - resolution: {integrity: sha512-nTh2ogNUtxbiSbxaT4Ds6aXnXEipHweN9YRgOX/oNXdf0cCrGn/+2LozFa3lnPV5D90MkjhgckCPBrsoSc1a7g==} + /@babel/plugin-transform-react-jsx-self@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-A0LQGx4+4Jv7u/tWzoJF7alZwnBDQd6cGLh9P+Ttk4dpiL+J5p7NSNv/9tlEFFJDq3kjxOavWmbm6t0Gk+A3Ig==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-transform-react-jsx-self@7.18.6(@babel/core@7.19.6): + resolution: {integrity: sha512-A0LQGx4+4Jv7u/tWzoJF7alZwnBDQd6cGLh9P+Ttk4dpiL+J5p7NSNv/9tlEFFJDq3kjxOavWmbm6t0Gk+A3Ig==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.19.6 + '@babel/helper-plugin-utils': 7.20.2 + dev: true + + /@babel/plugin-transform-react-jsx-self@7.18.6(@babel/core@7.20.12): + resolution: {integrity: sha512-A0LQGx4+4Jv7u/tWzoJF7alZwnBDQd6cGLh9P+Ttk4dpiL+J5p7NSNv/9tlEFFJDq3kjxOavWmbm6t0Gk+A3Ig==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 @@ -4269,8 +4383,28 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-react-jsx-source@7.22.5(@babel/core@7.22.5): - resolution: {integrity: sha512-yIiRO6yobeEIaI0RTbIr8iAK9FcBHLtZq0S89ZPjDLQXBA4xvghaKqI0etp/tF3htTM0sazJKKLz9oEiGRtu7w==} + /@babel/plugin-transform-react-jsx-source@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-utZmlASneDfdaMh0m/WausbjUjEdGrQJz0vFK93d7wD3xf5wBtX219+q6IlCNZeguIcxS2f/CvLZrlLSvSHQXw==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-transform-react-jsx-source@7.19.6(@babel/core@7.19.6): + resolution: {integrity: sha512-RpAi004QyMNisst/pvSanoRdJ4q+jMCWyk9zdw/CyLB9j8RXEahodR6l2GyttDRyEVWZtbN+TpLiHJ3t34LbsQ==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.19.6 + '@babel/helper-plugin-utils': 7.20.2 + dev: true + + /@babel/plugin-transform-react-jsx-source@7.19.6(@babel/core@7.20.12): + resolution: {integrity: sha512-RpAi004QyMNisst/pvSanoRdJ4q+jMCWyk9zdw/CyLB9j8RXEahodR6l2GyttDRyEVWZtbN+TpLiHJ3t34LbsQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 @@ -4307,7 +4441,21 @@ packages: '@babel/types': 7.22.5 dev: true - /@babel/plugin-transform-react-jsx@7.19.0(@babel/core@7.22.5): + /@babel/plugin-transform-react-jsx@7.19.0(@babel/core@7.19.6): + resolution: {integrity: sha512-UVEvX3tXie3Szm3emi1+G63jyw1w5IcMY0FSKM+CRnKRI5Mr1YbCNgsSTwoTwKphQEG9P+QqmuRFneJPZuHNhg==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.19.6 + '@babel/helper-annotate-as-pure': 7.18.6 + '@babel/helper-module-imports': 7.18.6 + '@babel/helper-plugin-utils': 7.20.2 + '@babel/plugin-syntax-jsx': 7.18.6(@babel/core@7.19.6) + '@babel/types': 7.21.3 + dev: true + + /@babel/plugin-transform-react-jsx@7.19.0(@babel/core@7.20.12): resolution: {integrity: sha512-UVEvX3tXie3Szm3emi1+G63jyw1w5IcMY0FSKM+CRnKRI5Mr1YbCNgsSTwoTwKphQEG9P+QqmuRFneJPZuHNhg==} engines: {node: '>=6.9.0'} peerDependencies: @@ -8623,7 +8771,7 @@ packages: resolution: {integrity: sha512-xryQlOEIe1TduDWAOphR0ihfebKFSWOXpIsk+70JskCfRfW+xALdnJ0r1ZOTo85F9Qsjk6vtlU7edTYHbls9tA==} dependencies: '@types/cheerio': 0.22.31 - '@types/react': 18.2.14 + '@types/react': 18.0.36 dev: true /@types/eslint-scope@3.7.4: @@ -8871,19 +9019,19 @@ packages: /@types/react-dom@18.0.6: resolution: {integrity: sha512-/5OFZgfIPSwy+YuIBP/FgJnQnsxhZhjjrnxudMddeblOouIodEQ75X14Rr4wGSG/bknL+Omy9iWlLo1u/9GzAA==} dependencies: - '@types/react': 18.2.14 + '@types/react': 18.0.36 dev: true /@types/react-dom@18.0.8: resolution: {integrity: sha512-C3GYO0HLaOkk9dDAz3Dl4sbe4AKUGTCfFIZsz3n/82dPNN8Du533HzKatDxeUYWu24wJgMP1xICqkWk1YOLOIw==} dependencies: - '@types/react': 18.2.14 + '@types/react': 18.0.36 dev: true /@types/react-is@17.0.3: resolution: {integrity: sha512-aBTIWg1emtu95bLTLx0cpkxwGW3ueZv71nE2YFBpL8k/z5czEW8yYpOo8Dp+UUAFAtKwNaOsh/ioSeQnWlZcfw==} dependencies: - '@types/react': 18.2.14 + '@types/react': 18.0.36 dev: false /@types/react-test-renderer@17.0.2: @@ -8895,7 +9043,7 @@ packages: /@types/react-transition-group@4.4.5: resolution: {integrity: sha512-juKD/eiSM3/xZYzjuzH6ZwpP+/lejltmiS3QEzV/vmb/Q8+HfDmxu+Baga8UEMGBqV88Nbg4l2hY/K2DkyaLLA==} dependencies: - '@types/react': 18.2.14 + '@types/react': 18.0.36 dev: false /@types/react@17.0.49: @@ -8914,12 +9062,12 @@ packages: csstype: 3.1.0 dev: true - /@types/react@18.2.14: - resolution: {integrity: sha512-A0zjq+QN/O0Kpe30hA1GidzyFjatVvrpIvWLxD+xv67Vt91TWWgco9IvrJBkeyHm1trGaFS/FSGqPlhyeZRm0g==} + /@types/react@18.0.36: + resolution: {integrity: sha512-Hqbi2s6k4X1CKRYwUb9BwhNN4jbCgs6BfakDTY5b5GEJ5h9i+uf24mRsbNXFh6rHI5zpk5h1b5jOm/eSUrfVNQ==} dependencies: '@types/prop-types': 15.7.5 '@types/scheduler': 0.16.2 - csstype: 3.1.2 + csstype: 3.1.0 /@types/resolve@1.17.1: resolution: {integrity: sha512-yy7HuzQhj0dhGpD8RLXSZWEkLsV9ibvxvi6EiJ3bkqLAO1RGo0WbkWQiwpRlSFymTJRz0d3k5LM3kkx8ArDbLw==} @@ -9490,8 +9638,26 @@ packages: - supports-color dev: true - /@vitejs/plugin-react@4.0.3(vite@4.3.9): - resolution: {integrity: sha512-pwXDog5nwwvSIzwrvYYmA2Ljcd/ZNlcsSG2Q9CNDBwnsd55UGAyr2doXtB5j+2uymRCnCfExlznzzSFbBRcoCg==} + /@vitejs/plugin-react@2.2.0(vite@4.2.1): + resolution: {integrity: sha512-FFpefhvExd1toVRlokZgxgy2JtnBOdp4ZDsq7ldCWaqGSGn9UhWMAVm/1lxPL14JfNS5yGz+s9yFrQY6shoStA==} + engines: {node: ^14.18.0 || >=16.0.0} + peerDependencies: + vite: ^3.0.0 + dependencies: + '@babel/core': 7.19.6 + '@babel/plugin-transform-react-jsx': 7.19.0(@babel/core@7.19.6) + '@babel/plugin-transform-react-jsx-development': 7.18.6(@babel/core@7.19.6) + '@babel/plugin-transform-react-jsx-self': 7.18.6(@babel/core@7.19.6) + '@babel/plugin-transform-react-jsx-source': 7.19.6(@babel/core@7.19.6) + magic-string: 0.26.7 + react-refresh: 0.14.0 + vite: 4.2.1(@types/node@18.15.11) + transitivePeerDependencies: + - supports-color + dev: true + + /@vitejs/plugin-react@3.1.0(vite@4.2.1): + resolution: {integrity: sha512-AfgcRL8ZBhAlc3BFdigClmTUMISmmzHn7sB2h9U1odvc5U/MjWXsAaz18b/WoppUTDBzxOJwo2VdClfUcItu9g==} engines: {node: ^14.18.0 || >=16.0.0} peerDependencies: vite: ^4.2.0 @@ -15058,8 +15224,19 @@ packages: - supports-color dev: true - /fast-glob@3.3.0: - resolution: {integrity: sha512-ChDuvbOypPuNjO8yIDf36x7BlZX1smcUMTTcyoIjycexOxd6DFsKsg21qVBzEmr3G7fUKIRy2/psii+CIUt7FA==} + /fast-glob@3.2.11: + resolution: {integrity: sha512-xrO3+1bxSo3ZVHAnqzyuewYT6aMFHRAd4Kcs92MAonjwQZLsK9d0SF1IyQ3k5PoirxTW0Oe/RqFgMQ6TcNE5Ew==} + engines: {node: '>=8.6.0'} + dependencies: + '@nodelib/fs.stat': 2.0.5 + '@nodelib/fs.walk': 1.2.8 + glob-parent: 5.1.2 + merge2: 1.4.1 + micromatch: 4.0.5 + dev: true + + /fast-glob@3.2.12: + resolution: {integrity: sha512-DVj4CQIYYow0BlaelwK1pHl5n5cRSJfM60UA0zK891sVInoPri2Ekj7+e1CT3/3qxXenpI+nBBmQAcJPJgaj4w==} engines: {node: '>=8.6.0'} dependencies: '@nodelib/fs.stat': 2.0.5 @@ -16478,6 +16655,9 @@ packages: resolve-cwd: 3.0.0 dev: true + /import-meta-resolve@2.2.2: + resolution: {integrity: sha512-f8KcQ1D80V7RnqVm+/lirO9zkOxjGxhaTC1IPrBGd3MEfNgmNG67tSUO9gTi2F3Blr2Az6g1vocaxzkVnWl9MA==} + /import-meta-resolve@3.0.0: resolution: {integrity: sha512-4IwhLhNNA8yy445rPjD/lWh++7hMDOml2eHtd58eG7h+qK3EryMuuRbsHGPikCoAgIkkDnckKfWSk2iDla/ejg==} dev: true @@ -16881,10 +17061,6 @@ packages: resolution: {integrity: sha512-5IcdXuf++TTNt3oGl9EBdkvndXA8gmc4bz/Y+mdEpWh3Mcn/+kOw6hI7LD5CocqJWMzeb0I0ClndRVNdEPuJXQ==} dev: true - /is-node-process@1.2.0: - resolution: {integrity: sha512-Vg4o6/fqPxIjtxgUH5QLJhwZ7gW5diGCVlXpuUfELC62CuxM1iHcRe51f2W1FDy04Ai4KJkagKjx3XaqyfRKXw==} - dev: true - /is-number-object@1.0.7: resolution: {integrity: sha512-k1U0IRzLMo7ZlYIfzRu23Oh6MiIFasgpb9X76eqfFZAqwH44UI4KTBvBYIZ1dSL9ZzChTB9ShHfLkR4pdW5krQ==} engines: {node: '>= 0.4'} @@ -19014,6 +19190,13 @@ packages: dependencies: brace-expansion: 1.1.11 + /minimatch@5.1.0: + resolution: {integrity: sha512-9TPBGGak4nHfGZsPBohm9AWg6NoT7QTCehS3BIJABslyZbzxfV78QM2Y6+i741OPZIafFAaiiEMh5OyIrJPgtg==} + engines: {node: '>=10'} + dependencies: + brace-expansion: 2.0.1 + dev: true + /minimatch@5.1.1: resolution: {integrity: sha512-362NP+zlprccbEt/SkxKfRMHnNY85V74mVnpUpNyr3F35covl09Kec7/sEFLt3RA4oXmewtoaanoIf67SE5Y5g==} engines: {node: '>=10'} @@ -19131,8 +19314,25 @@ packages: hasBin: true dev: true - /mlly@1.4.0: - resolution: {integrity: sha512-ua8PAThnTwpprIaU47EPeZ/bPUVp2QYBbWMphUQpVdBI3Lgqzm5KZQ45Agm3YJedHXaIHl6pBGabaLSUPPSptg==} + /mlly@0.5.16: + resolution: {integrity: sha512-LaJ8yuh4v0zEmge/g3c7jjFlhoCPfQn6RCjXgm9A0Qiuochq4BcuOxVfWmdnCoLTlg2MV+hqhOek+W2OhG0Lwg==} + dependencies: + acorn: 8.8.2 + pathe: 0.3.9 + pkg-types: 0.3.6 + ufo: 0.8.6 + dev: true + + /mlly@1.2.0: + resolution: {integrity: sha512-+c7A3CV0KGdKcylsI6khWyts/CYrGTrRVo4R/I7u/cUsy0Conxa6LUhiEzVKIw14lc2L5aiO4+SeVe4TeGRKww==} + dependencies: + acorn: 8.8.2 + pathe: 1.1.0 + pkg-types: 1.0.2 + ufo: 1.1.1 + + /mlly@1.3.0: + resolution: {integrity: sha512-HT5mcgIQKkOrZecOjOX3DJorTikWXwsBfpcr/MGBkhfWcjiqvnaL/9ppxvIUXfjT6xt4DVIAsN9fMUz1ev4bIw==} dependencies: acorn: 8.9.0 pathe: 1.1.1 @@ -19242,13 +19442,13 @@ packages: - supports-color dev: true - /msw@1.2.1(typescript@5.1.6): - resolution: {integrity: sha512-bF7qWJQSmKn6bwGYVPXOxhexTCGD5oJSZg8yt8IBClxvo3Dx/1W0zqE1nX9BSWmzRsCKWfeGWcB/vpqV6aclpw==} + /msw@0.49.2(typescript@5.0.3): + resolution: {integrity: sha512-70/E10f+POE2UmMw16v8PnKatpZplpkUwVRLBqiIdimpgaC3le7y2yOq9JmOrL15jpwWM5wAcPTOj0f550LI3g==} engines: {node: '>=14'} hasBin: true requiresBuild: true peerDependencies: - typescript: '>= 4.4.x <= 5.0.x' + typescript: '>= 4.4.x <= 4.9.x' peerDependenciesMeta: typescript: optional: true @@ -19264,15 +19464,15 @@ packages: graphql: 16.6.0 headers-polyfill: 3.1.2 inquirer: 8.2.4 - is-node-process: 1.2.0 + is-node-process: 1.0.1 js-levenshtein: 1.1.6 node-fetch: 2.6.7 - outvariant: 1.4.0 + outvariant: 1.3.0 path-to-regexp: 6.2.1 - strict-event-emitter: 0.4.6 + strict-event-emitter: 0.2.8 type-fest: 2.19.0 - typescript: 5.1.6 - yargs: 17.7.1 + typescript: 5.0.3 + yargs: 17.5.1 transitivePeerDependencies: - encoding - supports-color @@ -19913,10 +20113,6 @@ packages: resolution: {integrity: sha512-yeWM9k6UPfG/nzxdaPlJkB2p08hCg4xP6Lx99F+vP8YF7xyZVfTmJjrrNalkmzudD4WFvNLVudQikqUmF8zhVQ==} dev: true - /outvariant@1.4.0: - resolution: {integrity: sha512-AlWY719RF02ujitly7Kk/0QlV+pXGFDHrHf9O2OKqyqgBieaPOIeuSkL8sRK6j2WK+/ZAURq2kZsY0d8JapUiw==} - dev: true - /p-all@2.1.0: resolution: {integrity: sha512-HbZxz5FONzz/z2gJfk6bFca0BCiSRF8jU3yCsWOen/vR6lZjfPOu/e7L3uFzTW1i0H8TlC3vqQstEJPQL4/uLA==} engines: {node: '>=6'} @@ -20408,6 +20604,21 @@ packages: find-up: 5.0.0 dev: true + /pkg-types@0.3.6: + resolution: {integrity: sha512-uQZutkkh6axl1GxDm5/+8ivVdwuJ5pyDGqJeSiIWIUWIqYiK3p9QKozN/Rv6eVvFoeSWkN1uoYeSDBwwBJBtbg==} + dependencies: + jsonc-parser: 3.2.0 + mlly: 0.5.16 + pathe: 0.3.9 + dev: true + + /pkg-types@1.0.2: + resolution: {integrity: sha512-hM58GKXOcj8WTqUXnsQyJYXdeAPbythQgEF3nTcEo+nkD49chjQ9IKm/QJy9xf6JakXptz86h7ecP2024rrLaQ==} + dependencies: + jsonc-parser: 3.2.0 + mlly: 1.3.0 + pathe: 1.1.0 + /pkg-types@1.0.3: resolution: {integrity: sha512-nN7pYi0AQqJnoLPC9eHFQ8AcyaixBUOwvqc5TDnIKCMEE6I0y8P7OKA7fPexsXGCGxQDl/cmrLAp26LhcwxZ4A==} dependencies: @@ -22117,6 +22328,10 @@ packages: ajv-keywords: 3.5.2(ajv@6.12.6) dev: true + /scule@0.3.2: + resolution: {integrity: sha512-zIvPdjOH8fv8CgrPT5eqtxHQXmPNnV/vHJYffZhE43KZkvULvpCTvOt1HPlFaCZx287INL9qaqrZg34e8NgI4g==} + dev: true + /scule@1.0.0: resolution: {integrity: sha512-4AsO/FrViE/iDNEPaAQlb77tf0csuq27EsVpy6ett584EcRTp6pTDLoGWVxCD77y5iU5FauOvhsI4o1APwPoSQ==} dev: true @@ -22796,10 +23011,6 @@ packages: events: 3.3.0 dev: true - /strict-event-emitter@0.4.6: - resolution: {integrity: sha512-12KWeb+wixJohmnwNFerbyiBrAlq5qJLwIt38etRtKtmmHyDSoGlIqFE9wx+4IwG0aDjI7GV8tc8ZccjWZZtTg==} - dev: true - /string-argv@0.3.1: resolution: {integrity: sha512-a1uQGz7IyVy9YwhqjZIZu1c8JO8dNIe20xBmSS6qu9kv++k3JGzCVmprbNN5Kn+BgzD5E7YYwg1CcjuJMRNsvg==} engines: {node: '>=0.6.19'} @@ -22998,6 +23209,12 @@ packages: engines: {node: '>=8'} dev: true + /strip-literal@0.4.2: + resolution: {integrity: sha512-pv48ybn4iE1O9RLgCAN0iU4Xv7RlBTiit6DKmMiErbs9x1wH6vXBs45tWc0H5wUIF6TLTrKweqkmYF/iraQKNw==} + dependencies: + acorn: 8.8.2 + dev: true + /strip-literal@1.0.1: resolution: {integrity: sha512-QZTsipNpa2Ppr6v1AmJHESqJ3Uz247MUS0OjrnnZjFAvEoWqxuyFuXn2xLgMtRnijJShAa1HL0gtJyUs7u7n3Q==} dependencies: @@ -23999,8 +24216,25 @@ packages: vfile: 4.2.1 dev: true - /unimport@3.0.7(rollup@3.26.0): - resolution: {integrity: sha512-2dVQUxJEGcrSZ0U4qtwJVODrlfyGcwmIOoHVqbAFFUx7kPoEN5JWr1cZFhLwoAwTmZOvqAm3YIkzv1engIQocg==} + /unimport@0.6.7(esbuild@0.17.15)(rollup@3.20.2)(vite@4.2.1): + resolution: {integrity: sha512-EMoVqDjswHkU+nD098QYHXH7Mkw7KwGDQAyeRF2lgairJnuO+wpkhIcmCqrD1OPJmsjkTbJ2tW6Ap8St0PuWZA==} + dependencies: + '@rollup/pluginutils': 5.0.2(rollup@3.20.2) + escape-string-regexp: 5.0.0 + fast-glob: 3.2.12 + local-pkg: 0.4.3 + magic-string: 0.26.7 + mlly: 0.5.16 + pathe: 0.3.9 + scule: 0.3.2 + strip-literal: 0.4.2 + unplugin: 0.9.5(esbuild@0.17.15)(rollup@3.20.2)(vite@4.2.1) + transitivePeerDependencies: + - rollup + dev: true + + /unimport@3.0.6(rollup@3.20.2): + resolution: {integrity: sha512-GYxGJ1Bri1oqx8VFDjdgooGzeK7jBk3bvhXmamTIpu3nONOcUMGwZbX7X0L5RA7OWMXpR4vzpSQP7pXUzJg1/Q==} dependencies: '@rollup/pluginutils': 5.0.2(rollup@3.26.0) escape-string-regexp: 5.0.0 @@ -24189,8 +24423,27 @@ packages: engines: {node: '>= 0.8'} dev: true - /unplugin-auto-import@0.16.4(@vueuse/core@10.2.1)(rollup@3.26.0): - resolution: {integrity: sha512-xdgBa9NAS3JG8HjkAZHSbGSMlrjKpaWKXGUzaF6RzEtr980RCl1t0Zsu0skUInNYrEQfqaHc7aGWPv41DLTK/w==} + /unplugin-auto-import@0.11.2(esbuild@0.17.15)(rollup@3.20.2)(vite@4.2.1): + resolution: {integrity: sha512-1+VwBfn9dtiYv9SQLKP1AvZolUbK9xTVeAT+iOcEk4EHSFUlmIqBVLEKI76cifSQTLOJ3rZyPrEgptf3SZNLlQ==} + engines: {node: '>=14'} + peerDependencies: + '@vueuse/core': '*' + peerDependenciesMeta: + '@vueuse/core': + optional: true + dependencies: + '@antfu/utils': 0.5.2 + '@rollup/pluginutils': 4.2.1 + local-pkg: 0.4.2 + magic-string: 0.26.7 + unimport: 0.6.7(esbuild@0.17.15)(rollup@3.20.2)(vite@4.2.1) + unplugin: 0.9.5(esbuild@0.17.15)(rollup@3.20.2)(vite@4.2.1) + transitivePeerDependencies: + - rollup + dev: true + + /unplugin-auto-import@0.15.3(@vueuse/core@10.1.2)(rollup@3.20.2): + resolution: {integrity: sha512-RLT8SqbPn4bT7yBshZId0uPSofKWnwr66RyDaxWaFb/+f7OTDOWAsVNz+hOQLBWSjvbekr2xZY9ccS8TDHJbCQ==} engines: {node: '>=14'} peerDependencies: '@nuxt/kit': ^3.2.2 @@ -24202,8 +24455,8 @@ packages: optional: true dependencies: '@antfu/utils': 0.7.4 - '@rollup/pluginutils': 5.0.2(rollup@3.26.0) - '@vueuse/core': 10.2.1(vue@3.3.4) + '@rollup/pluginutils': 5.0.2(rollup@3.20.2) + '@vueuse/core': 10.1.2(vue@3.2.47) local-pkg: 0.4.3 magic-string: 0.30.1 minimatch: 9.0.1 @@ -24213,6 +24466,33 @@ packages: - rollup dev: true + /unplugin-vue-components@0.22.4(esbuild@0.17.15)(rollup@3.20.2)(vite@4.2.1)(vue@3.2.47): + resolution: {integrity: sha512-2rRZcM9OnJGXnYxQNfaceEYuPeVACcWySIjy8WBwIiN3onr980TmA3XE5pRJFt8zoQrUA+c46oyIq96noLqrEQ==} + engines: {node: '>=14'} + peerDependencies: + '@nuxt/kit': ^3.2.2 + '@vueuse/core': '*' + peerDependenciesMeta: + '@nuxt/kit': + optional: true + '@vueuse/core': + optional: true + dependencies: + '@antfu/utils': 0.7.4 + '@rollup/pluginutils': 5.0.2(rollup@3.20.2) + chokidar: 3.5.3 + debug: 4.3.4(supports-color@8.1.1) + fast-glob: 3.2.11 + local-pkg: 0.4.2 + magic-string: 0.26.3 + minimatch: 5.1.0 + resolve: 1.22.1 + unplugin: 0.9.5(esbuild@0.17.15)(rollup@3.20.2)(vite@4.2.1) + vue: 3.2.47 + transitivePeerDependencies: + - rollup + dev: true + /unplugin-vue-components@0.25.1(rollup@2.79.1)(vue@3.3.4): resolution: {integrity: sha512-kzS2ZHVMaGU2XEO2keYQcMjNZkanDSGDdY96uQT9EPe+wqSZwwgbFfKVJ5ti0+8rGAcKHColwKUvctBhq2LJ3A==} engines: {node: '>=14'} @@ -24242,8 +24522,8 @@ packages: - supports-color dev: true - /unplugin-vue-components@0.25.1(rollup@3.26.0)(vue@3.3.4): - resolution: {integrity: sha512-kzS2ZHVMaGU2XEO2keYQcMjNZkanDSGDdY96uQT9EPe+wqSZwwgbFfKVJ5ti0+8rGAcKHColwKUvctBhq2LJ3A==} + /unplugin-vue-components@0.24.1(rollup@3.20.2)(vue@3.2.47): + resolution: {integrity: sha512-T3A8HkZoIE1Cja95xNqolwza0yD5IVlgZZ1PVAGvVCx8xthmjsv38xWRCtHtwl+rvZyL9uif42SRkDGw9aCfMA==} engines: {node: '>=14'} peerDependencies: '@babel/parser': ^7.15.8 @@ -24261,16 +24541,38 @@ packages: debug: 4.3.4(supports-color@8.1.1) fast-glob: 3.3.0 local-pkg: 0.4.3 - magic-string: 0.30.1 - minimatch: 9.0.1 + magic-string: 0.30.0 + minimatch: 7.4.2 resolve: 1.22.2 unplugin: 1.3.1 - vue: 3.3.4 + vue: 3.2.47 transitivePeerDependencies: - rollup - supports-color dev: true + /unplugin@0.9.5(esbuild@0.17.15)(rollup@3.20.2)(vite@4.2.1): + resolution: {integrity: sha512-luraheyfxwtvkvHpsOvMNv7IjLdORTWKZp0gWYNHGLi2ImON3iIZOj464qEyyEwLA/EMt12fC415HW9zRpOfTg==} + peerDependencies: + '@babel/parser': ^7.15.8 + '@nuxt/kit': ^3.2.2 + vue: 2 || 3 + peerDependenciesMeta: + '@babel/parser': + optional: true + '@nuxt/kit': + optional: true + dependencies: + '@antfu/utils': 0.7.2 + '@rollup/pluginutils': 5.0.2(rollup@3.20.2) + chokidar: 3.5.3 + esbuild: 0.17.15 + rollup: 3.20.2 + vite: 4.2.1(@types/node@18.15.11) + webpack-sources: 3.2.3 + webpack-virtual-modules: 0.4.5 + dev: true + /unplugin@1.3.1: resolution: {integrity: sha512-h4uUTIvFBQRxUKS2Wjys6ivoeofGhxzTe2sRWlooyjHXVttcVfV/JiavNd3d4+jty0SVV0dxGw9AkY9MwiaCEw==} dependencies: @@ -25106,6 +25408,10 @@ packages: - supports-color dev: true + /webpack-virtual-modules@0.4.5: + resolution: {integrity: sha512-8bWq0Iluiv9lVf9YaqWQ9+liNgXSHICm+rg544yRgGYaR8yXZTVBaHZkINZSB2yZSWo4b0F6MIxqJezVfOEAlg==} + dev: true + /webpack-virtual-modules@0.5.0: resolution: {integrity: sha512-kyDivFZ7ZM0BVOUteVbDFhlRt7Ah/CSPwJdi8hBpkK7QLumUqdLtVfm/PX/hkcnrvr0i77fO5+TjZ94Pe+C9iw==} dev: true diff --git a/test/core/test/happy-dom.test.ts b/test/core/test/happy-dom.test.ts index bef420b134a8..e56e30b0f0a7 100644 --- a/test/core/test/happy-dom.test.ts +++ b/test/core/test/happy-dom.test.ts @@ -110,8 +110,9 @@ it('globals are the same', () => { expect(window.Blob).toBe(globalThis.Blob) expect(window.globalThis.Blob).toBe(globalThis.Blob) expect(Blob).toBe(globalThis.Blob) - expect(document.defaultView).toBe(window) - expect(document.defaultView).toBe(globalThis) - const el = document.createElement('div') - expect(el.ownerDocument.defaultView).toBe(globalThis) + // TODO: vm + // expect(document.defaultView).toBe(window) + // expect(document.defaultView).toBe(globalThis) + // const el = document.createElement('div') + // expect(el.ownerDocument.defaultView).toBe(globalThis) }) From e379319c5bf96ecab854e3e86178b06125ae3ac6 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 18 Apr 2023 09:38:01 +0200 Subject: [PATCH 02/87] refactor: move "native" logic into a separate class --- packages/vite-node/src/client.ts | 140 ++++------------------- packages/vite-node/src/native.ts | 188 +++++++++++++++++++++++++++++++ test/core/vitest.config.ts | 3 + 3 files changed, 210 insertions(+), 121 deletions(-) create mode 100644 packages/vite-node/src/native.ts diff --git a/packages/vite-node/src/client.ts b/packages/vite-node/src/client.ts index 18edd5a3993c..36924ac7b7fe 100644 --- a/packages/vite-node/src/client.ts +++ b/packages/vite-node/src/client.ts @@ -4,14 +4,12 @@ import { createRequire } from 'node:module' import { dirname } from 'node:path' import { fileURLToPath, pathToFileURL } from 'node:url' import vm from 'node:vm' -import { readFile } from 'node:fs/promises' import { resolve } from 'pathe' -import { hasESMSyntax } from 'mlly' -import { resolve as resolveModule } from 'import-meta-resolve' import createDebug from 'debug' import { VALID_ID_PREFIX, cleanUrl, isInternalRequest, isNodeBuiltin, isPrimitive, normalizeModuleId, normalizeRequestId, slash, toFilePath } from './utils' import type { HotContext, ModuleCache, ViteNodeRunnerOptions } from './types' import { extractSourceMap } from './source-map' +import { NativeNodeVmClient } from './native' const { setTimeout, clearTimeout } = globalThis @@ -184,13 +182,15 @@ export class ViteNodeRunner { * Keys of the map are filepaths, or plain package names */ moduleCache: ModuleCacheMap - externalCache: ModuleCacheMap + + nativeImporter?: NativeNodeVmClient constructor(public options: ViteNodeRunnerOptions) { this.root = options.root ?? process.cwd() this.moduleCache = options.moduleCache ?? new ModuleCacheMap() - this.externalCache = options.externalCache ?? new ModuleCacheMap() this.debug = options.debug ?? (typeof process !== 'undefined' ? !!process.env.VITE_NODE_DEBUG_RUNNER : false) + if (this.options.context) + this.nativeImporter = new NativeNodeVmClient(this.options.context) } async executeFile(file: string) { @@ -314,7 +314,7 @@ export class ViteNodeRunner { if (externalize) { debugNative(externalize) - const { exports } = await this.interopedImport(externalize) + const exports = await this.interopedImport(externalize) mod.exports = exports return exports } @@ -451,47 +451,14 @@ export class ViteNodeRunner { } } - async importModuleDynamically(specifier: string, script: vm.Script) { - const vmContext = this.options.context - if (!vmContext) + async importModuleDynamically(specifier: string, script: vm.Module): Promise { + const importer = this.nativeImporter + if (!importer) throw new Error('[vite-node] importModuleDynamically is not supported without a context') - // @ts-expect-error - private API - const moduleUrl = await resolveModule(specifier, script.identifier) - return this.createModule(moduleUrl.toString()) - } - - private async createModule(identifier: string) { - const vmContext = this.options.context! - const { format, module } = await this.interopedImport(identifier) - if (format === 'esm') - return module - const moduleKeys = Object.keys(module) - const importModuleDynamically = this.importModuleDynamically.bind(this) - const m: any = new vm.SyntheticModule( - // TODO: fix "default" shenanigans - Array.from(new Set([...moduleKeys, 'default'])), - () => { - for (const key of moduleKeys) - m.setExport(key, module[key]) - if (format === 'cjs' && !moduleKeys.includes('default')) - m.setExport('default', module) - }, - { - context: vmContext, - identifier, - // @ts-expect-error actually supported - importModuleDynamically, - }, - ) - - if (m.status === 'unlinked') - await m.link(importModuleDynamically) - - if (m.status === 'linked') - await m.evaluate() - - return m + const identifier = await importer.resolveAsync(specifier, script.identifier) + const { module } = await importer.evaluateImport(identifier) + return module } prepareContext(context: Record) { @@ -510,87 +477,18 @@ export class ViteNodeRunner { return !path.endsWith('.mjs') && 'default' in mod } - async externalizedImport(identifier: string) { - const vmContext = this.options.context - - if (!vmContext || isNodeBuiltin(identifier)) - return { format: 'builtin', module: await import(identifier) } - - const importModuleDynamically = this.importModuleDynamically.bind(this) as any - const fileUrl = identifier.startsWith('file:') ? identifier : pathToFileURL(identifier).toString() - const pathUrl = identifier.startsWith('file:') ? fileURLToPath(identifier) : identifier - - // TODO: dependencies are in the loop - const mod = this.externalCache.get(pathUrl) - - if (mod.promise) - return await mod.promise - - const content = await readFile(pathUrl, 'utf-8') - - // TODO: dirty check - if (!hasESMSyntax(content)) { - const cjsModule = `(function (exports, require, module, __filename, __dirname) { ${content} })` - const fn = vm.runInContext(cjsModule, vmContext, { - filename: pathUrl, - }) - const exports = mod.exports ??= (mod.exports = {}) - const module = { exports } - const require = createRequire(fileUrl) - const __dirname = dirname(pathUrl) - fn(module.exports, require, module, pathUrl, __dirname) - return { format: 'cjs', module: exports } - } - - const m = new vm.SourceTextModule( - content, - { - identifier: fileUrl, - context: vmContext, - importModuleDynamically, - initializeImportMeta(meta, mod) { - meta.url = mod.identifier - }, - }, - ) - - const promise = new Promise((resolve) => { - const result = { format: 'esm', module: m } - const finish = () => resolve(result) - if (m.status === 'unlinked') { - m.link(importModuleDynamically).then(() => { - if (m.status === 'linked') - m.evaluate().then(finish) - else - finish() - }) - } - else { - finish() - } - }) - - mod.promise = promise - - return await promise - } - /** * Import a module and interop it */ async interopedImport(path: string) { - const { format, module: importedModule } = await this.externalizedImport(path) + const importedModule = this.nativeImporter + ? this.nativeImporter.import(path) + : await import(path) - let namespace - if (importedModule instanceof vm.Module) - namespace = importedModule.namespace - else - namespace = importedModule - - if (!this.shouldInterop(path, namespace)) - return { format, exports: namespace, module: importedModule } + if (!this.shouldInterop(path, importedModule)) + return importedModule - const { mod, defaultExport } = interopModule(namespace) + const { mod, defaultExport } = interopModule(importedModule) const exports = new Proxy(mod, { get(mod, prop) { @@ -617,7 +515,7 @@ export class ViteNodeRunner { }, }) - return { format, exports, module: importedModule } + return exports } } diff --git a/packages/vite-node/src/native.ts b/packages/vite-node/src/native.ts new file mode 100644 index 000000000000..fd13dc059cd9 --- /dev/null +++ b/packages/vite-node/src/native.ts @@ -0,0 +1,188 @@ +import vm from 'node:vm' +import { fileURLToPath, pathToFileURL } from 'node:url' +import { dirname } from 'node:path' +import { createRequire } from 'node:module' +import { readFileSync } from 'node:fs' +import { readFile } from 'node:fs/promises' +import { resolve as resolveModule } from 'import-meta-resolve' +import { hasESMSyntax } from 'mlly' +import { extname } from 'pathe' +import { isNodeBuiltin } from './utils' + +const _require = createRequire(import.meta.url) + +export class NativeNodeVmClient { + private context: vm.Context + + private requireCache = _require.cache + private moduleCache = new Map>() + + constructor(context: vm.Context) { + this.context = context + } + + importModuleDynamically = async (specifier: string, script: vm.Module) => { + const identifier = await this.resolveAsync(specifier, script.identifier) + const { module } = await this.evaluateImport(identifier) + return module + } + + async resolveAsync(specifier: string, parent: string) { + return resolveModule(specifier, parent) + } + + private wrapSynteticModule(identifier: string, format: 'esm' | 'builtin' | 'cjs', exports: Record) { + const moduleKeys = Object.keys(exports) + const m: any = new vm.SyntheticModule( + // TODO: fix "default" shenanigans + Array.from(new Set([...moduleKeys, 'default'])), + () => { + for (const key of moduleKeys) + m.setExport(key, exports[key]) + if (format !== 'esm' && !moduleKeys.includes('default')) + m.setExport('default', exports) + }, + { + context: this.context, + identifier, + }, + ) + return m + } + + private async evaluateModule(m: T): Promise { + if (m.status === 'unlinked') + await m.link(this.importModuleDynamically) + + if (m.status === 'linked') + await m.evaluate() + + return m + } + + private createCjsModule(filename: string) { + const _require = createRequire(filename) + // doesn't respect "extensions" + const require: NodeRequire = (id: string) => { + const filename = _require.resolve(id) + if (isNodeBuiltin(filename)) + return _require(filename) + const code = readFileSync(filename, 'utf-8') + return this.evaluateCjsModule(filename, code) + } + require.resolve = _require.resolve + require.extensions = _require.extensions + require.main = _require.main + require.cache = this.requireCache + const __dirname = dirname(filename) + // dirty non-spec implementation - doesn't support children, parent, etc + const module: NodeModule = { + exports: {}, + isPreloading: false, + require, + id: filename, + filename, + loaded: false, + parent: null, + children: [], + path: __dirname, + paths: [], + } + return module + } + + private evaluateJsonCjsModule(filename: string, code: string): Record { + const module = this.createCjsModule(filename) + this.requireCache[filename] = module + module.exports = JSON.parse(code) + module.loaded = true + return module.exports + } + + // very naive implementation for Node.js require + private evaluateCjsModule(filename: string, code: string): Record { + const cached = this.requireCache[filename] + if (cached) + return cached.exports + + if (extname(filename) === '.json') + return this.evaluateJsonCjsModule(filename, code) + + const cjsModule = `(function (exports, require, module, __filename, __dirname) { ${code} })` + const script = new vm.Script(cjsModule, { + filename, + importModuleDynamically: this.importModuleDynamically as any, + }) + // @ts-expect-error mark script with current identifier + script.identifier = filename + const fn = script.runInContext(this.context) + const __dirname = dirname(filename) + const module = this.createCjsModule(filename) + this.requireCache[filename] = module + fn(module.exports, module.require, module, filename, __dirname) + module.loaded = true + return module.exports + } + + async evaluateEsmModule(fileUrl: string, code: string) { + const cached = this.moduleCache.get(fileUrl) + if (cached) + return cached + const m = new vm.SourceTextModule( + code, + { + identifier: fileUrl, + context: this.context, + importModuleDynamically: this.importModuleDynamically as any, + initializeImportMeta: (meta, mod) => { + meta.url = mod.identifier + // meta.resolve = (specifier: string, importer?: string) => + // this.resolveAsync(specifier, importer ?? mod.identifier) + }, + }, + ) + const promise = this.evaluateModule(m) + this.moduleCache.set(fileUrl, promise) + return await promise + } + + async evaluateImport(identifier: string) { + if (isNodeBuiltin(identifier)) { + const exports = await import(identifier) + const module = await this.evaluateModule(this.wrapSynteticModule(identifier, 'builtin', exports)) + return { + format: 'builtin', + module, + exports, + } + } + + const isFileUrl = identifier.startsWith('file://') + const fileUrl = isFileUrl ? identifier : pathToFileURL(identifier).toString() + const pathUrl = isFileUrl ? fileURLToPath(identifier) : identifier + const code = await readFile(pathUrl, 'utf-8') + + if (identifier.endsWith('.cjs') || !hasESMSyntax(code)) { + const exports = this.evaluateCjsModule(pathUrl, code) + const module = await this.evaluateModule(this.wrapSynteticModule(fileUrl, 'cjs', exports)) + return { + format: 'cjs', + module, + exports, + } + } + + const module = await this.evaluateEsmModule(fileUrl, code) + + return { + format: 'esm', + module, + exports: module.namespace, + } + } + + async import(identifier: string) { + const { exports } = await this.evaluateImport(identifier) + return exports + } +} diff --git a/test/core/vitest.config.ts b/test/core/vitest.config.ts index 9da89210a05d..30ea3c18fdb0 100644 --- a/test/core/vitest.config.ts +++ b/test/core/vitest.config.ts @@ -49,6 +49,9 @@ export default defineConfig({ setupFiles: [ './test/setup.ts', ], + poolMatchGlobs: [ + ['**/*', 'vm'], + ], testNamePattern: '^((?!does not include test that).)*$', coverage: { provider: 'istanbul', From f8a7e1c3f032d14bcb047a9c5c66632931a5280b Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 18 Apr 2023 10:05:11 +0200 Subject: [PATCH 03/87] IT IS ALIVE --- packages/vite-node/src/client.ts | 18 ++---------- packages/vite-node/src/native.ts | 50 +++++++++++--------------------- 2 files changed, 20 insertions(+), 48 deletions(-) diff --git a/packages/vite-node/src/client.ts b/packages/vite-node/src/client.ts index 36924ac7b7fe..f5afb10c2f8b 100644 --- a/packages/vite-node/src/client.ts +++ b/packages/vite-node/src/client.ts @@ -437,11 +437,11 @@ export class ViteNodeRunner { columnOffset: -codeDefinition.length, } - if (vmContext) { + if (vmContext && this.nativeImporter) { const fn = vm.runInContext(code, vmContext, { ...options, // if we encountered an import, it's not inlined - importModuleDynamically: this.importModuleDynamically.bind(this) as any, + importModuleDynamically: this.nativeImporter.importModuleDynamically as any, }) await fn(...Object.values(context)) } @@ -451,16 +451,6 @@ export class ViteNodeRunner { } } - async importModuleDynamically(specifier: string, script: vm.Module): Promise { - const importer = this.nativeImporter - if (!importer) - throw new Error('[vite-node] importModuleDynamically is not supported without a context') - - const identifier = await importer.resolveAsync(specifier, script.identifier) - const { module } = await importer.evaluateImport(identifier) - return module - } - prepareContext(context: Record) { return context } @@ -490,7 +480,7 @@ export class ViteNodeRunner { const { mod, defaultExport } = interopModule(importedModule) - const exports = new Proxy(mod, { + return new Proxy(mod, { get(mod, prop) { if (prop === 'default') return defaultExport @@ -514,8 +504,6 @@ export class ViteNodeRunner { } }, }) - - return exports } } diff --git a/packages/vite-node/src/native.ts b/packages/vite-node/src/native.ts index fd13dc059cd9..47a8dd8fc33a 100644 --- a/packages/vite-node/src/native.ts +++ b/packages/vite-node/src/native.ts @@ -15,7 +15,7 @@ export class NativeNodeVmClient { private context: vm.Context private requireCache = _require.cache - private moduleCache = new Map>() + private moduleCache = new Map() constructor(context: vm.Context) { this.context = context @@ -23,8 +23,7 @@ export class NativeNodeVmClient { importModuleDynamically = async (specifier: string, script: vm.Module) => { const identifier = await this.resolveAsync(specifier, script.identifier) - const { module } = await this.evaluateImport(identifier) - return module + return await this.createModule(identifier) } async resolveAsync(specifier: string, parent: string) { @@ -50,7 +49,7 @@ export class NativeNodeVmClient { return m } - private async evaluateModule(m: T): Promise { + async evaluateModule(m: T): Promise { if (m.status === 'unlinked') await m.link(this.importModuleDynamically) @@ -60,7 +59,7 @@ export class NativeNodeVmClient { return m } - private createCjsModule(filename: string) { + private createCjsNodeModule(filename: string) { const _require = createRequire(filename) // doesn't respect "extensions" const require: NodeRequire = (id: string) => { @@ -92,7 +91,7 @@ export class NativeNodeVmClient { } private evaluateJsonCjsModule(filename: string, code: string): Record { - const module = this.createCjsModule(filename) + const module = this.createCjsNodeModule(filename) this.requireCache[filename] = module module.exports = JSON.parse(code) module.loaded = true @@ -101,6 +100,7 @@ export class NativeNodeVmClient { // very naive implementation for Node.js require private evaluateCjsModule(filename: string, code: string): Record { + // console.log('cjs', filename) const cached = this.requireCache[filename] if (cached) return cached.exports @@ -117,14 +117,14 @@ export class NativeNodeVmClient { script.identifier = filename const fn = script.runInContext(this.context) const __dirname = dirname(filename) - const module = this.createCjsModule(filename) + const module = this.createCjsNodeModule(filename) this.requireCache[filename] = module fn(module.exports, module.require, module, filename, __dirname) module.loaded = true return module.exports } - async evaluateEsmModule(fileUrl: string, code: string) { + async createEsmModule(fileUrl: string, code: string) { const cached = this.moduleCache.get(fileUrl) if (cached) return cached @@ -141,20 +141,14 @@ export class NativeNodeVmClient { }, }, ) - const promise = this.evaluateModule(m) - this.moduleCache.set(fileUrl, promise) - return await promise + this.moduleCache.set(fileUrl, m) + return m } - async evaluateImport(identifier: string) { + async createModule(identifier: string): Promise { if (isNodeBuiltin(identifier)) { const exports = await import(identifier) - const module = await this.evaluateModule(this.wrapSynteticModule(identifier, 'builtin', exports)) - return { - format: 'builtin', - module, - exports, - } + return await this.wrapSynteticModule(identifier, 'builtin', exports) } const isFileUrl = identifier.startsWith('file://') @@ -164,25 +158,15 @@ export class NativeNodeVmClient { if (identifier.endsWith('.cjs') || !hasESMSyntax(code)) { const exports = this.evaluateCjsModule(pathUrl, code) - const module = await this.evaluateModule(this.wrapSynteticModule(fileUrl, 'cjs', exports)) - return { - format: 'cjs', - module, - exports, - } + return this.wrapSynteticModule(fileUrl, 'cjs', exports) } - const module = await this.evaluateEsmModule(fileUrl, code) - - return { - format: 'esm', - module, - exports: module.namespace, - } + return await this.createEsmModule(fileUrl, code) } async import(identifier: string) { - const { exports } = await this.evaluateImport(identifier) - return exports + const module = await this.createModule(identifier) + await this.evaluateModule(module) + return module.namespace } } From a0de65c08b4da48d37a97412724852b835033c3b Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 18 Apr 2023 11:04:44 +0200 Subject: [PATCH 04/87] chore: cleanup --- packages/vite-node/src/native.ts | 2 +- packages/vitest/src/runtime/entry-vm.ts | 4 +++- packages/vitest/src/runtime/vm.ts | 15 ++++++++++---- pnpm-lock.yaml | 26 ++++++++++++++++++------- 4 files changed, 34 insertions(+), 13 deletions(-) diff --git a/packages/vite-node/src/native.ts b/packages/vite-node/src/native.ts index 47a8dd8fc33a..1f19f1cfef03 100644 --- a/packages/vite-node/src/native.ts +++ b/packages/vite-node/src/native.ts @@ -146,7 +146,7 @@ export class NativeNodeVmClient { } async createModule(identifier: string): Promise { - if (isNodeBuiltin(identifier)) { + if (isNodeBuiltin(identifier) || identifier.startsWith('data:text/')) { const exports = await import(identifier) return await this.wrapSynteticModule(identifier, 'builtin', exports) } diff --git a/packages/vitest/src/runtime/entry-vm.ts b/packages/vitest/src/runtime/entry-vm.ts index 7a7ba1720c03..3d8673cf3b24 100644 --- a/packages/vitest/src/runtime/entry-vm.ts +++ b/packages/vitest/src/runtime/entry-vm.ts @@ -5,10 +5,12 @@ import type { ContextTestEnvironment, ResolvedConfig } from '../types' import { getWorkerState } from '../utils/global' import type { VitestExecutor } from './execute' import { resolveTestRunner } from './runners' +import { setupCommonEnv } from './setup.common' export async function run(files: string[], config: ResolvedConfig, environment: ContextTestEnvironment, executor: VitestExecutor): Promise { const workerState = getWorkerState() + await setupCommonEnv(config) await startCoverageInsideWorker(config.coverage, executor) if (config.chaiConfig) @@ -16,7 +18,7 @@ export async function run(files: string[], config: ResolvedConfig, environment: const runner = await resolveTestRunner(config, executor) - workerState.durations.prepare = performance.now() - workerState.durations.prepare + // workerState.durations.prepare = performance.now() - workerState.durations.prepare await startTests(files, runner) diff --git a/packages/vitest/src/runtime/vm.ts b/packages/vitest/src/runtime/vm.ts index 8dacb28531a0..32e0e29f91e9 100644 --- a/packages/vitest/src/runtime/vm.ts +++ b/packages/vitest/src/runtime/vm.ts @@ -1,4 +1,4 @@ -import { pathToFileURL } from 'node:url' +import { URL, pathToFileURL } from 'node:url' import { ModuleCacheMap } from 'vite-node/client' import type { BirpcReturn } from 'birpc' import { createBirpc } from 'birpc' @@ -14,9 +14,12 @@ import { createVitestExecutor } from './execute' let rpc: BirpcReturn -const caches: Record }> = {} +const caches: Record +}> = {} -// TODO: currently expect only one file in this function, which makes sense because the function itself is called for each file separately +// TODO: currently expects only one file in this function, which makes sense because the function itself is called for each file separately export async function run(ctx: WorkerContext) { const file = ctx.files[0] const cache = caches[file] || {} @@ -88,13 +91,17 @@ export async function run(ctx: WorkerContext) { context.__vitest_worker__ = __vitest_worker__ context.__vitest_environment__ = config.environment + // TODO: all globals for test/core to work // TODO: copy more globals context.process = process - context.performance = performance + context.URL ??= URL + context.performance ??= performance context.setImmediate = setImmediate context.clearImmediate = clearImmediate context.setTimeout = setTimeout context.clearTimeout = clearTimeout + context.setInterval = setInterval + context.clearInterval = clearInterval context.global = context context.console = console diff --git a/pnpm-lock.yaml b/pnpm-lock.yaml index a20d733fcd5a..a8ddf6c6abcd 100644 --- a/pnpm-lock.yaml +++ b/pnpm-lock.yaml @@ -8771,7 +8771,7 @@ packages: resolution: {integrity: sha512-xryQlOEIe1TduDWAOphR0ihfebKFSWOXpIsk+70JskCfRfW+xALdnJ0r1ZOTo85F9Qsjk6vtlU7edTYHbls9tA==} dependencies: '@types/cheerio': 0.22.31 - '@types/react': 18.0.36 + '@types/react': 18.0.37 dev: true /@types/eslint-scope@3.7.4: @@ -9019,19 +9019,19 @@ packages: /@types/react-dom@18.0.6: resolution: {integrity: sha512-/5OFZgfIPSwy+YuIBP/FgJnQnsxhZhjjrnxudMddeblOouIodEQ75X14Rr4wGSG/bknL+Omy9iWlLo1u/9GzAA==} dependencies: - '@types/react': 18.0.36 + '@types/react': 18.0.37 dev: true /@types/react-dom@18.0.8: resolution: {integrity: sha512-C3GYO0HLaOkk9dDAz3Dl4sbe4AKUGTCfFIZsz3n/82dPNN8Du533HzKatDxeUYWu24wJgMP1xICqkWk1YOLOIw==} dependencies: - '@types/react': 18.0.36 + '@types/react': 18.0.37 dev: true /@types/react-is@17.0.3: resolution: {integrity: sha512-aBTIWg1emtu95bLTLx0cpkxwGW3ueZv71nE2YFBpL8k/z5czEW8yYpOo8Dp+UUAFAtKwNaOsh/ioSeQnWlZcfw==} dependencies: - '@types/react': 18.0.36 + '@types/react': 18.0.37 dev: false /@types/react-test-renderer@17.0.2: @@ -9043,7 +9043,7 @@ packages: /@types/react-transition-group@4.4.5: resolution: {integrity: sha512-juKD/eiSM3/xZYzjuzH6ZwpP+/lejltmiS3QEzV/vmb/Q8+HfDmxu+Baga8UEMGBqV88Nbg4l2hY/K2DkyaLLA==} dependencies: - '@types/react': 18.0.36 + '@types/react': 18.0.37 dev: false /@types/react@17.0.49: @@ -9068,6 +9068,14 @@ packages: '@types/prop-types': 15.7.5 '@types/scheduler': 0.16.2 csstype: 3.1.0 + dev: true + + /@types/react@18.0.37: + resolution: {integrity: sha512-4yaZZtkRN3ZIQD3KSEwkfcik8s0SWV+82dlJot1AbGYHCzJkWP3ENBY6wYeDRmKZ6HkrgoGAmR2HqdwYGp6OEw==} + dependencies: + '@types/prop-types': 15.7.5 + '@types/scheduler': 0.16.2 + csstype: 3.1.0 /@types/resolve@1.17.1: resolution: {integrity: sha512-yy7HuzQhj0dhGpD8RLXSZWEkLsV9ibvxvi6EiJ3bkqLAO1RGo0WbkWQiwpRlSFymTJRz0d3k5LM3kkx8ArDbLw==} @@ -11474,8 +11482,12 @@ packages: dev: true optional: true - /birpc@0.2.12: - resolution: {integrity: sha512-6Wz9FXuJ/FE4gDH+IGQhrYdalAvAQU1Yrtcu1UlMk3+9mMXxIRXiL+MxUcGokso42s+Fy+YoUXGLOdOs0siV3A==} + /birpc@0.2.11: + resolution: {integrity: sha512-OcUm84SBHRsmvSQhOLZRt5Awmw8WVknVcMDMaPE8GPwYxzc4mGE0EIytkWXayPjheGvm7s/Ci1wQZGwk7YPU6A==} + dev: true + + /birpc@0.2.3: + resolution: {integrity: sha512-mG7m06C2JkfuHSaLRHhtHtMEvyT1P1nUyyuk5W/7LMT2p7YYX/tfzJzD2ynZZHem3JTi6yJve0nHPdrs/gpXYg==} /bl@4.1.0: resolution: {integrity: sha512-1W07cM9gS6DcLperZfFSj+bWLtaPGSOHWhPiGzXmvVJbRLdG82sH/Kn8EtW1VqWVA54AKf2h5k5BbnIbwF3h6w==} From 5ff7d019aba05efaf80b61d22ecb72dfcbddc08a Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 18 Apr 2023 12:40:38 +0200 Subject: [PATCH 05/87] refactor: cleanup --- packages/vite-node/src/client.ts | 30 ++--- packages/vitest/rollup.config.js | 1 + packages/vitest/src/runtime/console.ts | 113 ++++++++++++++++++ packages/vitest/src/runtime/entry-vm.ts | 22 +++- packages/vitest/src/runtime/execute.ts | 93 ++++++++++---- .../src/runtime/external-executor.ts} | 44 ++++--- packages/vitest/src/runtime/setup.node.ts | 109 +---------------- packages/vitest/src/runtime/vm.ts | 26 ++-- 8 files changed, 256 insertions(+), 182 deletions(-) create mode 100644 packages/vitest/src/runtime/console.ts rename packages/{vite-node/src/native.ts => vitest/src/runtime/external-executor.ts} (77%) diff --git a/packages/vite-node/src/client.ts b/packages/vite-node/src/client.ts index f5afb10c2f8b..201d4d48dbdb 100644 --- a/packages/vite-node/src/client.ts +++ b/packages/vite-node/src/client.ts @@ -9,7 +9,6 @@ import createDebug from 'debug' import { VALID_ID_PREFIX, cleanUrl, isInternalRequest, isNodeBuiltin, isPrimitive, normalizeModuleId, normalizeRequestId, slash, toFilePath } from './utils' import type { HotContext, ModuleCache, ViteNodeRunnerOptions } from './types' import { extractSourceMap } from './source-map' -import { NativeNodeVmClient } from './native' const { setTimeout, clearTimeout } = globalThis @@ -183,14 +182,10 @@ export class ViteNodeRunner { */ moduleCache: ModuleCacheMap - nativeImporter?: NativeNodeVmClient - constructor(public options: ViteNodeRunnerOptions) { this.root = options.root ?? process.cwd() this.moduleCache = options.moduleCache ?? new ModuleCacheMap() this.debug = options.debug ?? (typeof process !== 'undefined' ? !!process.env.VITE_NODE_DEBUG_RUNNER : false) - if (this.options.context) - this.nativeImporter = new NativeNodeVmClient(this.options.context) } async executeFile(file: string) { @@ -426,8 +421,7 @@ export class ViteNodeRunner { return exports } - async runModule(context: Record, transformed: string) { - const vmContext = this.options.context + protected async runModule(context: Record, transformed: string) { // add 'use strict' since ESM enables it by default const codeDefinition = `'use strict';async (${Object.keys(context).join(',')})=>{{` const code = `${codeDefinition}${transformed}\n}}` @@ -437,18 +431,8 @@ export class ViteNodeRunner { columnOffset: -codeDefinition.length, } - if (vmContext && this.nativeImporter) { - const fn = vm.runInContext(code, vmContext, { - ...options, - // if we encountered an import, it's not inlined - importModuleDynamically: this.nativeImporter.importModuleDynamically as any, - }) - await fn(...Object.values(context)) - } - else { - const fn = vm.runInThisContext(code, options) - await fn(...Object.values(context)) - } + const fn = vm.runInThisContext(code, options) + await fn(...Object.values(context)) } prepareContext(context: Record) { @@ -467,13 +451,15 @@ export class ViteNodeRunner { return !path.endsWith('.mjs') && 'default' in mod } + protected importExternalModule(path: string) { + return import(path) + } + /** * Import a module and interop it */ async interopedImport(path: string) { - const importedModule = this.nativeImporter - ? this.nativeImporter.import(path) - : await import(path) + const importedModule = await this.importExternalModule(path) if (!this.shouldInterop(path, importedModule)) return importedModule diff --git a/packages/vitest/rollup.config.js b/packages/vitest/rollup.config.js index 403c0b30e683..62526d018717 100644 --- a/packages/vitest/rollup.config.js +++ b/packages/vitest/rollup.config.js @@ -54,6 +54,7 @@ const external = [ 'node:worker_threads', 'node:fs', 'rollup', + 'node:vm', 'inspector', 'webdriverio', 'safaridriver', diff --git a/packages/vitest/src/runtime/console.ts b/packages/vitest/src/runtime/console.ts new file mode 100644 index 000000000000..89632d8dc241 --- /dev/null +++ b/packages/vitest/src/runtime/console.ts @@ -0,0 +1,113 @@ +import { Writable } from 'node:stream' +import { Console } from 'node:console' +import { getSafeTimers } from '@vitest/utils' +import { RealDate } from '../integrations/mock/date' +import { getWorkerState } from '../utils/global' +import { rpc } from './rpc' + +export function createCustomConsole() { + const stdoutBuffer = new Map() + const stderrBuffer = new Map() + const timers = new Map() + const unknownTestId = '__vitest__unknown_test__' + + const { setTimeout, clearTimeout } = getSafeTimers() + + // group sync console.log calls with macro task + function schedule(taskId: string) { + const timer = timers.get(taskId)! + const { stdoutTime, stderrTime } = timer + clearTimeout(timer.timer) + timer.timer = setTimeout(() => { + if (stderrTime < stdoutTime) { + sendStderr(taskId) + sendStdout(taskId) + } + else { + sendStdout(taskId) + sendStderr(taskId) + } + }) + } + function sendStdout(taskId: string) { + const buffer = stdoutBuffer.get(taskId) + if (!buffer) + return + const content = buffer.map(i => String(i)).join('') + const timer = timers.get(taskId)! + rpc().onUserConsoleLog({ + type: 'stdout', + content: content || '', + taskId, + time: timer.stdoutTime || RealDate.now(), + size: buffer.length, + }) + stdoutBuffer.set(taskId, []) + timer.stdoutTime = 0 + } + function sendStderr(taskId: string) { + const buffer = stderrBuffer.get(taskId) + if (!buffer) + return + const content = buffer.map(i => String(i)).join('') + const timer = timers.get(taskId)! + rpc().onUserConsoleLog({ + type: 'stderr', + content: content || '', + taskId, + time: timer.stderrTime || RealDate.now(), + size: buffer.length, + }) + stderrBuffer.set(taskId, []) + timer.stderrTime = 0 + } + + const stdout = new Writable({ + write(data, encoding, callback) { + const id = getWorkerState()?.current?.id ?? unknownTestId + let timer = timers.get(id) + if (timer) { + timer.stdoutTime = timer.stdoutTime || RealDate.now() + } + else { + timer = { stdoutTime: RealDate.now(), stderrTime: RealDate.now(), timer: 0 } + timers.set(id, timer) + } + let buffer = stdoutBuffer.get(id) + if (!buffer) { + buffer = [] + stdoutBuffer.set(id, buffer) + } + buffer.push(data) + schedule(id) + callback() + }, + }) + const stderr = new Writable({ + write(data, encoding, callback) { + const id = getWorkerState()?.current?.id ?? unknownTestId + let timer = timers.get(id) + if (timer) { + timer.stderrTime = timer.stderrTime || RealDate.now() + } + else { + timer = { stderrTime: RealDate.now(), stdoutTime: RealDate.now(), timer: 0 } + timers.set(id, timer) + } + let buffer = stderrBuffer.get(id) + if (!buffer) { + buffer = [] + stderrBuffer.set(id, buffer) + } + buffer.push(data) + schedule(id) + callback() + }, + }) + return new Console({ + stdout, + stderr, + colorMode: true, + groupIndentation: 2, + }) +} diff --git a/packages/vitest/src/runtime/entry-vm.ts b/packages/vitest/src/runtime/entry-vm.ts index 3d8673cf3b24..4cc2766c1dc7 100644 --- a/packages/vitest/src/runtime/entry-vm.ts +++ b/packages/vitest/src/runtime/entry-vm.ts @@ -1,4 +1,7 @@ +import { isatty } from 'node:tty' +import { createRequire } from 'node:module' import { startTests } from '@vitest/runner' +import { createColors, setupColors } from '@vitest/utils' import { setupChaiConfig } from '../integrations/chai' import { startCoverageInsideWorker, stopCoverageInsideWorker } from '../integrations/coverage' import type { ContextTestEnvironment, ResolvedConfig } from '../types' @@ -11,6 +14,15 @@ export async function run(files: string[], config: ResolvedConfig, environment: const workerState = getWorkerState() await setupCommonEnv(config) + + setupColors(createColors(isatty(1))) + + const _require = createRequire(import.meta.url) + // always mock "required" `css` files, because we cannot process them + _require.extensions['.css'] = () => ({}) + _require.extensions['.scss'] = () => ({}) + _require.extensions['.sass'] = () => ({}) + await startCoverageInsideWorker(config.coverage, executor) if (config.chaiConfig) @@ -18,11 +30,13 @@ export async function run(files: string[], config: ResolvedConfig, environment: const runner = await resolveTestRunner(config, executor) - // workerState.durations.prepare = performance.now() - workerState.durations.prepare + for (const file of files) { + workerState.filepath = file - await startTests(files, runner) + await startTests([file], runner) - await stopCoverageInsideWorker(config.coverage, executor) + workerState.filepath = undefined + } - workerState.environmentTeardownRun = true + await stopCoverageInsideWorker(config.coverage, executor) } diff --git a/packages/vitest/src/runtime/execute.ts b/packages/vitest/src/runtime/execute.ts index 96fc755ea692..14e90599393f 100644 --- a/packages/vitest/src/runtime/execute.ts +++ b/packages/vitest/src/runtime/execute.ts @@ -1,5 +1,5 @@ import { pathToFileURL } from 'node:url' -import type { Context } from 'node:vm' +import vm from 'node:vm' import { ModuleCacheMap, ViteNodeRunner } from 'vite-node/client' import { isInternalRequest, isNodeBuiltin, isPrimitive } from 'vite-node/utils' import type { ViteNodeRunnerOptions } from 'vite-node' @@ -7,17 +7,20 @@ import { normalize, relative, resolve } from 'pathe' import { processError } from '@vitest/utils/error' import type { MockMap } from '../types/mocker' import { getCurrentEnvironment, getWorkerState } from '../utils/global' -import type { ContextRPC, Environment, ResolvedConfig, ResolvedTestEnvironment } from '../types' +import type { ContextRPC, Environment, ResolvedConfig, ResolvedTestEnvironment, WorkerGlobalState } from '../types' import { distDir } from '../paths' import { loadEnvironment } from '../integrations/env' import { VitestMocker } from './mocker' -import { rpc } from './rpc' +import { rpc as getRpc } from './rpc' +import { ExternalModulesExecutor } from './external-executor' const entryUrl = pathToFileURL(resolve(distDir, 'entry.js')).href export interface ExecuteOptions extends ViteNodeRunnerOptions { mockMap: MockMap moduleDirectories?: string[] + context?: vm.Context + state?: WorkerGlobalState } export async function createVitestExecutor(options: ExecuteOptions) { @@ -37,12 +40,35 @@ let _viteNode: { export const moduleCache = new ModuleCacheMap() export const mockMap: MockMap = new Map() -export async function startViteNode(ctx: ContextRPC, vmContext?: Context) { +export async function startViteNode(ctx: ContextRPC) { if (_viteNode) return _viteNode + const executor = await startVitestExecutor(ctx) + + const environment = await loadEnvironment(ctx.environment.name, executor) + ctx.environment.environment = environment + + const { run } = await import(entryUrl) + + _viteNode = { run, executor, environment } + + return _viteNode +} + +export interface ContextExecutorOptions { + mockMap?: MockMap + moduleCache?: ModuleCacheMap + context?: vm.Context + state?: WorkerGlobalState + rpc?: typeof getRpc +} + +export async function startVitestExecutor(ctx: ContextRPC, options: ContextExecutorOptions = {}) { const { config } = ctx + const rpc = options.rpc ?? getRpc + const processExit = process.exit process.exit = (code = process.exitCode || 0): never => { @@ -52,7 +78,7 @@ export async function startViteNode(ctx: ContextRPC, vmContext?: Context) { } function catchError(err: unknown, type: string) { - const worker = getWorkerState() + const worker = options.state || getWorkerState() const error = processError(err) if (!isPrimitive(error)) { error.VITEST_TEST_NAME = worker.current?.name @@ -66,14 +92,16 @@ export async function startViteNode(ctx: ContextRPC, vmContext?: Context) { process.on('uncaughtException', e => catchError(e, 'Uncaught Exception')) process.on('unhandledRejection', e => catchError(e, 'Unhandled Rejection')) - let transformMode: 'ssr' | 'web' = ctx.environment.transformMode ?? 'ssr' + const getTransformMode = () => { + return ctx.environment.transformMode ?? ctx.environment.environment?.transformMode ?? 'ssr' + } - const executor = await createVitestExecutor({ + return await createVitestExecutor({ fetchModule(id) { - return rpc().fetch(id, transformMode) + return rpc().fetch(id, getTransformMode()) }, resolveId(id, importer) { - return rpc().resolveId(id, importer, transformMode) + return rpc().resolveId(id, importer, getTransformMode()) }, moduleCache, mockMap, @@ -81,22 +109,13 @@ export async function startViteNode(ctx: ContextRPC, vmContext?: Context) { moduleDirectories: config.deps.moduleDirectories, root: config.root, base: config.base, - context: vmContext, + ...options, }) - - const environment = await loadEnvironment(ctx.environment.name, executor) - ctx.environment.environment = environment - transformMode = ctx.environment.transformMode ?? environment.transformMode ?? 'ssr' - - const { run } = await import(entryUrl) - - _viteNode = { run, executor, environment } - - return _viteNode } export class VitestExecutor extends ViteNodeRunner { public mocker: VitestMocker + public externalModules?: ExternalModulesExecutor constructor(public options: ExecuteOptions) { super(options) @@ -108,6 +127,9 @@ export class VitestExecutor extends ViteNodeRunner { writable: true, configurable: true, }) + + if (options.context) + this.externalModules = new ExternalModulesExecutor(options.context) } shouldResolveId(id: string, _importee?: string | undefined): boolean { @@ -144,6 +166,35 @@ export class VitestExecutor extends ViteNodeRunner { } } + protected async runModule(context: Record, transformed: string) { + const vmContext = this.options.context + + if (!vmContext || !this.externalModules) + return super.runModule(context, transformed) + + // add 'use strict' since ESM enables it by default + const codeDefinition = `'use strict';async (${Object.keys(context).join(',')})=>{{` + const code = `${codeDefinition}${transformed}\n}}` + const options = { + filename: context.__filename, + lineOffset: 0, + columnOffset: -codeDefinition.length, + } + + const fn = vm.runInContext(code, vmContext, { + ...options, + // if we encountered an import, it's not inlined + importModuleDynamically: this.externalModules.importModuleDynamically as any, + } as any) + await fn(...Object.values(context)) + } + + protected async importExternalModule(path: string): Promise { + if (this.externalModules) + return this.externalModules.import(path) + return super.importExternalModule(path) + } + async dependencyRequest(id: string, fsPath: string, callstack: string[]): Promise { const mocked = await this.mocker.requestWithMock(fsPath, callstack) @@ -155,7 +206,7 @@ export class VitestExecutor extends ViteNodeRunner { } prepareContext(context: Record) { - const workerState = getWorkerState() + const workerState = this.options.state || getWorkerState() // support `import.meta.vitest` for test entry if (workerState.filepath && normalize(workerState.filepath) === normalize(context.__filename)) { diff --git a/packages/vite-node/src/native.ts b/packages/vitest/src/runtime/external-executor.ts similarity index 77% rename from packages/vite-node/src/native.ts rename to packages/vitest/src/runtime/external-executor.ts index 1f19f1cfef03..8bebef2c6cb9 100644 --- a/packages/vite-node/src/native.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -7,11 +7,11 @@ import { readFile } from 'node:fs/promises' import { resolve as resolveModule } from 'import-meta-resolve' import { hasESMSyntax } from 'mlly' import { extname } from 'pathe' -import { isNodeBuiltin } from './utils' +import { isNodeBuiltin } from 'vite-node/utils' const _require = createRequire(import.meta.url) -export class NativeNodeVmClient { +export class ExternalModulesExecutor { private context: vm.Context private requireCache = _require.cache @@ -59,15 +59,15 @@ export class NativeNodeVmClient { return m } - private createCjsNodeModule(filename: string) { + private createCommonJSNodeModule(filename: string) { const _require = createRequire(filename) - // doesn't respect "extensions" + // TODO: doesn't respect "extensions" const require: NodeRequire = (id: string) => { const filename = _require.resolve(id) if (isNodeBuiltin(filename)) return _require(filename) const code = readFileSync(filename, 'utf-8') - return this.evaluateCjsModule(filename, code) + return this.evaluateCommonJSModule(filename, code) } require.resolve = _require.resolve require.extensions = _require.extensions @@ -90,23 +90,34 @@ export class NativeNodeVmClient { return module } - private evaluateJsonCjsModule(filename: string, code: string): Record { - const module = this.createCjsNodeModule(filename) + private evaluateJsonCommonJSModule(filename: string, code: string): Record { + const module = this.createCommonJSNodeModule(filename) this.requireCache[filename] = module module.exports = JSON.parse(code) module.loaded = true return module.exports } + private evaluateCssCommonJSModule(filename: string): Record { + const module = this.createCommonJSNodeModule(filename) + this.requireCache[filename] = module + module.loaded = true + return module.exports + } + // very naive implementation for Node.js require - private evaluateCjsModule(filename: string, code: string): Record { - // console.log('cjs', filename) + private evaluateCommonJSModule(filename: string, code: string): Record { const cached = this.requireCache[filename] if (cached) return cached.exports - if (extname(filename) === '.json') - return this.evaluateJsonCjsModule(filename, code) + const extension = extname(filename) + + if (extension === '.json') + return this.evaluateJsonCommonJSModule(filename, code) + // TODO: should respect "extensions" + if (extension === '.css' || extension === '.scss' || extension === '.sass') + return this.evaluateCssCommonJSModule(filename) const cjsModule = `(function (exports, require, module, __filename, __dirname) { ${code} })` const script = new vm.Script(cjsModule, { @@ -117,7 +128,7 @@ export class NativeNodeVmClient { script.identifier = filename const fn = script.runInContext(this.context) const __dirname = dirname(filename) - const module = this.createCjsNodeModule(filename) + const module = this.createCommonJSNodeModule(filename) this.requireCache[filename] = module fn(module.exports, module.require, module, filename, __dirname) module.loaded = true @@ -146,7 +157,9 @@ export class NativeNodeVmClient { } async createModule(identifier: string): Promise { - if (isNodeBuiltin(identifier) || identifier.startsWith('data:text/')) { + const extension = extname(identifier) + + if (extension === '.node' || isNodeBuiltin(identifier) || identifier.startsWith('data:text/')) { const exports = await import(identifier) return await this.wrapSynteticModule(identifier, 'builtin', exports) } @@ -156,8 +169,9 @@ export class NativeNodeVmClient { const pathUrl = isFileUrl ? fileURLToPath(identifier) : identifier const code = await readFile(pathUrl, 'utf-8') - if (identifier.endsWith('.cjs') || !hasESMSyntax(code)) { - const exports = this.evaluateCjsModule(pathUrl, code) + // TODO: very dirty check for cjs + if (extension === '.cjs' || !hasESMSyntax(code)) { + const exports = this.evaluateCommonJSModule(pathUrl, code) return this.wrapSynteticModule(fileUrl, 'cjs', exports) } diff --git a/packages/vitest/src/runtime/setup.node.ts b/packages/vitest/src/runtime/setup.node.ts index 15625fcad1f7..de10a565e215 100644 --- a/packages/vitest/src/runtime/setup.node.ts +++ b/packages/vitest/src/runtime/setup.node.ts @@ -6,9 +6,7 @@ import type { EnvironmentOptions, ResolvedConfig, ResolvedTestEnvironment } from import { VitestSnapshotEnvironment } from '../integrations/snapshot/environments/node' import { getSafeTimers, getWorkerState } from '../utils' import * as VitestIndex from '../index' -import { RealDate } from '../integrations/mock/date' import { expect } from '../integrations/chai' -import { rpc } from './rpc' import { setupCommonEnv } from './setup.common' // this should only be used in Node @@ -47,112 +45,9 @@ export async function setupGlobalEnv(config: ResolvedConfig) { } export async function setupConsoleLogSpy() { - const stdoutBuffer = new Map() - const stderrBuffer = new Map() - const timers = new Map() - const unknownTestId = '__vitest__unknown_test__' + const { createCustomConsole } = await import('./console') - const { Writable } = await import('node:stream') - const { Console } = await import('node:console') - const { setTimeout, clearTimeout } = getSafeTimers() - - // group sync console.log calls with macro task - function schedule(taskId: string) { - const timer = timers.get(taskId)! - const { stdoutTime, stderrTime } = timer - clearTimeout(timer.timer) - timer.timer = setTimeout(() => { - if (stderrTime < stdoutTime) { - sendStderr(taskId) - sendStdout(taskId) - } - else { - sendStdout(taskId) - sendStderr(taskId) - } - }) - } - function sendStdout(taskId: string) { - const buffer = stdoutBuffer.get(taskId) - if (!buffer) - return - const content = buffer.map(i => String(i)).join('') - const timer = timers.get(taskId)! - rpc().onUserConsoleLog({ - type: 'stdout', - content: content || '', - taskId, - time: timer.stdoutTime || RealDate.now(), - size: buffer.length, - }) - stdoutBuffer.set(taskId, []) - timer.stdoutTime = 0 - } - function sendStderr(taskId: string) { - const buffer = stderrBuffer.get(taskId) - if (!buffer) - return - const content = buffer.map(i => String(i)).join('') - const timer = timers.get(taskId)! - rpc().onUserConsoleLog({ - type: 'stderr', - content: content || '', - taskId, - time: timer.stderrTime || RealDate.now(), - size: buffer.length, - }) - stderrBuffer.set(taskId, []) - timer.stderrTime = 0 - } - - const stdout = new Writable({ - write(data, encoding, callback) { - const id = getWorkerState()?.current?.id ?? unknownTestId - let timer = timers.get(id) - if (timer) { - timer.stdoutTime = timer.stdoutTime || RealDate.now() - } - else { - timer = { stdoutTime: RealDate.now(), stderrTime: RealDate.now(), timer: 0 } - timers.set(id, timer) - } - let buffer = stdoutBuffer.get(id) - if (!buffer) { - buffer = [] - stdoutBuffer.set(id, buffer) - } - buffer.push(data) - schedule(id) - callback() - }, - }) - const stderr = new Writable({ - write(data, encoding, callback) { - const id = getWorkerState()?.current?.id ?? unknownTestId - let timer = timers.get(id) - if (timer) { - timer.stderrTime = timer.stderrTime || RealDate.now() - } - else { - timer = { stderrTime: RealDate.now(), stdoutTime: RealDate.now(), timer: 0 } - timers.set(id, timer) - } - let buffer = stderrBuffer.get(id) - if (!buffer) { - buffer = [] - stderrBuffer.set(id, buffer) - } - buffer.push(data) - schedule(id) - callback() - }, - }) - globalThis.console = new Console({ - stdout, - stderr, - colorMode: true, - groupIndentation: 2, - }) + globalThis.console = createCustomConsole() } export async function withEnv( diff --git a/packages/vitest/src/runtime/vm.ts b/packages/vitest/src/runtime/vm.ts index 32e0e29f91e9..a2823776fc83 100644 --- a/packages/vitest/src/runtime/vm.ts +++ b/packages/vitest/src/runtime/vm.ts @@ -1,6 +1,7 @@ import { URL, pathToFileURL } from 'node:url' import { ModuleCacheMap } from 'vite-node/client' import type { BirpcReturn } from 'birpc' +import { workerId as poolId } from 'tinypool' import { createBirpc } from 'birpc' import { relative, resolve } from 'pathe' import { processError } from '@vitest/runner/utils' @@ -10,7 +11,8 @@ import type { RuntimeRPC, WorkerContext, WorkerGlobalState } from '../types' import { distDir } from '../paths' import { environments } from '../integrations/env' import { VitestSnapshotEnvironment } from '../integrations/snapshot/environments/node' -import { createVitestExecutor } from './execute' +import { startVitestExecutor } from './execute' +import { createCustomConsole } from './console' let rpc: BirpcReturn @@ -22,6 +24,7 @@ const caches: Record { @@ -113,19 +119,12 @@ export async function run(ctx: WorkerContext) { } ctx.files.forEach(i => moduleCache.delete(i)) - const executor = await createVitestExecutor({ - fetchModule(id) { - return rpc.fetch(id, ctx.environment.name) - }, - resolveId(id, importer) { - return rpc.resolveId(id, importer, ctx.environment.name) - }, + const executor = await startVitestExecutor(ctx, { + context, moduleCache, mockMap, - interopDefault: config.deps.interopDefault, - root: config.root, - base: config.base, - context, + state: __vitest_worker__, + rpc: () => rpc, }) context.__vitest_mocker__ = executor.mocker @@ -137,5 +136,6 @@ export async function run(ctx: WorkerContext) { } finally { await vm.teardown({}) + __vitest_worker__.environmentTeardownRun = true } } From 2ac712749a1d8405e39b9f840b8ae7a183ff6bad Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 18 Apr 2023 13:23:25 +0200 Subject: [PATCH 06/87] chore: pass down state --- packages/vitest/src/integrations/env/node.ts | 2 +- .../snapshot/environments/node.ts | 8 ++++-- packages/vitest/src/runtime/child.ts | 21 +++++++++------ packages/vitest/src/runtime/entry-vm.ts | 4 +++ packages/vitest/src/runtime/entry.ts | 3 +-- packages/vitest/src/runtime/execute.ts | 27 ++++++++++--------- .../vitest/src/runtime/external-executor.ts | 3 +++ packages/vitest/src/runtime/mocker.ts | 3 +-- packages/vitest/src/runtime/setup.node.ts | 2 +- packages/vitest/src/runtime/vm.ts | 26 ++++++++---------- packages/vitest/src/runtime/worker.ts | 20 +++++++------- packages/vitest/src/types/worker.ts | 7 +++-- packages/vitest/src/utils/global.ts | 6 ++--- 13 files changed, 74 insertions(+), 58 deletions(-) diff --git a/packages/vitest/src/integrations/env/node.ts b/packages/vitest/src/integrations/env/node.ts index b1dcf84a7d57..26df78a699ee 100644 --- a/packages/vitest/src/integrations/env/node.ts +++ b/packages/vitest/src/integrations/env/node.ts @@ -8,7 +8,7 @@ export default ({ async setupVm() { const vm = await importModule('node:vm') const global = {} // TODO: copy more globals - const context = vm.createContext(global) + const context = vm.createContext() return { getGlobal() { return global diff --git a/packages/vitest/src/integrations/snapshot/environments/node.ts b/packages/vitest/src/integrations/snapshot/environments/node.ts index 59657bb79e13..739501a67f29 100644 --- a/packages/vitest/src/integrations/snapshot/environments/node.ts +++ b/packages/vitest/src/integrations/snapshot/environments/node.ts @@ -1,12 +1,16 @@ import { NodeSnapshotEnvironment } from '@vitest/snapshot/environment' -import { rpc } from '../../../runtime/rpc' +import type { WorkerRPC } from '../../../types/worker' export class VitestSnapshotEnvironment extends NodeSnapshotEnvironment { + constructor(private rpc: WorkerRPC) { + super() + } + getHeader(): string { return `// Vitest Snapshot v${this.getVersion()}, https://vitest.dev/guide/snapshot.html` } resolvePath(filepath: string): Promise { - return rpc().resolveSnapshotPath(filepath) + return this.rpc.resolveSnapshotPath(filepath) } } diff --git a/packages/vitest/src/runtime/child.ts b/packages/vitest/src/runtime/child.ts index 3dcd5874acfe..d212352a55b1 100644 --- a/packages/vitest/src/runtime/child.ts +++ b/packages/vitest/src/runtime/child.ts @@ -3,7 +3,7 @@ import v8 from 'node:v8' import { createBirpc } from 'birpc' import { parseRegexp } from '@vitest/utils' import type { CancelReason } from '@vitest/runner' -import type { ResolvedConfig } from '../types' +import type { ResolvedConfig, WorkerGlobalState } from '../types' import type { RunnerRPC, RuntimeRPC } from '../types/rpc' import type { ChildContext } from '../types/child' import { mockMap, moduleCache, startViteNode } from './execute' @@ -21,15 +21,13 @@ function init(ctx: ChildContext) { setCancel = resolve }) - // @ts-expect-error untyped global - globalThis.__vitest_environment__ = environment.name - // @ts-expect-error I know what I am doing :P - globalThis.__vitest_worker__ = { + const state = { ctx, moduleCache, config, mockMap, onCancel, + environment: config.environment, durations: { environment: 0, prepare: performance.now(), @@ -50,6 +48,9 @@ function init(ctx: ChildContext) { ), } + // @ts-expect-error I know what I am doing :P + globalThis.__vitest_worker__ = state + if (ctx.invalidates) { ctx.invalidates.forEach((fsPath) => { moduleCache.delete(fsPath) @@ -57,6 +58,8 @@ function init(ctx: ChildContext) { }) } ctx.files.forEach(i => moduleCache.delete(i)) + + return state as unknown as WorkerGlobalState } function parsePossibleRegexp(str: string | RegExp) { @@ -76,9 +79,11 @@ export async function run(ctx: ChildContext) { const inspectorCleanup = setupInspect(ctx.config) try { - init(ctx) - const { run, executor, environment } = await startViteNode(ctx) - await run(ctx.files, ctx.config, { ...ctx.environment, environment }, executor) + const state = init(ctx) + const { run, executor } = await startViteNode(ctx, { + state, + }) + await run(ctx.files, ctx.config, ctx.environment, executor) await rpcDone() } finally { diff --git a/packages/vitest/src/runtime/entry-vm.ts b/packages/vitest/src/runtime/entry-vm.ts index 4cc2766c1dc7..ababe6bfc922 100644 --- a/packages/vitest/src/runtime/entry-vm.ts +++ b/packages/vitest/src/runtime/entry-vm.ts @@ -13,6 +13,8 @@ import { setupCommonEnv } from './setup.common' export async function run(files: string[], config: ResolvedConfig, environment: ContextTestEnvironment, executor: VitestExecutor): Promise { const workerState = getWorkerState() + process.stdout.write(`worker state ${workerState.filepath}\n`) + await setupCommonEnv(config) setupColors(createColors(isatty(1))) @@ -23,6 +25,8 @@ export async function run(files: string[], config: ResolvedConfig, environment: _require.extensions['.scss'] = () => ({}) _require.extensions['.sass'] = () => ({}) + Error.stackTraceLimit = 1000 + await startCoverageInsideWorker(config.coverage, executor) if (config.chaiConfig) diff --git a/packages/vitest/src/runtime/entry.ts b/packages/vitest/src/runtime/entry.ts index fca980972d9e..a86b2932ab3d 100644 --- a/packages/vitest/src/runtime/entry.ts +++ b/packages/vitest/src/runtime/entry.ts @@ -24,8 +24,7 @@ export async function run(files: string[], config: ResolvedConfig, environment: workerState.durations.prepare = performance.now() - workerState.durations.prepare - // @ts-expect-error untyped global - globalThis.__vitest_environment__ = environment.name + workerState.environment = environment.name workerState.durations.environment = performance.now() diff --git a/packages/vitest/src/runtime/execute.ts b/packages/vitest/src/runtime/execute.ts index 14e90599393f..96c3dfd72821 100644 --- a/packages/vitest/src/runtime/execute.ts +++ b/packages/vitest/src/runtime/execute.ts @@ -6,12 +6,10 @@ import type { ViteNodeRunnerOptions } from 'vite-node' import { normalize, relative, resolve } from 'pathe' import { processError } from '@vitest/utils/error' import type { MockMap } from '../types/mocker' -import { getCurrentEnvironment, getWorkerState } from '../utils/global' import type { ContextRPC, Environment, ResolvedConfig, ResolvedTestEnvironment, WorkerGlobalState } from '../types' import { distDir } from '../paths' import { loadEnvironment } from '../integrations/env' import { VitestMocker } from './mocker' -import { rpc as getRpc } from './rpc' import { ExternalModulesExecutor } from './external-executor' const entryUrl = pathToFileURL(resolve(distDir, 'entry.js')).href @@ -20,7 +18,7 @@ export interface ExecuteOptions extends ViteNodeRunnerOptions { mockMap: MockMap moduleDirectories?: string[] context?: vm.Context - state?: WorkerGlobalState + state: WorkerGlobalState } export async function createVitestExecutor(options: ExecuteOptions) { @@ -40,11 +38,11 @@ let _viteNode: { export const moduleCache = new ModuleCacheMap() export const mockMap: MockMap = new Map() -export async function startViteNode(ctx: ContextRPC) { +export async function startViteNode(ctx: ContextRPC, options: ContextExecutorOptions) { if (_viteNode) return _viteNode - const executor = await startVitestExecutor(ctx) + const executor = await startVitestExecutor(ctx, options) const environment = await loadEnvironment(ctx.environment.name, executor) ctx.environment.environment = environment @@ -60,14 +58,13 @@ export interface ContextExecutorOptions { mockMap?: MockMap moduleCache?: ModuleCacheMap context?: vm.Context - state?: WorkerGlobalState - rpc?: typeof getRpc + state: WorkerGlobalState } -export async function startVitestExecutor(ctx: ContextRPC, options: ContextExecutorOptions = {}) { +export async function startVitestExecutor(ctx: ContextRPC, options: ContextExecutorOptions) { const { config } = ctx - const rpc = options.rpc ?? getRpc + const rpc = () => options.state.rpc const processExit = process.exit @@ -78,7 +75,7 @@ export async function startVitestExecutor(ctx: ContextRPC, options: ContextExecu } function catchError(err: unknown, type: string) { - const worker = options.state || getWorkerState() + const worker = options.state const error = processError(err) if (!isPrimitive(error)) { error.VITEST_TEST_NAME = worker.current?.name @@ -132,10 +129,14 @@ export class VitestExecutor extends ViteNodeRunner { this.externalModules = new ExternalModulesExecutor(options.context) } + get state() { + return this.options.state + } + shouldResolveId(id: string, _importee?: string | undefined): boolean { if (isInternalRequest(id) || id.startsWith('data:')) return false - const environment = getCurrentEnvironment() + const environment = this.options.state.environment // do not try and resolve node builtins in Node // import('url') returns Node internal even if 'url' package is installed return environment === 'node' ? !isNodeBuiltin(id) : !id.startsWith('node:') @@ -189,7 +190,7 @@ export class VitestExecutor extends ViteNodeRunner { await fn(...Object.values(context)) } - protected async importExternalModule(path: string): Promise { + public async importExternalModule(path: string): Promise { if (this.externalModules) return this.externalModules.import(path) return super.importExternalModule(path) @@ -206,7 +207,7 @@ export class VitestExecutor extends ViteNodeRunner { } prepareContext(context: Record) { - const workerState = this.options.state || getWorkerState() + const workerState = this.state // support `import.meta.vitest` for test entry if (workerState.filepath && normalize(workerState.filepath) === normalize(context.__filename)) { diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index 8bebef2c6cb9..d1a7f2b2626f 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -137,6 +137,9 @@ export class ExternalModulesExecutor { async createEsmModule(fileUrl: string, code: string) { const cached = this.moduleCache.get(fileUrl) + // if (fileUrl.includes('entry')) { + // console.log('esm', fileUrl, !!cached, this.context.__vitest_worker__) + // } if (cached) return cached const m = new vm.SourceTextModule( diff --git a/packages/vitest/src/runtime/mocker.ts b/packages/vitest/src/runtime/mocker.ts index 4ac7f98a736a..8158e3345857 100644 --- a/packages/vitest/src/runtime/mocker.ts +++ b/packages/vitest/src/runtime/mocker.ts @@ -2,7 +2,6 @@ import { existsSync, readdirSync } from 'node:fs' import { basename, dirname, extname, isAbsolute, join, resolve } from 'pathe' import { getColors, getType } from '@vitest/utils' import { isNodeBuiltin } from 'vite-node/utils' -import { getWorkerState } from '../utils/global' import { getAllMockableProperties } from '../utils/base' import type { MockFactory, PendingSuiteMock } from '../types/mocker' import { spyOn } from '../integrations/spy' @@ -73,7 +72,7 @@ export class VitestMocker { } public getSuiteFilepath(): string { - return getWorkerState().filepath || 'global' + return this.executor.state.filepath || 'global' } public getMocks() { diff --git a/packages/vitest/src/runtime/setup.node.ts b/packages/vitest/src/runtime/setup.node.ts index de10a565e215..67aa8315f385 100644 --- a/packages/vitest/src/runtime/setup.node.ts +++ b/packages/vitest/src/runtime/setup.node.ts @@ -22,7 +22,7 @@ export async function setupGlobalEnv(config: ResolvedConfig) { const state = getWorkerState() if (!state.config.snapshotOptions.snapshotEnvironment) - state.config.snapshotOptions.snapshotEnvironment = new VitestSnapshotEnvironment() + state.config.snapshotOptions.snapshotEnvironment = new VitestSnapshotEnvironment(state.rpc) if (globalSetup) return diff --git a/packages/vitest/src/runtime/vm.ts b/packages/vitest/src/runtime/vm.ts index a2823776fc83..6b33bab5ed62 100644 --- a/packages/vitest/src/runtime/vm.ts +++ b/packages/vitest/src/runtime/vm.ts @@ -6,13 +6,15 @@ import { createBirpc } from 'birpc' import { relative, resolve } from 'pathe' import { processError } from '@vitest/runner/utils' import { isPrimitive } from '@vitest/utils' -import { installSourcemapsSupport } from 'vite-node/source-map' +// import { installSourcemapsSupport } from 'vite-node/source-map' import type { RuntimeRPC, WorkerContext, WorkerGlobalState } from '../types' import { distDir } from '../paths' import { environments } from '../integrations/env' import { VitestSnapshotEnvironment } from '../integrations/snapshot/environments/node' import { startVitestExecutor } from './execute' -import { createCustomConsole } from './console' +// import { createCustomConsole } from './console' + +const entryFile = pathToFileURL(resolve(distDir, 'entry-vm.js')).href let rpc: BirpcReturn @@ -45,6 +47,7 @@ export async function run(ctx: WorkerContext) { moduleCache, config, mockMap, + environment: ctx.environment.name, durations: { environment: 0, prepare: performance.now(), @@ -52,9 +55,9 @@ export async function run(ctx: WorkerContext) { rpc, } - installSourcemapsSupport({ - getSourceMap: source => moduleCache.getSourceMap(source), - }) + // installSourcemapsSupport({ + // getSourceMap: source => moduleCache.getSourceMap(source), + // }) const processExit = process.exit @@ -79,24 +82,18 @@ export async function run(ctx: WorkerContext) { process.on('uncaughtException', e => catchError(e, 'Uncaught Exception')) process.on('unhandledRejection', e => catchError(e, 'Unhandled Rejection')) - config.snapshotOptions.snapshotEnvironment = new VitestSnapshotEnvironment() + config.snapshotOptions.snapshotEnvironment = new VitestSnapshotEnvironment(rpc) const environment = environments[ctx.environment.name as 'happy-dom'] const vm = await environment.setupVm!({}, ctx.environment.options || {}) - // @ts-expect-error untyped global - globalThis.__vitest_environment__ = config.environment - // @ts-expect-error untyped global - globalThis.__vitest_worker__ = __vitest_worker__ - process.env.VITEST_WORKER_ID = String(ctx.workerId) process.env.VITEST_POOL_ID = String(poolId) const context = vm.getVmContext() context.__vitest_worker__ = __vitest_worker__ - context.__vitest_environment__ = config.environment // TODO: all globals for test/core to work // TODO: copy more globals context.process = process @@ -109,7 +106,7 @@ export async function run(ctx: WorkerContext) { context.setInterval = setInterval context.clearInterval = clearInterval context.global = context - context.console = createCustomConsole() + // context.console = createCustomConsole() if (ctx.invalidates) { ctx.invalidates.forEach((fsPath) => { @@ -124,12 +121,11 @@ export async function run(ctx: WorkerContext) { moduleCache, mockMap, state: __vitest_worker__, - rpc: () => rpc, }) context.__vitest_mocker__ = executor.mocker - const { run } = await executor.executeId(pathToFileURL(resolve(distDir, 'entry-vm.js')).href) + const { run } = await executor.importExternalModule(entryFile) try { await run(ctx.files, ctx.config, ctx.environment, executor) diff --git a/packages/vitest/src/runtime/worker.ts b/packages/vitest/src/runtime/worker.ts index ce2fa1a8b5f4..a48dbadc0694 100644 --- a/packages/vitest/src/runtime/worker.ts +++ b/packages/vitest/src/runtime/worker.ts @@ -2,7 +2,7 @@ import { performance } from 'node:perf_hooks' import { createBirpc } from 'birpc' import { workerId as poolId } from 'tinypool' import type { CancelReason } from '@vitest/runner' -import type { RunnerRPC, RuntimeRPC, WorkerContext } from '../types' +import type { RunnerRPC, RuntimeRPC, WorkerContext, WorkerGlobalState } from '../types' import { getWorkerState } from '../utils/global' import { mockMap, moduleCache, startViteNode } from './execute' import { setupInspect } from './inspector' @@ -22,16 +22,13 @@ function init(ctx: WorkerContext) { const onCancel = new Promise((resolve) => { setCancel = resolve }) - - // @ts-expect-error untyped global - globalThis.__vitest_environment__ = config.environment.name - // @ts-expect-error I know what I am doing :P - globalThis.__vitest_worker__ = { + const state = { ctx, moduleCache, config, mockMap, onCancel, + environment: ctx.environment.name, durations: { environment: 0, prepare: performance.now(), @@ -48,6 +45,9 @@ function init(ctx: WorkerContext) { ), } + // @ts-expect-error I know what I am doing :P + globalThis.__vitest_worker__ = state + if (ctx.invalidates) { ctx.invalidates.forEach((fsPath) => { moduleCache.delete(fsPath) @@ -55,15 +55,17 @@ function init(ctx: WorkerContext) { }) } ctx.files.forEach(i => moduleCache.delete(i)) + + return state as WorkerGlobalState } export async function run(ctx: WorkerContext) { const inspectorCleanup = setupInspect(ctx.config) try { - init(ctx) - const { run, executor, environment } = await startViteNode(ctx) - await run(ctx.files, ctx.config, { ...ctx.environment, environment }, executor) + const state = init(ctx) + const { run, executor } = await startViteNode(ctx, { state }) + await run(ctx.files, ctx.config, ctx.environment, executor) await rpcDone() } finally { diff --git a/packages/vitest/src/types/worker.ts b/packages/vitest/src/types/worker.ts index b6224e8174fe..f5aed5f41499 100644 --- a/packages/vitest/src/types/worker.ts +++ b/packages/vitest/src/types/worker.ts @@ -3,7 +3,7 @@ import type { CancelReason, Test } from '@vitest/runner' import type { ModuleCacheMap, ViteNodeResolveId } from 'vite-node' import type { BirpcReturn } from 'birpc' import type { MockMap } from './mocker' -import type { ResolvedConfig } from './config' +import type { ResolvedConfig, VitestEnvironment } from './config' import type { ContextRPC, RuntimeRPC } from './rpc' export interface WorkerContext extends ContextRPC { @@ -17,12 +17,15 @@ export interface AfterSuiteRunMeta { coverage?: unknown } +export type WorkerRPC = BirpcReturn + export interface WorkerGlobalState { ctx: WorkerContext config: ResolvedConfig - rpc: BirpcReturn + rpc: WorkerRPC current?: Test filepath?: string + environment: VitestEnvironment environmentTeardownRun?: boolean onCancel: Promise moduleCache: ModuleCacheMap diff --git a/packages/vitest/src/utils/global.ts b/packages/vitest/src/utils/global.ts index 02db76c687b0..b8e389e9f021 100644 --- a/packages/vitest/src/utils/global.ts +++ b/packages/vitest/src/utils/global.ts @@ -2,10 +2,10 @@ import type { WorkerGlobalState } from '../types' export function getWorkerState(): WorkerGlobalState { // @ts-expect-error untyped global - return globalThis.__vitest_worker__ + return __vitest_worker__ } export function getCurrentEnvironment(): string { - // @ts-expect-error untyped global - return globalThis.__vitest_environment__ + const state = getWorkerState() + return state.environment } From 89c4210c5e8ad9b4cbc6410da5e8d48040aef7e0 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 18 Apr 2023 13:24:14 +0200 Subject: [PATCH 07/87] chore: cleanup --- packages/vitest/src/runtime/entry-vm.ts | 2 -- 1 file changed, 2 deletions(-) diff --git a/packages/vitest/src/runtime/entry-vm.ts b/packages/vitest/src/runtime/entry-vm.ts index ababe6bfc922..57106df69f7a 100644 --- a/packages/vitest/src/runtime/entry-vm.ts +++ b/packages/vitest/src/runtime/entry-vm.ts @@ -13,8 +13,6 @@ import { setupCommonEnv } from './setup.common' export async function run(files: string[], config: ResolvedConfig, environment: ContextTestEnvironment, executor: VitestExecutor): Promise { const workerState = getWorkerState() - process.stdout.write(`worker state ${workerState.filepath}\n`) - await setupCommonEnv(config) setupColors(createColors(isatty(1))) From 169fd8ed2ee40ce662d047622e8f6b94f03dba17 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 18 Apr 2023 13:34:42 +0200 Subject: [PATCH 08/87] chore: setup console --- packages/vitest/src/runtime/console.ts | 13 ++++++------- packages/vitest/src/runtime/setup.node.ts | 8 ++++---- packages/vitest/src/runtime/vm.ts | 12 ++++++------ 3 files changed, 16 insertions(+), 17 deletions(-) diff --git a/packages/vitest/src/runtime/console.ts b/packages/vitest/src/runtime/console.ts index 89632d8dc241..3061221f7d55 100644 --- a/packages/vitest/src/runtime/console.ts +++ b/packages/vitest/src/runtime/console.ts @@ -2,10 +2,9 @@ import { Writable } from 'node:stream' import { Console } from 'node:console' import { getSafeTimers } from '@vitest/utils' import { RealDate } from '../integrations/mock/date' -import { getWorkerState } from '../utils/global' -import { rpc } from './rpc' +import type { WorkerGlobalState } from '../types' -export function createCustomConsole() { +export function createCustomConsole(state: WorkerGlobalState) { const stdoutBuffer = new Map() const stderrBuffer = new Map() const timers = new Map() @@ -35,7 +34,7 @@ export function createCustomConsole() { return const content = buffer.map(i => String(i)).join('') const timer = timers.get(taskId)! - rpc().onUserConsoleLog({ + state.rpc.onUserConsoleLog({ type: 'stdout', content: content || '', taskId, @@ -51,7 +50,7 @@ export function createCustomConsole() { return const content = buffer.map(i => String(i)).join('') const timer = timers.get(taskId)! - rpc().onUserConsoleLog({ + state.rpc.onUserConsoleLog({ type: 'stderr', content: content || '', taskId, @@ -64,7 +63,7 @@ export function createCustomConsole() { const stdout = new Writable({ write(data, encoding, callback) { - const id = getWorkerState()?.current?.id ?? unknownTestId + const id = state?.current?.id ?? unknownTestId let timer = timers.get(id) if (timer) { timer.stdoutTime = timer.stdoutTime || RealDate.now() @@ -85,7 +84,7 @@ export function createCustomConsole() { }) const stderr = new Writable({ write(data, encoding, callback) { - const id = getWorkerState()?.current?.id ?? unknownTestId + const id = state?.current?.id ?? unknownTestId let timer = timers.get(id) if (timer) { timer.stderrTime = timer.stderrTime || RealDate.now() diff --git a/packages/vitest/src/runtime/setup.node.ts b/packages/vitest/src/runtime/setup.node.ts index 67aa8315f385..26a23dbd7a49 100644 --- a/packages/vitest/src/runtime/setup.node.ts +++ b/packages/vitest/src/runtime/setup.node.ts @@ -2,7 +2,7 @@ import { createRequire } from 'node:module' import { isatty } from 'node:tty' import { installSourcemapsSupport } from 'vite-node/source-map' import { createColors, setupColors } from '@vitest/utils' -import type { EnvironmentOptions, ResolvedConfig, ResolvedTestEnvironment } from '../types' +import type { EnvironmentOptions, ResolvedConfig, ResolvedTestEnvironment, WorkerGlobalState } from '../types' import { VitestSnapshotEnvironment } from '../integrations/snapshot/environments/node' import { getSafeTimers, getWorkerState } from '../utils' import * as VitestIndex from '../index' @@ -41,13 +41,13 @@ export async function setupGlobalEnv(config: ResolvedConfig) { getSourceMap: source => state.moduleCache.getSourceMap(source), }) - await setupConsoleLogSpy() + await setupConsoleLogSpy(state) } -export async function setupConsoleLogSpy() { +export async function setupConsoleLogSpy(state: WorkerGlobalState) { const { createCustomConsole } = await import('./console') - globalThis.console = createCustomConsole() + globalThis.console = createCustomConsole(state) } export async function withEnv( diff --git a/packages/vitest/src/runtime/vm.ts b/packages/vitest/src/runtime/vm.ts index 6b33bab5ed62..84a588451c63 100644 --- a/packages/vitest/src/runtime/vm.ts +++ b/packages/vitest/src/runtime/vm.ts @@ -6,13 +6,13 @@ import { createBirpc } from 'birpc' import { relative, resolve } from 'pathe' import { processError } from '@vitest/runner/utils' import { isPrimitive } from '@vitest/utils' -// import { installSourcemapsSupport } from 'vite-node/source-map' +import { installSourcemapsSupport } from 'vite-node/source-map' import type { RuntimeRPC, WorkerContext, WorkerGlobalState } from '../types' import { distDir } from '../paths' import { environments } from '../integrations/env' import { VitestSnapshotEnvironment } from '../integrations/snapshot/environments/node' import { startVitestExecutor } from './execute' -// import { createCustomConsole } from './console' +import { createCustomConsole } from './console' const entryFile = pathToFileURL(resolve(distDir, 'entry-vm.js')).href @@ -55,9 +55,9 @@ export async function run(ctx: WorkerContext) { rpc, } - // installSourcemapsSupport({ - // getSourceMap: source => moduleCache.getSourceMap(source), - // }) + installSourcemapsSupport({ + getSourceMap: source => moduleCache.getSourceMap(source), + }) const processExit = process.exit @@ -106,7 +106,7 @@ export async function run(ctx: WorkerContext) { context.setInterval = setInterval context.clearInterval = clearInterval context.global = context - // context.console = createCustomConsole() + context.console = createCustomConsole(__vitest_worker__) if (ctx.invalidates) { ctx.invalidates.forEach((fsPath) => { From 5d8c9f7b1e3793d89e04f68d66431a5bbe14e1e6 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 18 Apr 2023 14:15:24 +0200 Subject: [PATCH 09/87] chore: cleanup --- packages/vitest/src/runtime/vm.ts | 39 ++++++------------------------- 1 file changed, 7 insertions(+), 32 deletions(-) diff --git a/packages/vitest/src/runtime/vm.ts b/packages/vitest/src/runtime/vm.ts index 84a588451c63..32eb3a74b335 100644 --- a/packages/vitest/src/runtime/vm.ts +++ b/packages/vitest/src/runtime/vm.ts @@ -3,9 +3,7 @@ import { ModuleCacheMap } from 'vite-node/client' import type { BirpcReturn } from 'birpc' import { workerId as poolId } from 'tinypool' import { createBirpc } from 'birpc' -import { relative, resolve } from 'pathe' -import { processError } from '@vitest/runner/utils' -import { isPrimitive } from '@vitest/utils' +import { resolve } from 'pathe' import { installSourcemapsSupport } from 'vite-node/source-map' import type { RuntimeRPC, WorkerContext, WorkerGlobalState } from '../types' import { distDir } from '../paths' @@ -42,7 +40,7 @@ export async function run(ctx: WorkerContext) { on(fn) { port.addListener('message', fn) }, }, ) - const __vitest_worker__: WorkerGlobalState = { + const state: WorkerGlobalState = { ctx, moduleCache, config, @@ -59,41 +57,18 @@ export async function run(ctx: WorkerContext) { getSourceMap: source => moduleCache.getSourceMap(source), }) - const processExit = process.exit - - process.exit = (code = process.exitCode || 0): never => { - const error = new Error(`process.exit called with "${code}"`) - rpc.onWorkerExit(error, code) - return processExit(code) - } - - function catchError(err: unknown, type: string) { - const worker = __vitest_worker__ - const error = processError(err) - if (!isPrimitive(error)) { - error.VITEST_TEST_NAME = worker.current?.name - if (worker.filepath) - error.VITEST_TEST_PATH = relative(config.root, worker.filepath) - error.VITEST_AFTER_ENV_TEARDOWN = worker.environmentTeardownRun - } - rpc.onUnhandledError(error, type) - } - - process.on('uncaughtException', e => catchError(e, 'Uncaught Exception')) - process.on('unhandledRejection', e => catchError(e, 'Unhandled Rejection')) - config.snapshotOptions.snapshotEnvironment = new VitestSnapshotEnvironment(rpc) const environment = environments[ctx.environment.name as 'happy-dom'] - const vm = await environment.setupVm!({}, ctx.environment.options || {}) + const vm = await environment.setupVM!({}, ctx.environment.options || {}) process.env.VITEST_WORKER_ID = String(ctx.workerId) process.env.VITEST_POOL_ID = String(poolId) const context = vm.getVmContext() - context.__vitest_worker__ = __vitest_worker__ + context.__vitest_worker__ = state // TODO: all globals for test/core to work // TODO: copy more globals context.process = process @@ -106,7 +81,7 @@ export async function run(ctx: WorkerContext) { context.setInterval = setInterval context.clearInterval = clearInterval context.global = context - context.console = createCustomConsole(__vitest_worker__) + context.console = createCustomConsole(state) if (ctx.invalidates) { ctx.invalidates.forEach((fsPath) => { @@ -120,7 +95,7 @@ export async function run(ctx: WorkerContext) { context, moduleCache, mockMap, - state: __vitest_worker__, + state, }) context.__vitest_mocker__ = executor.mocker @@ -132,6 +107,6 @@ export async function run(ctx: WorkerContext) { } finally { await vm.teardown({}) - __vitest_worker__.environmentTeardownRun = true + state.environmentTeardownRun = true } } From ad69374ca0b16949a2b4ed7bd489cf8f4a62ad42 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 18 Apr 2023 16:46:37 +0200 Subject: [PATCH 10/87] chore: clear require cache --- packages/vitest/src/runtime/entry-vm.ts | 4 ++-- .../vitest/src/runtime/external-executor.ts | 2 ++ packages/vitest/src/runtime/vm.ts | 22 ++++--------------- test/core/test/jest-expect.test.ts | 16 +++++++------- 4 files changed, 16 insertions(+), 28 deletions(-) diff --git a/packages/vitest/src/runtime/entry-vm.ts b/packages/vitest/src/runtime/entry-vm.ts index 57106df69f7a..dba18f545349 100644 --- a/packages/vitest/src/runtime/entry-vm.ts +++ b/packages/vitest/src/runtime/entry-vm.ts @@ -4,13 +4,13 @@ import { startTests } from '@vitest/runner' import { createColors, setupColors } from '@vitest/utils' import { setupChaiConfig } from '../integrations/chai' import { startCoverageInsideWorker, stopCoverageInsideWorker } from '../integrations/coverage' -import type { ContextTestEnvironment, ResolvedConfig } from '../types' +import type { ResolvedConfig } from '../types' import { getWorkerState } from '../utils/global' import type { VitestExecutor } from './execute' import { resolveTestRunner } from './runners' import { setupCommonEnv } from './setup.common' -export async function run(files: string[], config: ResolvedConfig, environment: ContextTestEnvironment, executor: VitestExecutor): Promise { +export async function run(files: string[], config: ResolvedConfig, executor: VitestExecutor): Promise { const workerState = getWorkerState() await setupCommonEnv(config) diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index d1a7f2b2626f..a23c1516c43d 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -19,6 +19,8 @@ export class ExternalModulesExecutor { constructor(context: vm.Context) { this.context = context + for (const file in this.requireCache) + delete this.requireCache[file] } importModuleDynamically = async (specifier: string, script: vm.Module) => { diff --git a/packages/vitest/src/runtime/vm.ts b/packages/vitest/src/runtime/vm.ts index 32eb3a74b335..b91ac29f290c 100644 --- a/packages/vitest/src/runtime/vm.ts +++ b/packages/vitest/src/runtime/vm.ts @@ -1,6 +1,5 @@ import { URL, pathToFileURL } from 'node:url' import { ModuleCacheMap } from 'vite-node/client' -import type { BirpcReturn } from 'birpc' import { workerId as poolId } from 'tinypool' import { createBirpc } from 'birpc' import { resolve } from 'pathe' @@ -14,25 +13,12 @@ import { createCustomConsole } from './console' const entryFile = pathToFileURL(resolve(distDir, 'entry-vm.js')).href -let rpc: BirpcReturn - -const caches: Record -}> = {} - // TODO: currently expects only one file in this function, which makes sense because the function itself is called for each file separately export async function run(ctx: WorkerContext) { - const file = ctx.files[0] - // cache is for reruning the same file in watch mode - const cache = caches[file] || {} - const moduleCache = cache.moduleCache ??= new ModuleCacheMap() - cache.moduleCache = moduleCache - const mockMap = cache.mockMap ?? new Map() - cache.mockMap = mockMap - caches[file] = cache + const moduleCache = new ModuleCacheMap() + const mockMap = new Map() const { config, port } = ctx - rpc = createBirpc( + const rpc = createBirpc( {}, { eventNames: ['onUserConsoleLog', 'onFinished', 'onCollected', 'onWorkerExit'], @@ -103,7 +89,7 @@ export async function run(ctx: WorkerContext) { const { run } = await executor.importExternalModule(entryFile) try { - await run(ctx.files, ctx.config, ctx.environment, executor) + await run(ctx.files, ctx.config, executor) } finally { await vm.teardown({}) diff --git a/test/core/test/jest-expect.test.ts b/test/core/test/jest-expect.test.ts index eb2d8ce75b14..02be6726a834 100644 --- a/test/core/test/jest-expect.test.ts +++ b/test/core/test/jest-expect.test.ts @@ -687,24 +687,24 @@ describe('async expect', () => { try { expect(actual).toBe({ ...actual }) } - catch (error) { - expect(error).toEqual(toStrictEqualError1) + catch (error: any) { + expect(error.message).toBe(toStrictEqualError1.message) } const toStrictEqualError2 = generatedToBeMessage('toStrictEqual', 'FakeClass{}', 'FakeClass{}') try { expect(new FakeClass()).toBe(new FakeClass()) } - catch (error) { - expect(error).toEqual(toStrictEqualError2) + catch (error: any) { + expect(error.message).toBe(toStrictEqualError2.message) } const toEqualError1 = generatedToBeMessage('toEqual', '{}', 'FakeClass{}') try { expect({}).toBe(new FakeClass()) } - catch (error) { - expect(error).toEqual(toEqualError1) + catch (error: any) { + expect(error.message).toBe(toEqualError1.message) // expect(error).toEqual('1234') } @@ -712,8 +712,8 @@ describe('async expect', () => { try { expect(new FakeClass()).toBe({}) } - catch (error) { - expect(error).toEqual(toEqualError2) + catch (error: any) { + expect(error.message).toBe(toEqualError2.message) } }) From a95f147d94530faf8d3965645d18617ceb77d7d9 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 18 Apr 2023 19:18:15 +0200 Subject: [PATCH 11/87] chore: fix linking race conditions --- .../vitest/src/runtime/external-executor.ts | 53 +++++++++++++------ 1 file changed, 37 insertions(+), 16 deletions(-) diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index a23c1516c43d..4ee3a9686e45 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -17,14 +17,21 @@ export class ExternalModulesExecutor { private requireCache = _require.cache private moduleCache = new Map() + private esmLinkMap = new WeakMap>() + constructor(context: vm.Context) { this.context = context for (const file in this.requireCache) delete this.requireCache[file] } - importModuleDynamically = async (specifier: string, script: vm.Module) => { - const identifier = await this.resolveAsync(specifier, script.identifier) + importModuleDynamically = async (specifier: string, referencer: vm.Module) => { + const module = await this.resolveModule(specifier, referencer) + return this.evaluateModule(module) + } + + resolveModule = async (specifier: string, referencer: vm.Module) => { + const identifier = await this.resolveAsync(specifier, referencer.identifier) return await this.createModule(identifier) } @@ -32,15 +39,16 @@ export class ExternalModulesExecutor { return resolveModule(specifier, parent) } - private wrapSynteticModule(identifier: string, format: 'esm' | 'builtin' | 'cjs', exports: Record) { + private async wrapSynteticModule(identifier: string, format: 'esm' | 'builtin' | 'cjs', exports: Record) { const moduleKeys = Object.keys(exports) + if (format !== 'esm' && !moduleKeys.includes('default')) + moduleKeys.push('default') const m: any = new vm.SyntheticModule( - // TODO: fix "default" shenanigans - Array.from(new Set([...moduleKeys, 'default'])), + moduleKeys, () => { for (const key of moduleKeys) m.setExport(key, exports[key]) - if (format !== 'esm' && !moduleKeys.includes('default')) + if (format !== 'esm') m.setExport('default', exports) }, { @@ -52,8 +60,14 @@ export class ExternalModulesExecutor { } async evaluateModule(m: T): Promise { - if (m.status === 'unlinked') - await m.link(this.importModuleDynamically) + if (m.status === 'unlinked') { + this.esmLinkMap.set( + m, + m.link(this.resolveModule), + ) + } + + await this.esmLinkMap.get(m) if (m.status === 'linked') await m.evaluate() @@ -139,9 +153,6 @@ export class ExternalModulesExecutor { async createEsmModule(fileUrl: string, code: string) { const cached = this.moduleCache.get(fileUrl) - // if (fileUrl.includes('entry')) { - // console.log('esm', fileUrl, !!cached, this.context.__vitest_worker__) - // } if (cached) return cached const m = new vm.SourceTextModule( @@ -161,21 +172,31 @@ export class ExternalModulesExecutor { return m } + private requireCoreModule(identifier: string) { + return _require(identifier) + } + + private getIdentifierCode(code: string) { + if (code.startsWith('data:text/javascript')) + return code.match(/data:text\/javascript;.*,(.*)/)?.[1] + } + async createModule(identifier: string): Promise { const extension = extname(identifier) - if (extension === '.node' || isNodeBuiltin(identifier) || identifier.startsWith('data:text/')) { - const exports = await import(identifier) + if (extension === '.node' || isNodeBuiltin(identifier)) { + const exports = this.requireCoreModule(identifier) return await this.wrapSynteticModule(identifier, 'builtin', exports) } const isFileUrl = identifier.startsWith('file://') const fileUrl = isFileUrl ? identifier : pathToFileURL(identifier).toString() const pathUrl = isFileUrl ? fileURLToPath(identifier) : identifier - const code = await readFile(pathUrl, 'utf-8') + const inlineCode = this.getIdentifierCode(identifier) + const code = inlineCode || await readFile(pathUrl, 'utf-8') - // TODO: very dirty check for cjs - if (extension === '.cjs' || !hasESMSyntax(code)) { + // TODO: very dirty check for cjs, it should actually check filepath + if (!inlineCode && (extension === '.cjs' || !hasESMSyntax(code))) { const exports = this.evaluateCommonJSModule(pathUrl, code) return this.wrapSynteticModule(fileUrl, 'cjs', exports) } From f35f32057de9bc6a897f7f0002a35dca1fdc4601 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 18 Apr 2023 21:03:58 +0200 Subject: [PATCH 12/87] chore: fix mocker VM bugs --- examples/mocks/vite.config.ts | 3 ++ .../src/integrations/env/edge-runtime.ts | 18 +++++++ packages/vitest/src/integrations/env/jsdom.ts | 5 +- packages/vitest/src/runtime/entry-vm.ts | 7 ++- packages/vitest/src/runtime/environment.ts | 15 ++++++ packages/vitest/src/runtime/execute.ts | 1 + packages/vitest/src/runtime/mocker.ts | 48 +++++++++++++++---- packages/vitest/src/runtime/vm.ts | 14 +++--- packages/vitest/src/types/general.ts | 5 +- packages/vitest/src/utils/base.ts | 20 ++++++-- 10 files changed, 107 insertions(+), 29 deletions(-) create mode 100644 packages/vitest/src/runtime/environment.ts diff --git a/examples/mocks/vite.config.ts b/examples/mocks/vite.config.ts index 76cb1dad1e3e..320448de2c5e 100644 --- a/examples/mocks/vite.config.ts +++ b/examples/mocks/vite.config.ts @@ -29,6 +29,9 @@ export default defineConfig({ test: { globals: true, environment: 'node', + poolMatchGlobs: [ + ['**/*', 'vm'], + ], deps: { external: [/src\/external/], interopDefault: true, diff --git a/packages/vitest/src/integrations/env/edge-runtime.ts b/packages/vitest/src/integrations/env/edge-runtime.ts index 9d072eb0aaec..1ccc055d7e64 100644 --- a/packages/vitest/src/integrations/env/edge-runtime.ts +++ b/packages/vitest/src/integrations/env/edge-runtime.ts @@ -5,6 +5,24 @@ import { populateGlobal } from './utils' export default ({ name: 'edge-runtime', transformMode: 'ssr', + async setupVM() { + const { EdgeVM } = await importModule('@edge-runtime/vm') as typeof import('@edge-runtime/vm') + const vm = new EdgeVM({ + extend: (context) => { + context.global = context + context.Buffer = Buffer + return context + }, + }) + return { + getVmContext() { + return vm.context + }, + teardown() { + // TODO + }, + } + }, async setup(global) { const { EdgeVM } = await importModule('@edge-runtime/vm') as typeof import('@edge-runtime/vm') const vm = new EdgeVM({ diff --git a/packages/vitest/src/integrations/env/jsdom.ts b/packages/vitest/src/integrations/env/jsdom.ts index 2964a5b92453..2f7c1b8090bb 100644 --- a/packages/vitest/src/integrations/env/jsdom.ts +++ b/packages/vitest/src/integrations/env/jsdom.ts @@ -29,7 +29,7 @@ function catchWindowErrors(window: Window) { export default ({ name: 'jsdom', transformMode: 'web', - async setupVm(_: any, { jsdom = {} }) { + async setupVM({ jsdom = {} }) { const { CookieJar, JSDOM, @@ -65,9 +65,6 @@ export default ({ }, ) return { - getGlobal() { - return dom.window - }, getVmContext() { return dom.getInternalVMContext() }, diff --git a/packages/vitest/src/runtime/entry-vm.ts b/packages/vitest/src/runtime/entry-vm.ts index dba18f545349..fdf0c246b8c7 100644 --- a/packages/vitest/src/runtime/entry-vm.ts +++ b/packages/vitest/src/runtime/entry-vm.ts @@ -6,6 +6,7 @@ import { setupChaiConfig } from '../integrations/chai' import { startCoverageInsideWorker, stopCoverageInsideWorker } from '../integrations/coverage' import type { ResolvedConfig } from '../types' import { getWorkerState } from '../utils/global' +import { VitestSnapshotEnvironment } from '../integrations/snapshot/environments/node' import type { VitestExecutor } from './execute' import { resolveTestRunner } from './runners' import { setupCommonEnv } from './setup.common' @@ -15,6 +16,8 @@ export async function run(files: string[], config: ResolvedConfig, executor: Vit await setupCommonEnv(config) + config.snapshotOptions.snapshotEnvironment = new VitestSnapshotEnvironment(workerState.rpc) + setupColors(createColors(isatty(1))) const _require = createRequire(import.meta.url) @@ -23,8 +26,6 @@ export async function run(files: string[], config: ResolvedConfig, executor: Vit _require.extensions['.scss'] = () => ({}) _require.extensions['.sass'] = () => ({}) - Error.stackTraceLimit = 1000 - await startCoverageInsideWorker(config.coverage, executor) if (config.chaiConfig) @@ -32,6 +33,8 @@ export async function run(files: string[], config: ResolvedConfig, executor: Vit const runner = await resolveTestRunner(config, executor) + workerState.durations.prepare = performance.now() - workerState.durations.prepare + for (const file of files) { workerState.filepath = file diff --git a/packages/vitest/src/runtime/environment.ts b/packages/vitest/src/runtime/environment.ts new file mode 100644 index 000000000000..f5aa85acc363 --- /dev/null +++ b/packages/vitest/src/runtime/environment.ts @@ -0,0 +1,15 @@ +import { environments } from '../integrations/env' +import type { Environment } from '../types' + +export async function loadEnvironment(name: string, method: 'setup' | 'setupVM'): Promise { + if (name in environments) + return environments[name as 'jsdom'] + const pkg = await import(`vitest-environment-${name}`) + if (!pkg || !pkg.default || typeof pkg.default !== 'object' || typeof pkg.default[method] !== 'function') { + throw new Error( + `Environment "${name}" is not a valid environment. ` + + `Package "vitest-environment-${name}" should have default export with "${method}" method.`, + ) + } + return pkg.default +} diff --git a/packages/vitest/src/runtime/execute.ts b/packages/vitest/src/runtime/execute.ts index 96c3dfd72821..0db4dce646dc 100644 --- a/packages/vitest/src/runtime/execute.ts +++ b/packages/vitest/src/runtime/execute.ts @@ -25,6 +25,7 @@ export async function createVitestExecutor(options: ExecuteOptions) { const runner = new VitestExecutor(options) await runner.executeId('/@vite/env') + await runner.mocker.initializeSpyModule() return runner } diff --git a/packages/vitest/src/runtime/mocker.ts b/packages/vitest/src/runtime/mocker.ts index 8158e3345857..55da5dd8811e 100644 --- a/packages/vitest/src/runtime/mocker.ts +++ b/packages/vitest/src/runtime/mocker.ts @@ -1,12 +1,16 @@ import { existsSync, readdirSync } from 'node:fs' +import vm from 'node:vm' import { basename, dirname, extname, isAbsolute, join, resolve } from 'pathe' import { getColors, getType } from '@vitest/utils' import { isNodeBuiltin } from 'vite-node/utils' +import { distDir } from '../paths' +import type { GlobalConstructors } from '../utils/base' import { getAllMockableProperties } from '../utils/base' import type { MockFactory, PendingSuiteMock } from '../types/mocker' -import { spyOn } from '../integrations/spy' import type { VitestExecutor } from './execute' +const spyModulePath = resolve(distDir, 'spy.js') + const filterPublicKeys = ['__esModule', Symbol.asyncIterator, Symbol.hasInstance, Symbol.isConcatSpreadable, Symbol.iterator, Symbol.match, Symbol.matchAll, Symbol.replace, Symbol.search, Symbol.split, Symbol.species, Symbol.toPrimitive, Symbol.toStringTag, Symbol.unscopables] class RefTracker { @@ -38,7 +42,8 @@ function isSpecialProp(prop: Key, parentType: string) { } export class VitestMocker { - public static pendingIds: PendingSuiteMock[] = [] + private static pendingIds: PendingSuiteMock[] = [] + private spyModule?: typeof import('@vitest/spy') private resolveCache = new Map>() constructor( @@ -61,6 +66,10 @@ export class VitestMocker { return this.executor.options.moduleDirectories || [] } + public async initializeSpyModule() { + this.spyModule = await this.executor.executeId(spyModulePath) + } + private deleteCachedItem(id: string) { const mockId = this.getMockPath(id) if (this.moduleCache.has(mockId)) @@ -75,6 +84,25 @@ export class VitestMocker { return this.executor.state.filepath || 'global' } + private getErrorConstructor(): typeof Error { + const context = this.executor.options.context + if (!context) + return Error + return vm.runInContext('Error', context) + } + + private createError(message: string) { + const Error = this.getErrorConstructor() + return new Error(message) + } + + private getFinalPrototypes(): GlobalConstructors { + const context = this.executor.options.context + if (!context) + return { Object, Function, RegExp, Array, Map } + return vm.runInContext('({ Object, Function, RegExp, Array, Map })', context) + } + public getMocks() { const suite = this.getSuiteFilepath() const suiteMocks = this.mockMap.get(suite) @@ -138,7 +166,7 @@ export class VitestMocker { exports = await mock() } catch (err) { - const vitestError = new Error( + const vitestError = this.createError( '[vitest] There was an error when mocking a module. ' + 'If you are using "vi.mock" factory, make sure there are no top level variables inside, since this call is hoisted to top of the file. ' + 'Read more: https://vitest.dev/api/vi.html#vi-mock') @@ -150,10 +178,10 @@ export class VitestMocker { const mockpath = this.resolveCache.get(this.getSuiteFilepath())?.[filepath] || filepath if (exports === null || typeof exports !== 'object') - throw new Error(`[vitest] vi.mock("${mockpath}", factory?: () => unknown) is not returning an object. Did you mean to return an object with a "default" key?`) + throw this.createError(`[vitest] vi.mock("${mockpath}", factory?: () => unknown) is not returning an object. Did you mean to return an object with a "default" key?`) const moduleExports = new Proxy(exports, { - get(target, prop) { + get: (target, prop) => { const val = target[prop] // 'then' can exist on non-Promise objects, need nested instanceof check for logic to work @@ -165,7 +193,7 @@ export class VitestMocker { if (filterPublicKeys.includes(prop)) return undefined const c = getColors() - throw new Error( + throw this.createError( `[vitest] No "${String(prop)}" export is defined on the "${mockpath}" mock. ` + 'Did you forget to return it from "vi.mock"?' + '\nIf you need to partially mock a module, you can use "vi.importActual" inside:\n\n' @@ -233,6 +261,7 @@ export class VitestMocker { public mockObject(object: Record, mockExports: Record = {}) { const finalizers = new Array<() => void>() const refs = new RefTracker() + const constructors = this.getFinalPrototypes() const define = (container: Record, key: Key, value: any) => { try { @@ -247,7 +276,7 @@ export class VitestMocker { const mockPropertiesOf = (container: Record, newContainer: Record) => { const containerType = getType(container) const isModule = containerType === 'Module' || !!container.__esModule - for (const { key: property, descriptor } of getAllMockableProperties(container, isModule)) { + for (const { key: property, descriptor } of getAllMockableProperties(container, isModule, constructors)) { // Modules define their exports as getters. We want to process those. if (!isModule && descriptor.get) { try { @@ -292,7 +321,10 @@ export class VitestMocker { continue if (isFunction) { - const mock = spyOn(newContainer, property).mockImplementation(() => undefined) + const spyModule = this.spyModule + if (!spyModule) + throw this.createError('[vitest] `spyModule` is not defined. This is Vitest error. Please open a new issue with reproduction.') + const mock = spyModule.spyOn(newContainer, property).mockImplementation(() => undefined) mock.mockRestore = () => { mock.mockReset() mock.mockImplementation(() => undefined) diff --git a/packages/vitest/src/runtime/vm.ts b/packages/vitest/src/runtime/vm.ts index b91ac29f290c..5e188a6a90de 100644 --- a/packages/vitest/src/runtime/vm.ts +++ b/packages/vitest/src/runtime/vm.ts @@ -6,14 +6,12 @@ import { resolve } from 'pathe' import { installSourcemapsSupport } from 'vite-node/source-map' import type { RuntimeRPC, WorkerContext, WorkerGlobalState } from '../types' import { distDir } from '../paths' -import { environments } from '../integrations/env' -import { VitestSnapshotEnvironment } from '../integrations/snapshot/environments/node' import { startVitestExecutor } from './execute' import { createCustomConsole } from './console' +import { loadEnvironment } from './environment' const entryFile = pathToFileURL(resolve(distDir, 'entry-vm.js')).href -// TODO: currently expects only one file in this function, which makes sense because the function itself is called for each file separately export async function run(ctx: WorkerContext) { const moduleCache = new ModuleCacheMap() const mockMap = new Map() @@ -33,7 +31,7 @@ export async function run(ctx: WorkerContext) { mockMap, environment: ctx.environment.name, durations: { - environment: 0, + environment: performance.now(), prepare: performance.now(), }, rpc, @@ -43,11 +41,11 @@ export async function run(ctx: WorkerContext) { getSourceMap: source => moduleCache.getSourceMap(source), }) - config.snapshotOptions.snapshotEnvironment = new VitestSnapshotEnvironment(rpc) + const environment = await loadEnvironment(ctx.environment.name, 'setupVM') - const environment = environments[ctx.environment.name as 'happy-dom'] + const vm = await environment.setupVM!(ctx.environment.options || {}) - const vm = await environment.setupVM!({}, ctx.environment.options || {}) + state.durations.environment = performance.now() - state.durations.environment process.env.VITEST_WORKER_ID = String(ctx.workerId) process.env.VITEST_POOL_ID = String(poolId) @@ -92,7 +90,7 @@ export async function run(ctx: WorkerContext) { await run(ctx.files, ctx.config, executor) } finally { - await vm.teardown({}) + await vm.teardown() state.environmentTeardownRun = true } } diff --git a/packages/vitest/src/types/general.ts b/packages/vitest/src/types/general.ts index 75ea208968cc..18c1eb205788 100644 --- a/packages/vitest/src/types/general.ts +++ b/packages/vitest/src/types/general.ts @@ -24,15 +24,14 @@ export interface EnvironmentReturn { } export interface VmEnvironmentReturn { - getGlobal(): Context getVmContext(): Context - teardown: (global: any) => Awaitable + teardown(): Awaitable } export interface Environment { name: string transformMode?: 'web' | 'ssr' - setupVm?(global: any, options: Record): Awaitable + setupVM?(options: Record): Awaitable setup(global: any, options: Record): Awaitable } diff --git a/packages/vitest/src/utils/base.ts b/packages/vitest/src/utils/base.ts index 010a1b0e3107..151de2a8cdf8 100644 --- a/packages/vitest/src/utils/base.ts +++ b/packages/vitest/src/utils/base.ts @@ -2,8 +2,12 @@ import type { Arrayable, Nullable } from '../types' export { notNullish, getCallLastIndex } from '@vitest/utils' -function isFinalObj(obj: any) { - return obj === Object.prototype || obj === Function.prototype || obj === RegExp.prototype +export interface GlobalConstructors { + Object: ObjectConstructor + Function: FunctionConstructor + RegExp: RegExpConstructor + Array: ArrayConstructor + Map: MapConstructor } function collectOwnProperties(obj: any, collector: Set | ((key: string | symbol) => void)) { @@ -25,12 +29,20 @@ export function isPrimitive(value: unknown) { return value === null || (typeof value !== 'function' && typeof value !== 'object') } -export function getAllMockableProperties(obj: any, isModule: boolean) { +export function getAllMockableProperties(obj: any, isModule: boolean, constructors: GlobalConstructors) { + const { + Map, + Object, + Function, + RegExp, + Array, + } = constructors + const allProps = new Map() let curr = obj do { // we don't need properties from these - if (isFinalObj(curr)) + if (curr === Object.prototype || curr === Function.prototype || curr === RegExp.prototype) break collectOwnProperties(curr, (key) => { From b9c1dce45553f769e606751c1a91449ae7966b6f Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 18 Apr 2023 21:04:18 +0200 Subject: [PATCH 13/87] chore: cleanup --- packages/vitest/src/runtime/mocker.ts | 4 ++-- 1 file changed, 2 insertions(+), 2 deletions(-) diff --git a/packages/vitest/src/runtime/mocker.ts b/packages/vitest/src/runtime/mocker.ts index 55da5dd8811e..7aa34a8f67e2 100644 --- a/packages/vitest/src/runtime/mocker.ts +++ b/packages/vitest/src/runtime/mocker.ts @@ -96,7 +96,7 @@ export class VitestMocker { return new Error(message) } - private getFinalPrototypes(): GlobalConstructors { + private getFinalConstructors(): GlobalConstructors { const context = this.executor.options.context if (!context) return { Object, Function, RegExp, Array, Map } @@ -261,7 +261,7 @@ export class VitestMocker { public mockObject(object: Record, mockExports: Record = {}) { const finalizers = new Array<() => void>() const refs = new RefTracker() - const constructors = this.getFinalPrototypes() + const constructors = this.getFinalConstructors() const define = (container: Record, key: Key, value: any) => { try { From 755f4015dc2f39936d0fcc28f4d7f245d368c924 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 18 Apr 2023 21:16:27 +0200 Subject: [PATCH 14/87] chore: fix evaluating scripts with // comments at the end of the file --- packages/vitest/src/runtime/external-executor.ts | 3 ++- 1 file changed, 2 insertions(+), 1 deletion(-) diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index 4ee3a9686e45..a35d4e8369c3 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -135,7 +135,7 @@ export class ExternalModulesExecutor { if (extension === '.css' || extension === '.scss' || extension === '.sass') return this.evaluateCssCommonJSModule(filename) - const cjsModule = `(function (exports, require, module, __filename, __dirname) { ${code} })` + const cjsModule = `(function (exports, require, module, __filename, __dirname) { ${code}\n})` const script = new vm.Script(cjsModule, { filename, importModuleDynamically: this.importModuleDynamically as any, @@ -172,6 +172,7 @@ export class ExternalModulesExecutor { return m } + // TODO: return custom "createRequire" function for "node:module" private requireCoreModule(identifier: string) { return _require(identifier) } From 7965255fc9bf352bc8b308320960b58fe9f606c3 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 18 Apr 2023 21:36:26 +0200 Subject: [PATCH 15/87] perf: improve entry import performance --- .../vitest/src/integrations/chai/config.ts | 7 ++++++ .../vitest/src/integrations/chai/index.ts | 6 ----- packages/vitest/src/integrations/vi.ts | 3 ++- packages/vitest/src/runtime/entry-vm.ts | 2 +- packages/vitest/src/runtime/entry.ts | 2 +- packages/vitest/src/runtime/execute.ts | 16 ++++++++------ packages/vitest/src/types/config.ts | 2 +- packages/vitest/src/utils/index.ts | 22 +------------------ .../src/utils/{import.ts => modules.ts} | 21 ++++++++++++++++++ 9 files changed, 43 insertions(+), 38 deletions(-) create mode 100644 packages/vitest/src/integrations/chai/config.ts rename packages/vitest/src/utils/{import.ts => modules.ts} (56%) diff --git a/packages/vitest/src/integrations/chai/config.ts b/packages/vitest/src/integrations/chai/config.ts new file mode 100644 index 000000000000..2adbcb6143f2 --- /dev/null +++ b/packages/vitest/src/integrations/chai/config.ts @@ -0,0 +1,7 @@ +import * as chai from 'chai' + +export function setupChaiConfig(config: ChaiConfig) { + Object.assign(chai.config, config) +} + +export type ChaiConfig = Omit, 'useProxy' | 'proxyExcludedKeys'> diff --git a/packages/vitest/src/integrations/chai/index.ts b/packages/vitest/src/integrations/chai/index.ts index 93d3c6d8094a..4433d6985277 100644 --- a/packages/vitest/src/integrations/chai/index.ts +++ b/packages/vitest/src/integrations/chai/index.ts @@ -95,9 +95,3 @@ Object.defineProperty(globalThis, GLOBAL_EXPECT, { export { assert, should } from 'chai' export { chai, globalExpect as expect } - -export function setupChaiConfig(config: ChaiConfig) { - Object.assign(chai.config, config) -} - -export type ChaiConfig = Omit, 'useProxy' | 'proxyExcludedKeys'> diff --git a/packages/vitest/src/integrations/vi.ts b/packages/vitest/src/integrations/vi.ts index a463a33865f3..a93cab706786 100644 --- a/packages/vitest/src/integrations/vi.ts +++ b/packages/vitest/src/integrations/vi.ts @@ -3,8 +3,9 @@ import { assertTypes, createSimpleStackTrace } from '@vitest/utils' import { parseSingleStack } from '../utils/source-map' import type { VitestMocker } from '../runtime/mocker' import type { ResolvedConfig, RuntimeConfig } from '../types' -import { getWorkerState, resetModules, waitForImportsToResolve } from '../utils' import type { MockFactoryWithHelper } from '../types/mocker' +import { getWorkerState } from '../utils/global' +import { resetModules, waitForImportsToResolve } from '../utils/modules' import { FakeTimers } from './mock/timers' import type { EnhancedSpy, MaybeMocked, MaybeMockedDeep, MaybePartiallyMocked, MaybePartiallyMockedDeep } from './spy' import { fn, isMockFunction, spies, spyOn } from './spy' diff --git a/packages/vitest/src/runtime/entry-vm.ts b/packages/vitest/src/runtime/entry-vm.ts index fdf0c246b8c7..19fbdaf195f4 100644 --- a/packages/vitest/src/runtime/entry-vm.ts +++ b/packages/vitest/src/runtime/entry-vm.ts @@ -2,7 +2,7 @@ import { isatty } from 'node:tty' import { createRequire } from 'node:module' import { startTests } from '@vitest/runner' import { createColors, setupColors } from '@vitest/utils' -import { setupChaiConfig } from '../integrations/chai' +import { setupChaiConfig } from '../integrations/chai/config' import { startCoverageInsideWorker, stopCoverageInsideWorker } from '../integrations/coverage' import type { ResolvedConfig } from '../types' import { getWorkerState } from '../utils/global' diff --git a/packages/vitest/src/runtime/entry.ts b/packages/vitest/src/runtime/entry.ts index a86b2932ab3d..6ee9b78edaa2 100644 --- a/packages/vitest/src/runtime/entry.ts +++ b/packages/vitest/src/runtime/entry.ts @@ -4,7 +4,7 @@ import type { ResolvedConfig, ResolvedTestEnvironment } from '../types' import { getWorkerState, resetModules } from '../utils' import { vi } from '../integrations/vi' import { startCoverageInsideWorker, stopCoverageInsideWorker } from '../integrations/coverage' -import { setupChaiConfig } from '../integrations/chai' +import { setupChaiConfig } from '../integrations/chai/config' import { setupGlobalEnv, withEnv } from './setup.node' import type { VitestExecutor } from './execute' import { resolveTestRunner } from './runners' diff --git a/packages/vitest/src/runtime/execute.ts b/packages/vitest/src/runtime/execute.ts index 0db4dce646dc..a0cfdf5d275f 100644 --- a/packages/vitest/src/runtime/execute.ts +++ b/packages/vitest/src/runtime/execute.ts @@ -120,14 +120,16 @@ export class VitestExecutor extends ViteNodeRunner { this.mocker = new VitestMocker(this) - Object.defineProperty(globalThis, '__vitest_mocker__', { - value: this.mocker, - writable: true, - configurable: true, - }) - - if (options.context) + if (!options.context) { + Object.defineProperty(globalThis, '__vitest_mocker__', { + value: this.mocker, + writable: true, + configurable: true, + }) + } + else { this.externalModules = new ExternalModulesExecutor(options.context) + } } get state() { diff --git a/packages/vitest/src/types/config.ts b/packages/vitest/src/types/config.ts index 234e2b4bdd7a..94f6edc8b80f 100644 --- a/packages/vitest/src/types/config.ts +++ b/packages/vitest/src/types/config.ts @@ -5,7 +5,7 @@ import type { SequenceHooks, SequenceSetupFiles } from '@vitest/runner' import type { ViteNodeServerOptions } from 'vite-node' import type { BuiltinReporters } from '../node/reporters' import type { TestSequencerConstructor } from '../node/sequencers/types' -import type { ChaiConfig } from '../integrations/chai' +import type { ChaiConfig } from '../integrations/chai/config' import type { CoverageOptions, ResolvedCoverageOptions } from './coverage' import type { JSDOMOptions } from './jsdom-options' import type { Reporter } from './reporter' diff --git a/packages/vitest/src/utils/index.ts b/packages/vitest/src/utils/index.ts index 7cf3ea9540bf..5464456d13b3 100644 --- a/packages/vitest/src/utils/index.ts +++ b/packages/vitest/src/utils/index.ts @@ -1,5 +1,4 @@ import { relative } from 'pathe' -import type { ModuleCacheMap } from 'vite-node' import { getWorkerState } from '../utils' import { isNode } from './env' @@ -8,8 +7,8 @@ export * from './tasks' export * from './base' export * from './global' export * from './timers' -export * from './import' export * from './env' +export * from './modules' export const isWindows = isNode && process.platform === 'win32' export function getRunMode() { @@ -25,25 +24,6 @@ export function isRunningInBenchmark() { export const relativePath = relative export { resolve } from 'pathe' -export function resetModules(modules: ModuleCacheMap, resetMocks = false) { - const skipPaths = [ - // Vitest - /\/vitest\/dist\//, - /\/vite-node\/dist\//, - // yarn's .store folder - /vitest-virtual-\w+\/dist/, - // cnpm - /@vitest\/dist/, - // don't clear mocks - ...(!resetMocks ? [/^mock:/] : []), - ] - modules.forEach((mod, path) => { - if (skipPaths.some(re => re.test(path))) - return - modules.invalidateModule(mod) - }) -} - export function removeUndefinedValues>(obj: T): T { for (const key in Object.keys(obj)) { if (obj[key] === undefined) diff --git a/packages/vitest/src/utils/import.ts b/packages/vitest/src/utils/modules.ts similarity index 56% rename from packages/vitest/src/utils/import.ts rename to packages/vitest/src/utils/modules.ts index 0cefc901d256..699d96cffdb1 100644 --- a/packages/vitest/src/utils/import.ts +++ b/packages/vitest/src/utils/modules.ts @@ -1,6 +1,27 @@ +import type { ModuleCacheMap } from 'vite-node/client' + import { getWorkerState } from './global' import { getSafeTimers } from './timers' +export function resetModules(modules: ModuleCacheMap, resetMocks = false) { + const skipPaths = [ + // Vitest + /\/vitest\/dist\//, + /\/vite-node\/dist\//, + // yarn's .store folder + /vitest-virtual-\w+\/dist/, + // cnpm + /@vitest\/dist/, + // don't clear mocks + ...(!resetMocks ? [/^mock:/] : []), + ] + modules.forEach((mod, path) => { + if (skipPaths.some(re => re.test(path))) + return + modules.invalidateModule(mod) + }) +} + function waitNextTick() { const { setTimeout } = getSafeTimers() return new Promise(resolve => setTimeout(resolve, 0)) From 2c3a9134d73e1d252cbdcc10031cd21ebb44bfd8 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Wed, 19 Apr 2023 09:21:53 +0200 Subject: [PATCH 16/87] chore: cleanup --- packages/vitest/src/node/pools/vm.ts | 5 +---- packages/vitest/suppress-warnings.cjs | 1 + 2 files changed, 2 insertions(+), 4 deletions(-) diff --git a/packages/vitest/src/node/pools/vm.ts b/packages/vitest/src/node/pools/vm.ts index 8a52d60290e5..a797c210f8ea 100644 --- a/packages/vitest/src/node/pools/vm.ts +++ b/packages/vitest/src/node/pools/vm.ts @@ -25,10 +25,7 @@ function createWorkerChannel(project: WorkspaceProject) { createMethodsRPC(project), { post(v) { - try { - port.postMessage(v) - } - catch {} + port.postMessage(v) }, on(fn) { port.on('message', fn) diff --git a/packages/vitest/suppress-warnings.cjs b/packages/vitest/suppress-warnings.cjs index f3cdeef0c4c6..aa71368624b6 100644 --- a/packages/vitest/suppress-warnings.cjs +++ b/packages/vitest/suppress-warnings.cjs @@ -6,6 +6,7 @@ const ignoreWarnings = new Set([ 'Custom ESM Loaders is an experimental feature. This feature could change at any time', 'Custom ESM Loaders is an experimental feature and might change at any time', 'VM Modules is an experimental feature and might change at any time', + 'VM Modules is an experimental feature. This feature could change at any time', ]) const { emit } = process From 38a4114ce675b016cb493123844a60aa5c327869 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Wed, 19 Apr 2023 10:06:16 +0200 Subject: [PATCH 17/87] chore: safe guard rpc just once --- packages/vitest/src/runtime/child.ts | 32 ++++++++++++++------------- packages/vitest/src/runtime/rpc.ts | 9 ++++++-- packages/vitest/src/runtime/worker.ts | 25 ++++++++++++--------- pnpm-lock.yaml | 10 +-------- 4 files changed, 39 insertions(+), 37 deletions(-) diff --git a/packages/vitest/src/runtime/child.ts b/packages/vitest/src/runtime/child.ts index d212352a55b1..12abf7c30bab 100644 --- a/packages/vitest/src/runtime/child.ts +++ b/packages/vitest/src/runtime/child.ts @@ -7,7 +7,7 @@ import type { ResolvedConfig, WorkerGlobalState } from '../types' import type { RunnerRPC, RuntimeRPC } from '../types/rpc' import type { ChildContext } from '../types/child' import { mockMap, moduleCache, startViteNode } from './execute' -import { rpcDone } from './rpc' +import { createSafeRpc, rpcDone } from './rpc' import { setupInspect } from './inspector' function init(ctx: ChildContext) { @@ -21,6 +21,21 @@ function init(ctx: ChildContext) { setCancel = resolve }) + const rpc = createBirpc( + { + onCancel: setCancel, + }, + { + eventNames: ['onUserConsoleLog', 'onFinished', 'onCollected', 'onWorkerExit', 'onCancel'], + serialize: v8.serialize, + deserialize: v => v8.deserialize(Buffer.from(v)), + post(v) { + process.send?.(v) + }, + on(fn) { process.on('message', fn) }, + }, + ) + const state = { ctx, moduleCache, @@ -32,20 +47,7 @@ function init(ctx: ChildContext) { environment: 0, prepare: performance.now(), }, - rpc: createBirpc( - { - onCancel: setCancel, - }, - { - eventNames: ['onUserConsoleLog', 'onFinished', 'onCollected', 'onWorkerExit', 'onCancel'], - serialize: v8.serialize, - deserialize: v => v8.deserialize(Buffer.from(v)), - post(v) { - process.send?.(v) - }, - on(fn) { process.on('message', fn) }, - }, - ), + rpc: createSafeRpc(rpc), } // @ts-expect-error I know what I am doing :P diff --git a/packages/vitest/src/runtime/rpc.ts b/packages/vitest/src/runtime/rpc.ts index 2e50bbb9be64..0357c059f5a1 100644 --- a/packages/vitest/src/runtime/rpc.ts +++ b/packages/vitest/src/runtime/rpc.ts @@ -4,6 +4,7 @@ import { import type { BirpcReturn } from 'birpc' import { getWorkerState } from '../utils/global' import type { RuntimeRPC } from '../types/rpc' +import type { WorkerRPC } from '../types' const { get } = Reflect @@ -52,8 +53,7 @@ export async function rpcDone() { return Promise.all(awaitable) } -export function rpc(): BirpcReturn { - const { rpc } = getWorkerState() +export function createSafeRpc(rpc: WorkerRPC) { return new Proxy(rpc, { get(target, p, handler) { const sendCall = get(target, p, handler) @@ -72,3 +72,8 @@ export function rpc(): BirpcReturn { }, }) } + +export function rpc(): BirpcReturn { + const { rpc } = getWorkerState() + return rpc +} diff --git a/packages/vitest/src/runtime/worker.ts b/packages/vitest/src/runtime/worker.ts index a48dbadc0694..34355cf3c3c9 100644 --- a/packages/vitest/src/runtime/worker.ts +++ b/packages/vitest/src/runtime/worker.ts @@ -6,7 +6,7 @@ import type { RunnerRPC, RuntimeRPC, WorkerContext, WorkerGlobalState } from '.. import { getWorkerState } from '../utils/global' import { mockMap, moduleCache, startViteNode } from './execute' import { setupInspect } from './inspector' -import { rpcDone } from './rpc' +import { createSafeRpc, rpcDone } from './rpc' function init(ctx: WorkerContext) { // @ts-expect-error untyped global @@ -22,6 +22,18 @@ function init(ctx: WorkerContext) { const onCancel = new Promise((resolve) => { setCancel = resolve }) + + const rpc = createBirpc( + { + onCancel: setCancel, + }, + { + eventNames: ['onUserConsoleLog', 'onFinished', 'onCollected', 'onWorkerExit', 'onCancel'], + post(v) { port.postMessage(v) }, + on(fn) { port.addListener('message', fn) }, + }, + ) + const state = { ctx, moduleCache, @@ -33,16 +45,7 @@ function init(ctx: WorkerContext) { environment: 0, prepare: performance.now(), }, - rpc: createBirpc( - { - onCancel: setCancel, - }, - { - eventNames: ['onUserConsoleLog', 'onFinished', 'onCollected', 'onWorkerExit', 'onCancel'], - post(v) { port.postMessage(v) }, - on(fn) { port.addListener('message', fn) }, - }, - ), + rpc: createSafeRpc(rpc), } // @ts-expect-error I know what I am doing :P diff --git a/pnpm-lock.yaml b/pnpm-lock.yaml index a8ddf6c6abcd..abe96a2b6e86 100644 --- a/pnpm-lock.yaml +++ b/pnpm-lock.yaml @@ -328,7 +328,7 @@ importers: version: 20.4.1 '@types/react': specifier: latest - version: 18.0.36 + version: 18.0.37 '@vitejs/plugin-react': specifier: latest version: 4.0.3(vite@4.3.9) @@ -9062,14 +9062,6 @@ packages: csstype: 3.1.0 dev: true - /@types/react@18.0.36: - resolution: {integrity: sha512-Hqbi2s6k4X1CKRYwUb9BwhNN4jbCgs6BfakDTY5b5GEJ5h9i+uf24mRsbNXFh6rHI5zpk5h1b5jOm/eSUrfVNQ==} - dependencies: - '@types/prop-types': 15.7.5 - '@types/scheduler': 0.16.2 - csstype: 3.1.0 - dev: true - /@types/react@18.0.37: resolution: {integrity: sha512-4yaZZtkRN3ZIQD3KSEwkfcik8s0SWV+82dlJot1AbGYHCzJkWP3ENBY6wYeDRmKZ6HkrgoGAmR2HqdwYGp6OEw==} dependencies: From 320aac226513bf5436969e88e5f9a01ca3a864b4 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Wed, 19 Apr 2023 10:16:24 +0200 Subject: [PATCH 18/87] chore: inline vm types --- .../vitest/src/runtime/external-executor.ts | 96 ++++++++++++++++--- 1 file changed, 85 insertions(+), 11 deletions(-) diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index a35d4e8369c3..63a5580fcbbb 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -9,15 +9,89 @@ import { hasESMSyntax } from 'mlly' import { extname } from 'pathe' import { isNodeBuiltin } from 'vite-node/utils' +// need to copy paste types for vm +// because they require latest @types/node which we don't bundle + +interface ModuleEvaluateOptions { + timeout?: vm.RunningScriptOptions['timeout'] | undefined + breakOnSigint?: vm.RunningScriptOptions['breakOnSigint'] | undefined +} + +type ModuleLinker = (specifier: string, referencingModule: VMModule, extra: { assert: Object }) => VMModule | Promise +type ModuleStatus = 'unlinked' | 'linking' | 'linked' | 'evaluating' | 'evaluated' | 'errored' +declare class VMModule { + dependencySpecifiers: readonly string[] + error: any + identifier: string + context: vm.Context + namespace: Object + status: ModuleStatus + evaluate(options?: ModuleEvaluateOptions): Promise + link(linker: ModuleLinker): Promise +} +interface SyntheticModuleOptions { + /** + * String used in stack traces. + * @default 'vm:module(i)' where i is a context-specific ascending index. + */ + identifier?: string | undefined + /** + * The contextified object as returned by the `vm.createContext()` method, to compile and evaluate this module in. + */ + context?: vm.Context | undefined +} +declare class VMSyntheticModule extends VMModule { + /** + * Creates a new `SyntheticModule` instance. + * @param exportNames Array of names that will be exported from the module. + * @param evaluateCallback Called when the module is evaluated. + */ + constructor(exportNames: string[], evaluateCallback: (this: VMSyntheticModule) => void, options?: SyntheticModuleOptions) + /** + * This method is used after the module is linked to set the values of exports. + * If it is called before the module is linked, an `ERR_VM_MODULE_STATUS` error will be thrown. + * @param name + * @param value + */ + setExport(name: string, value: any): void +} + +declare interface ImportModuleDynamically { + (specifier: string, script: VMModule, importAssertions: Object): VMModule | Promise +} + +interface SourceTextModuleOptions { + identifier?: string | undefined + cachedData?: vm.ScriptOptions['cachedData'] | undefined + context?: vm.Context | undefined + lineOffset?: vm.BaseOptions['lineOffset'] | undefined + columnOffset?: vm.BaseOptions['columnOffset'] | undefined + /** + * Called during evaluation of this module to initialize the `import.meta`. + */ + initializeImportMeta?: ((meta: ImportMeta, module: VMSourceTextModule) => void) | undefined + importModuleDynamically?: ImportModuleDynamically +} +declare class VMSourceTextModule extends VMModule { + /** + * Creates a new `SourceTextModule` instance. + * @param code JavaScript Module code to parse + */ + constructor(code: string, options?: SourceTextModuleOptions) +} + +const SyntheticModule: typeof VMSyntheticModule = (vm as any).SyntheticModule +const SourceTextModule: typeof VMSourceTextModule = (vm as any).SourceTextModule + const _require = createRequire(import.meta.url) export class ExternalModulesExecutor { private context: vm.Context private requireCache = _require.cache - private moduleCache = new Map() + private moduleCache = new Map() - private esmLinkMap = new WeakMap>() + private esmLinkMap = new WeakMap>() constructor(context: vm.Context) { this.context = context @@ -25,12 +99,12 @@ export class ExternalModulesExecutor { delete this.requireCache[file] } - importModuleDynamically = async (specifier: string, referencer: vm.Module) => { + importModuleDynamically = async (specifier: string, referencer: VMModule) => { const module = await this.resolveModule(specifier, referencer) return this.evaluateModule(module) } - resolveModule = async (specifier: string, referencer: vm.Module) => { + resolveModule = async (specifier: string, referencer: VMModule) => { const identifier = await this.resolveAsync(specifier, referencer.identifier) return await this.createModule(identifier) } @@ -43,7 +117,7 @@ export class ExternalModulesExecutor { const moduleKeys = Object.keys(exports) if (format !== 'esm' && !moduleKeys.includes('default')) moduleKeys.push('default') - const m: any = new vm.SyntheticModule( + const m: any = new SyntheticModule( moduleKeys, () => { for (const key of moduleKeys) @@ -59,7 +133,7 @@ export class ExternalModulesExecutor { return m } - async evaluateModule(m: T): Promise { + async evaluateModule(m: T): Promise { if (m.status === 'unlinked') { this.esmLinkMap.set( m, @@ -138,8 +212,8 @@ export class ExternalModulesExecutor { const cjsModule = `(function (exports, require, module, __filename, __dirname) { ${code}\n})` const script = new vm.Script(cjsModule, { filename, - importModuleDynamically: this.importModuleDynamically as any, - }) + importModuleDynamically: this.importModuleDynamically, + } as any) // @ts-expect-error mark script with current identifier script.identifier = filename const fn = script.runInContext(this.context) @@ -155,12 +229,12 @@ export class ExternalModulesExecutor { const cached = this.moduleCache.get(fileUrl) if (cached) return cached - const m = new vm.SourceTextModule( + const m = new SourceTextModule( code, { identifier: fileUrl, context: this.context, - importModuleDynamically: this.importModuleDynamically as any, + importModuleDynamically: this.importModuleDynamically, initializeImportMeta: (meta, mod) => { meta.url = mod.identifier // meta.resolve = (specifier: string, importer?: string) => @@ -182,7 +256,7 @@ export class ExternalModulesExecutor { return code.match(/data:text\/javascript;.*,(.*)/)?.[1] } - async createModule(identifier: string): Promise { + async createModule(identifier: string): Promise { const extension = extname(identifier) if (extension === '.node' || isNodeBuiltin(identifier)) { From a994b93898f242c648eef4fcdae3294b4cf41022 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Wed, 19 Apr 2023 10:23:23 +0200 Subject: [PATCH 19/87] chore: lockfile --- pnpm-lock.yaml | 269 ++++++++++--------------------------------------- 1 file changed, 51 insertions(+), 218 deletions(-) diff --git a/pnpm-lock.yaml b/pnpm-lock.yaml index abe96a2b6e86..600343e7f79b 100644 --- a/pnpm-lock.yaml +++ b/pnpm-lock.yaml @@ -614,8 +614,8 @@ importers: specifier: ^18.0.8 version: 18.0.8 '@vitejs/plugin-react': - specifier: ^2.2.0 - version: 2.2.0(vite@4.2.1) + specifier: latest + version: 3.1.0(vite@4.2.1) '@vitest/coverage-c8': specifier: ^0.24.5 version: 0.24.5 @@ -672,8 +672,8 @@ importers: specifier: latest version: 22.1.0 msw: - specifier: ^0.49.2 - version: 0.49.2(typescript@5.0.3) + specifier: ^1.2.1 + version: 1.2.1(typescript@5.0.3) vite: specifier: ^4.3.9 version: 4.3.9(@types/node@18.16.19) @@ -803,11 +803,11 @@ importers: specifier: latest version: 22.1.0 unplugin-auto-import: - specifier: ^0.11.1 - version: 0.11.2(esbuild@0.17.15)(rollup@3.20.2)(vite@4.2.1) + specifier: latest + version: 0.12.1(rollup@3.20.2) unplugin-vue-components: - specifier: ^0.22.4 - version: 0.22.4(esbuild@0.17.15)(rollup@3.20.2)(vite@4.2.1)(vue@3.2.47) + specifier: latest + version: 0.22.12(rollup@3.20.2)(vue@3.2.47) vite: specifier: ^4.3.9 version: 4.3.9(@types/node@18.16.19) @@ -2346,29 +2346,6 @@ packages: transitivePeerDependencies: - supports-color - /@babel/core@7.19.6: - resolution: {integrity: sha512-D2Ue4KHpc6Ys2+AxpIx1BZ8+UegLLLE2p3KJEuJRKmokHOtl49jQ5ny1773KsGLZs8MQvBidAF6yWUJxRqtKtg==} - engines: {node: '>=6.9.0'} - dependencies: - '@ampproject/remapping': 2.2.0 - '@babel/code-frame': 7.18.6 - '@babel/generator': 7.20.7 - '@babel/helper-compilation-targets': 7.20.7(@babel/core@7.19.6) - '@babel/helper-module-transforms': 7.20.11 - '@babel/helpers': 7.20.7 - '@babel/parser': 7.20.7 - '@babel/template': 7.20.7 - '@babel/traverse': 7.20.12 - '@babel/types': 7.21.3 - convert-source-map: 1.9.0 - debug: 4.3.4(supports-color@8.1.1) - gensync: 1.0.0-beta.2 - json5: 2.2.3 - semver: 6.3.0 - transitivePeerDependencies: - - supports-color - dev: true - /@babel/core@7.20.12: resolution: {integrity: sha512-XsMfHovsUYHFMdrIHkZphTN/2Hzzi78R08NuHfDBehym2VsPDL6Zn/JAD/JQdnRvbSsbQc4mVaU1m6JgtTEElg==} engines: {node: '>=6.9.0'} @@ -2494,20 +2471,6 @@ packages: semver: 6.3.0 dev: true - /@babel/helper-compilation-targets@7.20.7(@babel/core@7.19.6): - resolution: {integrity: sha512-4tGORmfQcrc+bvrjb5y3dG9Mx1IOZjsHqQVUz7XCNHO+iTmqxWnVg3KRygjGmpRLJGdQSKuvFinbIb0CnZwHAQ==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0 - dependencies: - '@babel/compat-data': 7.20.10 - '@babel/core': 7.19.6 - '@babel/helper-validator-option': 7.18.6 - browserslist: 4.21.3 - lru-cache: 5.1.1 - semver: 6.3.0 - dev: true - /@babel/helper-compilation-targets@7.20.7(@babel/core@7.20.12): resolution: {integrity: sha512-4tGORmfQcrc+bvrjb5y3dG9Mx1IOZjsHqQVUz7XCNHO+iTmqxWnVg3KRygjGmpRLJGdQSKuvFinbIb0CnZwHAQ==} engines: {node: '>=6.9.0'} @@ -3529,16 +3492,6 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-jsx@7.18.6(@babel/core@7.19.6): - resolution: {integrity: sha512-6mmljtAedFGTWu2p/8WIORGwy+61PLgOMPOdazc7YoJ9ZCWUyFy3A6CpPkRKLKD1ToAesxX8KGEViAiLo9N+7Q==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.19.6 - '@babel/helper-plugin-utils': 7.20.2 - dev: true - /@babel/plugin-syntax-jsx@7.18.6(@babel/core@7.20.12): resolution: {integrity: sha512-6mmljtAedFGTWu2p/8WIORGwy+61PLgOMPOdazc7YoJ9ZCWUyFy3A6CpPkRKLKD1ToAesxX8KGEViAiLo9N+7Q==} engines: {node: '>=6.9.0'} @@ -4333,16 +4286,6 @@ packages: '@babel/plugin-transform-react-jsx': 7.19.0(@babel/core@7.18.13) dev: true - /@babel/plugin-transform-react-jsx-development@7.18.6(@babel/core@7.19.6): - resolution: {integrity: sha512-SA6HEjwYFKF7WDjWcMcMGUimmw/nhNRDWxr+KaLSCrkD/LMDBvWRmHAYgE1HDeF8KUuI8OAu+RT6EOtKxSW2qA==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.19.6 - '@babel/plugin-transform-react-jsx': 7.19.0(@babel/core@7.19.6) - dev: true - /@babel/plugin-transform-react-jsx-development@7.18.6(@babel/core@7.20.12): resolution: {integrity: sha512-SA6HEjwYFKF7WDjWcMcMGUimmw/nhNRDWxr+KaLSCrkD/LMDBvWRmHAYgE1HDeF8KUuI8OAu+RT6EOtKxSW2qA==} engines: {node: '>=6.9.0'} @@ -4363,16 +4306,6 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-react-jsx-self@7.18.6(@babel/core@7.19.6): - resolution: {integrity: sha512-A0LQGx4+4Jv7u/tWzoJF7alZwnBDQd6cGLh9P+Ttk4dpiL+J5p7NSNv/9tlEFFJDq3kjxOavWmbm6t0Gk+A3Ig==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.19.6 - '@babel/helper-plugin-utils': 7.20.2 - dev: true - /@babel/plugin-transform-react-jsx-self@7.18.6(@babel/core@7.20.12): resolution: {integrity: sha512-A0LQGx4+4Jv7u/tWzoJF7alZwnBDQd6cGLh9P+Ttk4dpiL+J5p7NSNv/9tlEFFJDq3kjxOavWmbm6t0Gk+A3Ig==} engines: {node: '>=6.9.0'} @@ -4393,16 +4326,6 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-react-jsx-source@7.19.6(@babel/core@7.19.6): - resolution: {integrity: sha512-RpAi004QyMNisst/pvSanoRdJ4q+jMCWyk9zdw/CyLB9j8RXEahodR6l2GyttDRyEVWZtbN+TpLiHJ3t34LbsQ==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.19.6 - '@babel/helper-plugin-utils': 7.20.2 - dev: true - /@babel/plugin-transform-react-jsx-source@7.19.6(@babel/core@7.20.12): resolution: {integrity: sha512-RpAi004QyMNisst/pvSanoRdJ4q+jMCWyk9zdw/CyLB9j8RXEahodR6l2GyttDRyEVWZtbN+TpLiHJ3t34LbsQ==} engines: {node: '>=6.9.0'} @@ -4441,20 +4364,6 @@ packages: '@babel/types': 7.22.5 dev: true - /@babel/plugin-transform-react-jsx@7.19.0(@babel/core@7.19.6): - resolution: {integrity: sha512-UVEvX3tXie3Szm3emi1+G63jyw1w5IcMY0FSKM+CRnKRI5Mr1YbCNgsSTwoTwKphQEG9P+QqmuRFneJPZuHNhg==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.19.6 - '@babel/helper-annotate-as-pure': 7.18.6 - '@babel/helper-module-imports': 7.18.6 - '@babel/helper-plugin-utils': 7.20.2 - '@babel/plugin-syntax-jsx': 7.18.6(@babel/core@7.19.6) - '@babel/types': 7.21.3 - dev: true - /@babel/plugin-transform-react-jsx@7.19.0(@babel/core@7.20.12): resolution: {integrity: sha512-UVEvX3tXie3Szm3emi1+G63jyw1w5IcMY0FSKM+CRnKRI5Mr1YbCNgsSTwoTwKphQEG9P+QqmuRFneJPZuHNhg==} engines: {node: '>=6.9.0'} @@ -9638,24 +9547,6 @@ packages: - supports-color dev: true - /@vitejs/plugin-react@2.2.0(vite@4.2.1): - resolution: {integrity: sha512-FFpefhvExd1toVRlokZgxgy2JtnBOdp4ZDsq7ldCWaqGSGn9UhWMAVm/1lxPL14JfNS5yGz+s9yFrQY6shoStA==} - engines: {node: ^14.18.0 || >=16.0.0} - peerDependencies: - vite: ^3.0.0 - dependencies: - '@babel/core': 7.19.6 - '@babel/plugin-transform-react-jsx': 7.19.0(@babel/core@7.19.6) - '@babel/plugin-transform-react-jsx-development': 7.18.6(@babel/core@7.19.6) - '@babel/plugin-transform-react-jsx-self': 7.18.6(@babel/core@7.19.6) - '@babel/plugin-transform-react-jsx-source': 7.19.6(@babel/core@7.19.6) - magic-string: 0.26.7 - react-refresh: 0.14.0 - vite: 4.2.1(@types/node@18.15.11) - transitivePeerDependencies: - - supports-color - dev: true - /@vitejs/plugin-react@3.1.0(vite@4.2.1): resolution: {integrity: sha512-AfgcRL8ZBhAlc3BFdigClmTUMISmmzHn7sB2h9U1odvc5U/MjWXsAaz18b/WoppUTDBzxOJwo2VdClfUcItu9g==} engines: {node: ^14.18.0 || >=16.0.0} @@ -15228,17 +15119,6 @@ packages: - supports-color dev: true - /fast-glob@3.2.11: - resolution: {integrity: sha512-xrO3+1bxSo3ZVHAnqzyuewYT6aMFHRAd4Kcs92MAonjwQZLsK9d0SF1IyQ3k5PoirxTW0Oe/RqFgMQ6TcNE5Ew==} - engines: {node: '>=8.6.0'} - dependencies: - '@nodelib/fs.stat': 2.0.5 - '@nodelib/fs.walk': 1.2.8 - glob-parent: 5.1.2 - merge2: 1.4.1 - micromatch: 4.0.5 - dev: true - /fast-glob@3.2.12: resolution: {integrity: sha512-DVj4CQIYYow0BlaelwK1pHl5n5cRSJfM60UA0zK891sVInoPri2Ekj7+e1CT3/3qxXenpI+nBBmQAcJPJgaj4w==} engines: {node: '>=8.6.0'} @@ -17065,6 +16945,10 @@ packages: resolution: {integrity: sha512-5IcdXuf++TTNt3oGl9EBdkvndXA8gmc4bz/Y+mdEpWh3Mcn/+kOw6hI7LD5CocqJWMzeb0I0ClndRVNdEPuJXQ==} dev: true + /is-node-process@1.2.0: + resolution: {integrity: sha512-Vg4o6/fqPxIjtxgUH5QLJhwZ7gW5diGCVlXpuUfELC62CuxM1iHcRe51f2W1FDy04Ai4KJkagKjx3XaqyfRKXw==} + dev: true + /is-number-object@1.0.7: resolution: {integrity: sha512-k1U0IRzLMo7ZlYIfzRu23Oh6MiIFasgpb9X76eqfFZAqwH44UI4KTBvBYIZ1dSL9ZzChTB9ShHfLkR4pdW5krQ==} engines: {node: '>= 0.4'} @@ -19194,13 +19078,6 @@ packages: dependencies: brace-expansion: 1.1.11 - /minimatch@5.1.0: - resolution: {integrity: sha512-9TPBGGak4nHfGZsPBohm9AWg6NoT7QTCehS3BIJABslyZbzxfV78QM2Y6+i741OPZIafFAaiiEMh5OyIrJPgtg==} - engines: {node: '>=10'} - dependencies: - brace-expansion: 2.0.1 - dev: true - /minimatch@5.1.1: resolution: {integrity: sha512-362NP+zlprccbEt/SkxKfRMHnNY85V74mVnpUpNyr3F35covl09Kec7/sEFLt3RA4oXmewtoaanoIf67SE5Y5g==} engines: {node: '>=10'} @@ -19318,15 +19195,6 @@ packages: hasBin: true dev: true - /mlly@0.5.16: - resolution: {integrity: sha512-LaJ8yuh4v0zEmge/g3c7jjFlhoCPfQn6RCjXgm9A0Qiuochq4BcuOxVfWmdnCoLTlg2MV+hqhOek+W2OhG0Lwg==} - dependencies: - acorn: 8.8.2 - pathe: 0.3.9 - pkg-types: 0.3.6 - ufo: 0.8.6 - dev: true - /mlly@1.2.0: resolution: {integrity: sha512-+c7A3CV0KGdKcylsI6khWyts/CYrGTrRVo4R/I7u/cUsy0Conxa6LUhiEzVKIw14lc2L5aiO4+SeVe4TeGRKww==} dependencies: @@ -19446,13 +19314,13 @@ packages: - supports-color dev: true - /msw@0.49.2(typescript@5.0.3): - resolution: {integrity: sha512-70/E10f+POE2UmMw16v8PnKatpZplpkUwVRLBqiIdimpgaC3le7y2yOq9JmOrL15jpwWM5wAcPTOj0f550LI3g==} + /msw@1.2.1(typescript@5.0.3): + resolution: {integrity: sha512-bF7qWJQSmKn6bwGYVPXOxhexTCGD5oJSZg8yt8IBClxvo3Dx/1W0zqE1nX9BSWmzRsCKWfeGWcB/vpqV6aclpw==} engines: {node: '>=14'} hasBin: true requiresBuild: true peerDependencies: - typescript: '>= 4.4.x <= 4.9.x' + typescript: '>= 4.4.x <= 5.0.x' peerDependenciesMeta: typescript: optional: true @@ -19468,15 +19336,15 @@ packages: graphql: 16.6.0 headers-polyfill: 3.1.2 inquirer: 8.2.4 - is-node-process: 1.0.1 + is-node-process: 1.2.0 js-levenshtein: 1.1.6 node-fetch: 2.6.7 - outvariant: 1.3.0 + outvariant: 1.4.0 path-to-regexp: 6.2.1 - strict-event-emitter: 0.2.8 + strict-event-emitter: 0.4.6 type-fest: 2.19.0 typescript: 5.0.3 - yargs: 17.5.1 + yargs: 17.7.1 transitivePeerDependencies: - encoding - supports-color @@ -20117,6 +19985,10 @@ packages: resolution: {integrity: sha512-yeWM9k6UPfG/nzxdaPlJkB2p08hCg4xP6Lx99F+vP8YF7xyZVfTmJjrrNalkmzudD4WFvNLVudQikqUmF8zhVQ==} dev: true + /outvariant@1.4.0: + resolution: {integrity: sha512-AlWY719RF02ujitly7Kk/0QlV+pXGFDHrHf9O2OKqyqgBieaPOIeuSkL8sRK6j2WK+/ZAURq2kZsY0d8JapUiw==} + dev: true + /p-all@2.1.0: resolution: {integrity: sha512-HbZxz5FONzz/z2gJfk6bFca0BCiSRF8jU3yCsWOen/vR6lZjfPOu/e7L3uFzTW1i0H8TlC3vqQstEJPQL4/uLA==} engines: {node: '>=6'} @@ -20608,14 +20480,6 @@ packages: find-up: 5.0.0 dev: true - /pkg-types@0.3.6: - resolution: {integrity: sha512-uQZutkkh6axl1GxDm5/+8ivVdwuJ5pyDGqJeSiIWIUWIqYiK3p9QKozN/Rv6eVvFoeSWkN1uoYeSDBwwBJBtbg==} - dependencies: - jsonc-parser: 3.2.0 - mlly: 0.5.16 - pathe: 0.3.9 - dev: true - /pkg-types@1.0.2: resolution: {integrity: sha512-hM58GKXOcj8WTqUXnsQyJYXdeAPbythQgEF3nTcEo+nkD49chjQ9IKm/QJy9xf6JakXptz86h7ecP2024rrLaQ==} dependencies: @@ -22332,10 +22196,6 @@ packages: ajv-keywords: 3.5.2(ajv@6.12.6) dev: true - /scule@0.3.2: - resolution: {integrity: sha512-zIvPdjOH8fv8CgrPT5eqtxHQXmPNnV/vHJYffZhE43KZkvULvpCTvOt1HPlFaCZx287INL9qaqrZg34e8NgI4g==} - dev: true - /scule@1.0.0: resolution: {integrity: sha512-4AsO/FrViE/iDNEPaAQlb77tf0csuq27EsVpy6ett584EcRTp6pTDLoGWVxCD77y5iU5FauOvhsI4o1APwPoSQ==} dev: true @@ -23015,6 +22875,10 @@ packages: events: 3.3.0 dev: true + /strict-event-emitter@0.4.6: + resolution: {integrity: sha512-12KWeb+wixJohmnwNFerbyiBrAlq5qJLwIt38etRtKtmmHyDSoGlIqFE9wx+4IwG0aDjI7GV8tc8ZccjWZZtTg==} + dev: true + /string-argv@0.3.1: resolution: {integrity: sha512-a1uQGz7IyVy9YwhqjZIZu1c8JO8dNIe20xBmSS6qu9kv++k3JGzCVmprbNN5Kn+BgzD5E7YYwg1CcjuJMRNsvg==} engines: {node: '>=0.6.19'} @@ -23213,12 +23077,6 @@ packages: engines: {node: '>=8'} dev: true - /strip-literal@0.4.2: - resolution: {integrity: sha512-pv48ybn4iE1O9RLgCAN0iU4Xv7RlBTiit6DKmMiErbs9x1wH6vXBs45tWc0H5wUIF6TLTrKweqkmYF/iraQKNw==} - dependencies: - acorn: 8.8.2 - dev: true - /strip-literal@1.0.1: resolution: {integrity: sha512-QZTsipNpa2Ppr6v1AmJHESqJ3Uz247MUS0OjrnnZjFAvEoWqxuyFuXn2xLgMtRnijJShAa1HL0gtJyUs7u7n3Q==} dependencies: @@ -24220,19 +24078,20 @@ packages: vfile: 4.2.1 dev: true - /unimport@0.6.7(esbuild@0.17.15)(rollup@3.20.2)(vite@4.2.1): - resolution: {integrity: sha512-EMoVqDjswHkU+nD098QYHXH7Mkw7KwGDQAyeRF2lgairJnuO+wpkhIcmCqrD1OPJmsjkTbJ2tW6Ap8St0PuWZA==} + /unimport@1.3.0(rollup@3.20.2): + resolution: {integrity: sha512-fOkrdxglsHd428yegH0wPH/6IfaSdDeMXtdRGn6en/ccyzc2aaoxiUTMrJyc6Bu+xoa18RJRPMfLUHEzjz8atw==} dependencies: '@rollup/pluginutils': 5.0.2(rollup@3.20.2) escape-string-regexp: 5.0.0 fast-glob: 3.2.12 local-pkg: 0.4.3 - magic-string: 0.26.7 - mlly: 0.5.16 - pathe: 0.3.9 - scule: 0.3.2 - strip-literal: 0.4.2 - unplugin: 0.9.5(esbuild@0.17.15)(rollup@3.20.2)(vite@4.2.1) + magic-string: 0.27.0 + mlly: 1.2.0 + pathe: 1.1.0 + pkg-types: 1.0.2 + scule: 1.0.0 + strip-literal: 1.0.1 + unplugin: 1.3.1 transitivePeerDependencies: - rollup dev: true @@ -24427,8 +24286,8 @@ packages: engines: {node: '>= 0.8'} dev: true - /unplugin-auto-import@0.11.2(esbuild@0.17.15)(rollup@3.20.2)(vite@4.2.1): - resolution: {integrity: sha512-1+VwBfn9dtiYv9SQLKP1AvZolUbK9xTVeAT+iOcEk4EHSFUlmIqBVLEKI76cifSQTLOJ3rZyPrEgptf3SZNLlQ==} + /unplugin-auto-import@0.12.1(rollup@3.20.2): + resolution: {integrity: sha512-J/3ZORq5YGKG+8D5vLLOgqaHNK77izlVN07mQ752yRLqBNDbJiwPRSnUwwYqH5N6rDay1SqnJCHaUdbJ9QMI2w==} engines: {node: '>=14'} peerDependencies: '@vueuse/core': '*' @@ -24436,12 +24295,12 @@ packages: '@vueuse/core': optional: true dependencies: - '@antfu/utils': 0.5.2 - '@rollup/pluginutils': 4.2.1 - local-pkg: 0.4.2 - magic-string: 0.26.7 - unimport: 0.6.7(esbuild@0.17.15)(rollup@3.20.2)(vite@4.2.1) - unplugin: 0.9.5(esbuild@0.17.15)(rollup@3.20.2)(vite@4.2.1) + '@antfu/utils': 0.7.2 + '@rollup/pluginutils': 5.0.2(rollup@3.20.2) + local-pkg: 0.4.3 + magic-string: 0.27.0 + unimport: 1.3.0(rollup@3.20.2) + unplugin: 1.3.1 transitivePeerDependencies: - rollup dev: true @@ -24470,8 +24329,8 @@ packages: - rollup dev: true - /unplugin-vue-components@0.22.4(esbuild@0.17.15)(rollup@3.20.2)(vite@4.2.1)(vue@3.2.47): - resolution: {integrity: sha512-2rRZcM9OnJGXnYxQNfaceEYuPeVACcWySIjy8WBwIiN3onr980TmA3XE5pRJFt8zoQrUA+c46oyIq96noLqrEQ==} + /unplugin-vue-components@0.22.12(rollup@3.20.2)(vue@3.2.47): + resolution: {integrity: sha512-FxyzsuBvMCYPIk+8cgscGBQ345tvwVu+qY5IhE++eorkyvA4Z1TiD/HCiim+Kbqozl10i4K+z+NCa2WO2jexRA==} engines: {node: '>=14'} peerDependencies: '@nuxt/kit': ^3.2.2 @@ -24486,12 +24345,12 @@ packages: '@rollup/pluginutils': 5.0.2(rollup@3.20.2) chokidar: 3.5.3 debug: 4.3.4(supports-color@8.1.1) - fast-glob: 3.2.11 - local-pkg: 0.4.2 - magic-string: 0.26.3 - minimatch: 5.1.0 + fast-glob: 3.2.12 + local-pkg: 0.4.3 + magic-string: 0.27.0 + minimatch: 5.1.1 resolve: 1.22.1 - unplugin: 0.9.5(esbuild@0.17.15)(rollup@3.20.2)(vite@4.2.1) + unplugin: 1.3.1 vue: 3.2.47 transitivePeerDependencies: - rollup @@ -24555,28 +24414,6 @@ packages: - supports-color dev: true - /unplugin@0.9.5(esbuild@0.17.15)(rollup@3.20.2)(vite@4.2.1): - resolution: {integrity: sha512-luraheyfxwtvkvHpsOvMNv7IjLdORTWKZp0gWYNHGLi2ImON3iIZOj464qEyyEwLA/EMt12fC415HW9zRpOfTg==} - peerDependencies: - '@babel/parser': ^7.15.8 - '@nuxt/kit': ^3.2.2 - vue: 2 || 3 - peerDependenciesMeta: - '@babel/parser': - optional: true - '@nuxt/kit': - optional: true - dependencies: - '@antfu/utils': 0.7.2 - '@rollup/pluginutils': 5.0.2(rollup@3.20.2) - chokidar: 3.5.3 - esbuild: 0.17.15 - rollup: 3.20.2 - vite: 4.2.1(@types/node@18.15.11) - webpack-sources: 3.2.3 - webpack-virtual-modules: 0.4.5 - dev: true - /unplugin@1.3.1: resolution: {integrity: sha512-h4uUTIvFBQRxUKS2Wjys6ivoeofGhxzTe2sRWlooyjHXVttcVfV/JiavNd3d4+jty0SVV0dxGw9AkY9MwiaCEw==} dependencies: @@ -25412,10 +25249,6 @@ packages: - supports-color dev: true - /webpack-virtual-modules@0.4.5: - resolution: {integrity: sha512-8bWq0Iluiv9lVf9YaqWQ9+liNgXSHICm+rg544yRgGYaR8yXZTVBaHZkINZSB2yZSWo4b0F6MIxqJezVfOEAlg==} - dev: true - /webpack-virtual-modules@0.5.0: resolution: {integrity: sha512-kyDivFZ7ZM0BVOUteVbDFhlRt7Ah/CSPwJdi8hBpkK7QLumUqdLtVfm/PX/hkcnrvr0i77fO5+TjZ94Pe+C9iw==} dev: true From 5f81cf1f9af748a3b98f321d31e24db2e46152ba Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Wed, 19 Apr 2023 10:32:08 +0200 Subject: [PATCH 20/87] chore: cleanup --- packages/vitest/src/utils/global.ts | 4 ++-- 1 file changed, 2 insertions(+), 2 deletions(-) diff --git a/packages/vitest/src/utils/global.ts b/packages/vitest/src/utils/global.ts index b8e389e9f021..6239d58685fb 100644 --- a/packages/vitest/src/utils/global.ts +++ b/packages/vitest/src/utils/global.ts @@ -2,10 +2,10 @@ import type { WorkerGlobalState } from '../types' export function getWorkerState(): WorkerGlobalState { // @ts-expect-error untyped global - return __vitest_worker__ + return globalThis.__vitest_worker__ } export function getCurrentEnvironment(): string { const state = getWorkerState() - return state.environment + return state?.environment } From e858784db9b1767918cf7f6503914c9fac34b305 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Wed, 19 Apr 2023 10:57:49 +0200 Subject: [PATCH 21/87] chore: fix web-worker runner options --- packages/web-worker/src/utils.ts | 4 +++- 1 file changed, 3 insertions(+), 1 deletion(-) diff --git a/packages/web-worker/src/utils.ts b/packages/web-worker/src/utils.ts index 758b357a46b4..a955d02b9de1 100644 --- a/packages/web-worker/src/utils.ts +++ b/packages/web-worker/src/utils.ts @@ -61,7 +61,8 @@ export function createMessageEvent(data: any, transferOrOptions: StructuredSeria } export function getRunnerOptions(): any { - const { config, rpc, mockMap, moduleCache } = getWorkerState() + const state = getWorkerState() + const { config, rpc, mockMap, moduleCache } = state return { fetchModule(id: string) { @@ -76,5 +77,6 @@ export function getRunnerOptions(): any { moduleDirectories: config.deps.moduleDirectories, root: config.root, base: config.base, + state, } } From b9e47943f15ceee156a7d455ba00c78dc8bbbd4e Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Thu, 20 Apr 2023 11:11:32 +0200 Subject: [PATCH 22/87] refactor: rename vm to experimental-vm-threads --- packages/vitest/src/node/cli-api.ts | 3 +++ packages/vitest/src/node/cli.ts | 1 + packages/vitest/src/node/pool.ts | 16 +++++++++------- .../src/node/pools/{vm.ts => vm-threads.ts} | 10 +--------- packages/vitest/src/types/config.ts | 12 +++++++++++- test/core/vitest.config.ts | 2 +- 6 files changed, 26 insertions(+), 18 deletions(-) rename packages/vitest/src/node/pools/{vm.ts => vm-threads.ts} (91%) diff --git a/packages/vitest/src/node/cli-api.ts b/packages/vitest/src/node/cli-api.ts index a6456138948f..0592f1ecbd66 100644 --- a/packages/vitest/src/node/cli-api.ts +++ b/packages/vitest/src/node/cli-api.ts @@ -56,6 +56,9 @@ export async function startVitest( if (typeof options.browser === 'object' && !('enabled' in options.browser)) options.browser.enabled = true + if ('threads' in options && options.experimentalVmThreads) + throw new Error('Cannot use both "threads" (or "no-threads") and "experimentalVmThreads" at the same time.') + const ctx = await createVitest(mode, options, viteOverrides) if (mode === 'test' && ctx.config.coverage.enabled) { diff --git a/packages/vitest/src/node/cli.ts b/packages/vitest/src/node/cli.ts index c4573ed3ce3b..722db4b83ab4 100644 --- a/packages/vitest/src/node/cli.ts +++ b/packages/vitest/src/node/cli.ts @@ -23,6 +23,7 @@ cli .option('--api [api]', 'Serve API, available options: --api.port , --api.host [host] and --api.strictPort') .option('--threads', 'Enabled threads (default: true)') .option('--single-thread', 'Run tests inside a single thread, requires --threads (default: false)') + .option('--experimental-vm-threads', 'Run tests in a worker pool using VM isolation (default: false)') .option('--silent', 'Silent console output from tests') .option('--hideSkippedTests', 'Hide logs for skipped tests') .option('--isolate', 'Isolate environment for each test file (default: true)') diff --git a/packages/vitest/src/node/pool.ts b/packages/vitest/src/node/pool.ts index 1f9810e762e2..3b6ecc0cfaf6 100644 --- a/packages/vitest/src/node/pool.ts +++ b/packages/vitest/src/node/pool.ts @@ -7,7 +7,7 @@ import type { Vitest } from './core' import { createChildProcessPool } from './pools/child' import { createThreadsPool } from './pools/threads' import { createBrowserPool } from './pools/browser' -import { createVmPool } from './pools/vm' +import { createVmThreadsPool } from './pools/vm-threads' import type { WorkspaceProject } from './workspace' export type WorkspaceSpec = [project: WorkspaceProject, testFile: string] @@ -31,12 +31,14 @@ export function createPool(ctx: Vitest): ProcessPool { child_process: null, threads: null, browser: null, - vm: null, + experimentalVmThreads: null, } - function getDefaultPoolName(project: WorkspaceProject) { + function getDefaultPoolName(project: WorkspaceProject): VitestPool { if (project.config.browser.enabled) return 'browser' + if (project.config.experimentalVmThreads) + return 'experimentalVmThreads' if (project.config.threads) return 'threads' return 'child_process' @@ -89,7 +91,7 @@ export function createPool(ctx: Vitest): ProcessPool { child_process: [] as WorkspaceSpec[], threads: [] as WorkspaceSpec[], browser: [] as WorkspaceSpec[], - vm: [] as WorkspaceSpec[], + experimentalVmThreads: [] as WorkspaceSpec[], } for (const spec of files) { @@ -106,9 +108,9 @@ export function createPool(ctx: Vitest): ProcessPool { return pools.browser.runTests(files, invalidate) } - if (pool === 'vm') { - pools.vm ??= createVmPool(ctx, options) - return pools.vm.runTests(files, invalidate) + if (pool === 'experimentalVmThreads') { + pools.experimentalVmThreads ??= createVmThreadsPool(ctx, options) + return pools.experimentalVmThreads.runTests(files, invalidate) } if (pool === 'threads') { diff --git a/packages/vitest/src/node/pools/vm.ts b/packages/vitest/src/node/pools/vm-threads.ts similarity index 91% rename from packages/vitest/src/node/pools/vm.ts rename to packages/vitest/src/node/pools/vm-threads.ts index a797c210f8ea..ee4a21a95d42 100644 --- a/packages/vitest/src/node/pools/vm.ts +++ b/packages/vitest/src/node/pools/vm-threads.ts @@ -36,7 +36,7 @@ function createWorkerChannel(project: WorkspaceProject) { return { workerPort, port } } -export function createVmPool(ctx: Vitest, { execArgv, env }: PoolProcessOptions): ProcessPool { +export function createVmThreadsPool(ctx: Vitest, { execArgv, env }: PoolProcessOptions): ProcessPool { const threadsCount = ctx.config.watch ? Math.max(Math.floor(cpus().length / 2), 1) : Math.max(cpus().length - 1, 1) @@ -117,14 +117,6 @@ export function createVmPool(ctx: Vitest, { execArgv, env }: PoolProcessOptions) return config } - const workspaceMap = new Map() - for (const [project, file] of specs) { - const workspaceFiles = workspaceMap.get(file) ?? [] - workspaceFiles.push(project) - workspaceMap.set(file, workspaceFiles) - } - - // it's possible that project defines a file that is also defined by another project const { shard } = ctx.config if (shard) diff --git a/packages/vitest/src/types/config.ts b/packages/vitest/src/types/config.ts index 94f6edc8b80f..af9c3b766be3 100644 --- a/packages/vitest/src/types/config.ts +++ b/packages/vitest/src/types/config.ts @@ -19,7 +19,7 @@ export type { SequenceHooks, SequenceSetupFiles } from '@vitest/runner' export type BuiltinEnvironment = 'node' | 'jsdom' | 'happy-dom' | 'edge-runtime' // Record is used, so user can get intellisense for builtin environments, but still allow custom environments export type VitestEnvironment = BuiltinEnvironment | (string & Record) -export type VitestPool = 'browser' | 'threads' | 'child_process' | 'vm' +export type VitestPool = 'browser' | 'threads' | 'child_process' | 'experimentalVmThreads' export type CSSModuleScopeStrategy = 'stable' | 'scoped' | 'non-scoped' export type ApiConfig = Pick @@ -301,6 +301,16 @@ export interface InlineConfig { */ outputFile?: string | (Partial> & Record) + /** + * Run tests using VM context in a worker pool. + * + * This makes tests run faster, but VM module is unstable. Your tests might leak memory. + */ + experimentalVmThreads?: boolean + + // TODO: document that "--no-isolate" has no effect on experimentalVmThreads + // TODO: workerIdleMemoryLimit for experimentalVmThreads, so they don't leak + /** * Enable multi-threading * diff --git a/test/core/vitest.config.ts b/test/core/vitest.config.ts index 30ea3c18fdb0..5051031ceadf 100644 --- a/test/core/vitest.config.ts +++ b/test/core/vitest.config.ts @@ -50,7 +50,7 @@ export default defineConfig({ './test/setup.ts', ], poolMatchGlobs: [ - ['**/*', 'vm'], + ['**/*', 'experimentalVmThreads'], ], testNamePattern: '^((?!does not include test that).)*$', coverage: { From be23d154f6a6ce719f0a6c10ccfba0991fe5b1e4 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Wed, 10 May 2023 16:53:14 +0200 Subject: [PATCH 23/87] chore: cleanup --- pnpm-lock.yaml | 194 +++++++++++++++++++++---------------------------- 1 file changed, 84 insertions(+), 110 deletions(-) diff --git a/pnpm-lock.yaml b/pnpm-lock.yaml index 600343e7f79b..1efc56c3be59 100644 --- a/pnpm-lock.yaml +++ b/pnpm-lock.yaml @@ -325,10 +325,10 @@ importers: version: 13.3.0(react-dom@18.0.0)(react@18.0.0) '@types/node': specifier: latest - version: 20.4.1 + version: 20.1.2 '@types/react': specifier: latest - version: 18.0.37 + version: 18.2.3 '@vitejs/plugin-react': specifier: latest version: 4.0.3(vite@4.3.9) @@ -615,7 +615,7 @@ importers: version: 18.0.8 '@vitejs/plugin-react': specifier: latest - version: 3.1.0(vite@4.2.1) + version: 4.0.0(vite@4.2.1) '@vitest/coverage-c8': specifier: ^0.24.5 version: 0.24.5 @@ -673,7 +673,7 @@ importers: version: 22.1.0 msw: specifier: ^1.2.1 - version: 1.2.1(typescript@5.0.3) + version: 1.2.1(typescript@5.0.4) vite: specifier: ^4.3.9 version: 4.3.9(@types/node@18.16.19) @@ -2346,28 +2346,6 @@ packages: transitivePeerDependencies: - supports-color - /@babel/core@7.20.12: - resolution: {integrity: sha512-XsMfHovsUYHFMdrIHkZphTN/2Hzzi78R08NuHfDBehym2VsPDL6Zn/JAD/JQdnRvbSsbQc4mVaU1m6JgtTEElg==} - engines: {node: '>=6.9.0'} - dependencies: - '@ampproject/remapping': 2.2.0 - '@babel/code-frame': 7.18.6 - '@babel/generator': 7.20.7 - '@babel/helper-compilation-targets': 7.20.7(@babel/core@7.20.12) - '@babel/helper-module-transforms': 7.20.11 - '@babel/helpers': 7.20.7 - '@babel/parser': 7.20.7 - '@babel/template': 7.20.7 - '@babel/traverse': 7.20.12 - '@babel/types': 7.21.3 - convert-source-map: 1.9.0 - debug: 4.3.4(supports-color@8.1.1) - gensync: 1.0.0-beta.2 - json5: 2.2.3 - semver: 6.3.0 - transitivePeerDependencies: - - supports-color - /@babel/core@7.20.5: resolution: {integrity: sha512-UdOWmk4pNWTm/4DlPUl/Pt4Gz4rcEMb7CY0Y3eJl5Yz1vI8ZJGmHWaVE55LoxRjdpx0z259GE9U5STA9atUinQ==} engines: {node: '>=6.9.0'} @@ -2471,8 +2449,8 @@ packages: semver: 6.3.0 dev: true - /@babel/helper-compilation-targets@7.20.7(@babel/core@7.20.12): - resolution: {integrity: sha512-4tGORmfQcrc+bvrjb5y3dG9Mx1IOZjsHqQVUz7XCNHO+iTmqxWnVg3KRygjGmpRLJGdQSKuvFinbIb0CnZwHAQ==} + /@babel/helper-compilation-targets@7.21.4(@babel/core@7.20.5): + resolution: {integrity: sha512-Fa0tTuOXZ1iL8IeDFUWCzjZcn+sJGd9RZdH9esYVjEejGmzf+FFYQpMi/kZUk2kPy/q1H3/GPw7np8qar/stfg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0 @@ -3492,15 +3470,6 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-jsx@7.18.6(@babel/core@7.20.12): - resolution: {integrity: sha512-6mmljtAedFGTWu2p/8WIORGwy+61PLgOMPOdazc7YoJ9ZCWUyFy3A6CpPkRKLKD1ToAesxX8KGEViAiLo9N+7Q==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.20.12 - '@babel/helper-plugin-utils': 7.20.2 - /@babel/plugin-syntax-jsx@7.18.6(@babel/core@7.20.5): resolution: {integrity: sha512-6mmljtAedFGTWu2p/8WIORGwy+61PLgOMPOdazc7YoJ9ZCWUyFy3A6CpPkRKLKD1ToAesxX8KGEViAiLo9N+7Q==} engines: {node: '>=6.9.0'} @@ -4286,7 +4255,7 @@ packages: '@babel/plugin-transform-react-jsx': 7.19.0(@babel/core@7.18.13) dev: true - /@babel/plugin-transform-react-jsx-development@7.18.6(@babel/core@7.20.12): + /@babel/plugin-transform-react-jsx-development@7.18.6(@babel/core@7.21.4): resolution: {integrity: sha512-SA6HEjwYFKF7WDjWcMcMGUimmw/nhNRDWxr+KaLSCrkD/LMDBvWRmHAYgE1HDeF8KUuI8OAu+RT6EOtKxSW2qA==} engines: {node: '>=6.9.0'} peerDependencies: @@ -4306,8 +4275,8 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-react-jsx-self@7.18.6(@babel/core@7.20.12): - resolution: {integrity: sha512-A0LQGx4+4Jv7u/tWzoJF7alZwnBDQd6cGLh9P+Ttk4dpiL+J5p7NSNv/9tlEFFJDq3kjxOavWmbm6t0Gk+A3Ig==} + /@babel/plugin-transform-react-jsx-self@7.21.0(@babel/core@7.21.4): + resolution: {integrity: sha512-f/Eq+79JEu+KUANFks9UZCcvydOOGMgF7jBrcwjHa5jTZD8JivnhCJYvmlhR/WTXBWonDExPoW0eO/CR4QJirA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 @@ -4326,7 +4295,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-react-jsx-source@7.19.6(@babel/core@7.20.12): + /@babel/plugin-transform-react-jsx-source@7.19.6(@babel/core@7.21.4): resolution: {integrity: sha512-RpAi004QyMNisst/pvSanoRdJ4q+jMCWyk9zdw/CyLB9j8RXEahodR6l2GyttDRyEVWZtbN+TpLiHJ3t34LbsQ==} engines: {node: '>=6.9.0'} peerDependencies: @@ -4364,7 +4333,7 @@ packages: '@babel/types': 7.22.5 dev: true - /@babel/plugin-transform-react-jsx@7.19.0(@babel/core@7.20.12): + /@babel/plugin-transform-react-jsx@7.19.0(@babel/core@7.21.4): resolution: {integrity: sha512-UVEvX3tXie3Szm3emi1+G63jyw1w5IcMY0FSKM+CRnKRI5Mr1YbCNgsSTwoTwKphQEG9P+QqmuRFneJPZuHNhg==} engines: {node: '>=6.9.0'} peerDependencies: @@ -5899,7 +5868,7 @@ packages: engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: '@jest/types': 27.5.1 - '@types/node': 20.4.1 + '@types/node': 20.1.2 chalk: 4.1.2 jest-message-util: 27.5.1 jest-util: 27.5.1 @@ -5920,7 +5889,7 @@ packages: '@jest/test-result': 27.5.1 '@jest/transform': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.1 + '@types/node': 20.1.2 ansi-escapes: 4.3.2 chalk: 4.1.2 emittery: 0.8.1 @@ -5957,7 +5926,7 @@ packages: dependencies: '@jest/fake-timers': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.1 + '@types/node': 20.1.2 jest-mock: 27.5.1 dev: true @@ -5974,7 +5943,7 @@ packages: dependencies: '@jest/types': 27.5.1 '@sinonjs/fake-timers': 8.1.0 - '@types/node': 20.4.1 + '@types/node': 20.1.2 jest-message-util: 27.5.1 jest-mock: 27.5.1 jest-util: 27.5.1 @@ -6003,7 +5972,7 @@ packages: '@jest/test-result': 27.5.1 '@jest/transform': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.1 + '@types/node': 20.1.2 chalk: 4.1.2 collect-v8-coverage: 1.0.1 exit: 0.1.2 @@ -6116,7 +6085,7 @@ packages: dependencies: '@types/istanbul-lib-coverage': 2.0.4 '@types/istanbul-reports': 3.0.1 - '@types/node': 20.4.1 + '@types/node': 20.1.2 '@types/yargs': 15.0.14 chalk: 4.1.2 dev: true @@ -6127,7 +6096,7 @@ packages: dependencies: '@types/istanbul-lib-coverage': 2.0.4 '@types/istanbul-reports': 3.0.1 - '@types/node': 20.4.1 + '@types/node': 20.1.2 '@types/yargs': 16.0.5 chalk: 4.1.2 dev: true @@ -6139,7 +6108,7 @@ packages: '@jest/schemas': 29.4.3 '@types/istanbul-lib-coverage': 2.0.4 '@types/istanbul-reports': 3.0.1 - '@types/node': 20.4.1 + '@types/node': 20.1.2 '@types/yargs': 17.0.12 chalk: 4.1.2 dev: true @@ -6662,7 +6631,7 @@ packages: engines: {node: '>=14'} hasBin: true dependencies: - '@types/node': 20.4.1 + '@types/node': 20.1.2 playwright-core: 1.28.0 dev: true @@ -8641,7 +8610,7 @@ packages: /@types/cheerio@0.22.31: resolution: {integrity: sha512-Kt7Cdjjdi2XWSfrZ53v4Of0wG3ZcmaegFXjMmz9tfNrZSkzzo36G0AL1YqSdcIA78Etjt6E609pt5h1xnQkPUw==} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.1.2 dev: true /@types/codemirror@5.60.8: @@ -8680,7 +8649,7 @@ packages: resolution: {integrity: sha512-xryQlOEIe1TduDWAOphR0ihfebKFSWOXpIsk+70JskCfRfW+xALdnJ0r1ZOTo85F9Qsjk6vtlU7edTYHbls9tA==} dependencies: '@types/cheerio': 0.22.31 - '@types/react': 18.0.37 + '@types/react': 18.2.6 dev: true /@types/eslint-scope@3.7.4: @@ -8711,33 +8680,33 @@ packages: resolution: {integrity: sha512-MxObHvNl4A69ofaTRU8DFqvgzzv8s9yRtaPPm5gud9HDNvpB3GPQFvNuTWAI59B9huVGV5jXYJwbCsmBsOGYWA==} dependencies: '@types/jsonfile': 6.1.1 - '@types/node': 20.4.1 + '@types/node': 20.1.2 dev: true /@types/fs-extra@9.0.13: resolution: {integrity: sha512-nEnwB++1u5lVDM2UI4c1+5R+FYaKfaAzS4OococimjVm3nQw3TuzH5UNsocrcTBbhnerblyHj4A49qXbIiZdpA==} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.1.2 dev: true /@types/glob@7.2.0: resolution: {integrity: sha512-ZUxbzKl0IfJILTS6t7ip5fQQM/J3TJYubDm3nMbgubNNYS62eXeUpoLUC8/7fJNiFYHTrGPQn7hspDUzIHX3UA==} dependencies: '@types/minimatch': 5.1.1 - '@types/node': 20.4.1 + '@types/node': 20.1.2 dev: true /@types/glob@8.0.0: resolution: {integrity: sha512-l6NQsDDyQUVeoTynNpC9uRvCUint/gSUXQA2euwmTuWGvPY5LSDUu6tkCtJB2SvGQlJQzLaKqcGZP4//7EDveA==} dependencies: '@types/minimatch': 5.1.1 - '@types/node': 20.4.1 + '@types/node': 20.1.2 dev: true /@types/graceful-fs@4.1.5: resolution: {integrity: sha512-anKkLmZZ+xm4p8JWBf4hElkM4XR+EZeA2M9BAkkTldmcyDY4mbdIJnRghDJH3Ov5ooY7/UAoENtmdMSkaAd7Cw==} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.1.2 dev: true /@types/hast@2.3.4: @@ -8809,7 +8778,7 @@ packages: /@types/jsdom@21.1.1: resolution: {integrity: sha512-cZFuoVLtzKP3gmq9eNosUL1R50U+USkbLtUQ1bYVgl/lKp0FZM7Cq4aIHAL8oIvQ17uSHi7jXPtfDOdjPwBE7A==} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.1.2 '@types/tough-cookie': 4.0.2 parse5: 7.1.2 dev: true @@ -8821,7 +8790,7 @@ packages: /@types/jsonfile@6.1.1: resolution: {integrity: sha512-GSgiRCVeapDN+3pqA35IkQwasaCh/0YFH5dEF6S88iDvEn901DjOeH3/QPY+XYP1DFzDZPvIvfeEgk+7br5png==} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.1.2 dev: true /@types/lodash@4.14.195: @@ -8855,7 +8824,7 @@ packages: /@types/node-fetch@2.6.2: resolution: {integrity: sha512-DHqhlq5jeESLy19TYhLakJ07kNumXWjcDdxXsLUMJZ6ue8VZJj4kLPQVE/2mdHh3xZziNF1xppu5lwmS53HR+A==} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.1.2 form-data: 3.0.1 dev: true @@ -8874,8 +8843,8 @@ packages: resolution: {integrity: sha512-46yIhxSe5xEaJZXWdIBP7GU4HDTG8/eo0qd9atdiL+lFpA03y8KS+lkTN834TWJj5767GbWv4n/P6efyTFt1Dw==} dev: false - /@types/node@20.4.1: - resolution: {integrity: sha512-JIzsAvJeA/5iY6Y/OxZbv1lUcc8dNSE77lb2gnBH+/PJ3lFR1Ccvgwl5JWnHAkNHcRsT0TbpVOsiMKZ1F/yyJg==} + /@types/node@20.1.2: + resolution: {integrity: sha512-CTO/wa8x+rZU626cL2BlbCDzydgnFNgc19h4YvizpTO88MFQxab8wqisxaofQJ/9bLGugRdWIuX/TbIs6VVF6g==} dev: true /@types/normalize-package-data@2.4.1: @@ -8904,7 +8873,7 @@ packages: /@types/prompts@2.4.4: resolution: {integrity: sha512-p5N9uoTH76lLvSAaYSZtBCdEXzpOOufsRjnhjVSrZGXikVGHX9+cc9ERtHRV4hvBKHyZb1bg4K+56Bd2TqUn4A==} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.1.2 kleur: 3.0.3 dev: true @@ -8928,19 +8897,19 @@ packages: /@types/react-dom@18.0.6: resolution: {integrity: sha512-/5OFZgfIPSwy+YuIBP/FgJnQnsxhZhjjrnxudMddeblOouIodEQ75X14Rr4wGSG/bknL+Omy9iWlLo1u/9GzAA==} dependencies: - '@types/react': 18.0.37 + '@types/react': 18.2.6 dev: true /@types/react-dom@18.0.8: resolution: {integrity: sha512-C3GYO0HLaOkk9dDAz3Dl4sbe4AKUGTCfFIZsz3n/82dPNN8Du533HzKatDxeUYWu24wJgMP1xICqkWk1YOLOIw==} dependencies: - '@types/react': 18.0.37 + '@types/react': 18.2.6 dev: true /@types/react-is@17.0.3: resolution: {integrity: sha512-aBTIWg1emtu95bLTLx0cpkxwGW3ueZv71nE2YFBpL8k/z5czEW8yYpOo8Dp+UUAFAtKwNaOsh/ioSeQnWlZcfw==} dependencies: - '@types/react': 18.0.37 + '@types/react': 18.2.6 dev: false /@types/react-test-renderer@17.0.2: @@ -8952,7 +8921,7 @@ packages: /@types/react-transition-group@4.4.5: resolution: {integrity: sha512-juKD/eiSM3/xZYzjuzH6ZwpP+/lejltmiS3QEzV/vmb/Q8+HfDmxu+Baga8UEMGBqV88Nbg4l2hY/K2DkyaLLA==} dependencies: - '@types/react': 18.0.37 + '@types/react': 18.2.6 dev: false /@types/react@17.0.49: @@ -8971,8 +8940,16 @@ packages: csstype: 3.1.0 dev: true - /@types/react@18.0.37: - resolution: {integrity: sha512-4yaZZtkRN3ZIQD3KSEwkfcik8s0SWV+82dlJot1AbGYHCzJkWP3ENBY6wYeDRmKZ6HkrgoGAmR2HqdwYGp6OEw==} + /@types/react@18.2.3: + resolution: {integrity: sha512-myU58XyFvSCcF9stRlhYnPbHZu9md7VZNsLukY6D68JHzIHLvqxvutD5luAJLnrUKMswvAgGwdSlEUKKSD+9Fw==} + dependencies: + '@types/prop-types': 15.7.5 + '@types/scheduler': 0.16.2 + csstype: 3.1.0 + dev: true + + /@types/react@18.2.6: + resolution: {integrity: sha512-wRZClXn//zxCFW+ye/D2qY65UsYP1Fpex2YXorHc8awoNamkMZSvBxwxdYVInsHOZZd2Ppq8isnSzJL5Mpf8OA==} dependencies: '@types/prop-types': 15.7.5 '@types/scheduler': 0.16.2 @@ -8981,7 +8958,7 @@ packages: /@types/resolve@1.17.1: resolution: {integrity: sha512-yy7HuzQhj0dhGpD8RLXSZWEkLsV9ibvxvi6EiJ3bkqLAO1RGo0WbkWQiwpRlSFymTJRz0d3k5LM3kkx8ArDbLw==} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.1.2 dev: true /@types/resolve@1.20.2: @@ -8998,7 +8975,7 @@ packages: /@types/set-cookie-parser@2.4.2: resolution: {integrity: sha512-fBZgytwhYAUkj/jC/FAV4RQ5EerRup1YQsXQCh8rZfiHkc4UahC192oH0smGwsXol3cL3A5oETuAHeQHmhXM4w==} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.1.2 dev: true /@types/sinonjs__fake-timers@8.1.1: @@ -9078,7 +9055,7 @@ packages: /@types/webpack-sources@3.2.0: resolution: {integrity: sha512-Ft7YH3lEVRQ6ls8k4Ff1oB4jN6oy/XmU6tQISKdhfh+1mR+viZFphS6WL0IrtDOzvefmJg5a0s7ZQoRXwqTEFg==} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.1.2 '@types/source-list-map': 0.1.2 source-map: 0.7.4 dev: true @@ -9086,7 +9063,7 @@ packages: /@types/webpack@4.41.32: resolution: {integrity: sha512-cb+0ioil/7oz5//7tZUSwbrSAN/NWHrQylz5cW8G0dWTcF/g+/dSdMlKVZspBYuMAN1+WnwHrkxiRrLcwd0Heg==} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.1.2 '@types/tapable': 1.0.8 '@types/uglify-js': 3.17.0 '@types/webpack-sources': 3.2.0 @@ -9101,7 +9078,7 @@ packages: /@types/ws@8.5.5: resolution: {integrity: sha512-lwhs8hktwxSjf9UaZ9tG5M03PGogvFaH8gUgLNbN9HKIg0dvv6q+gkSuJ8HN4/VbyxkuLzCjlN7GquQ0gUJfIg==} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.1.2 dev: true /@types/yargs-parser@21.0.0: @@ -9130,7 +9107,7 @@ packages: resolution: {integrity: sha512-Cn6WYCm0tXv8p6k+A8PvbDG763EDpBoTzHdA+Q/MF6H3sapGjCm9NzoaJncJS9tUKSuCoDs9XHxYYsQDgxR6kw==} requiresBuild: true dependencies: - '@types/node': 20.4.1 + '@types/node': 20.1.2 dev: true optional: true @@ -9547,8 +9524,8 @@ packages: - supports-color dev: true - /@vitejs/plugin-react@3.1.0(vite@4.2.1): - resolution: {integrity: sha512-AfgcRL8ZBhAlc3BFdigClmTUMISmmzHn7sB2h9U1odvc5U/MjWXsAaz18b/WoppUTDBzxOJwo2VdClfUcItu9g==} + /@vitejs/plugin-react@4.0.0(vite@4.2.1): + resolution: {integrity: sha512-HX0XzMjL3hhOYm+0s95pb0Z7F8O81G7joUHgfDd/9J/ZZf5k4xX6QAMFkKsHFxaHlf6X7GD7+XuaZ66ULiJuhQ==} engines: {node: ^14.18.0 || >=16.0.0} peerDependencies: vite: ^4.2.0 @@ -9557,7 +9534,7 @@ packages: '@babel/plugin-transform-react-jsx-self': 7.22.5(@babel/core@7.22.5) '@babel/plugin-transform-react-jsx-source': 7.22.5(@babel/core@7.22.5) react-refresh: 0.14.0 - vite: 4.3.9(@types/node@20.4.1) + vite: 4.2.1(@types/node@20.1.2) transitivePeerDependencies: - supports-color dev: true @@ -11367,10 +11344,6 @@ packages: /birpc@0.2.11: resolution: {integrity: sha512-OcUm84SBHRsmvSQhOLZRt5Awmw8WVknVcMDMaPE8GPwYxzc4mGE0EIytkWXayPjheGvm7s/Ci1wQZGwk7YPU6A==} - dev: true - - /birpc@0.2.3: - resolution: {integrity: sha512-mG7m06C2JkfuHSaLRHhtHtMEvyT1P1nUyyuk5W/7LMT2p7YYX/tfzJzD2ynZZHem3JTi6yJve0nHPdrs/gpXYg==} /bl@4.1.0: resolution: {integrity: sha512-1W07cM9gS6DcLperZfFSj+bWLtaPGSOHWhPiGzXmvVJbRLdG82sH/Kn8EtW1VqWVA54AKf2h5k5BbnIbwF3h6w==} @@ -12028,7 +12001,7 @@ packages: engines: {node: '>=12.13.0'} hasBin: true dependencies: - '@types/node': 20.4.1 + '@types/node': 20.1.2 escape-string-regexp: 4.0.0 is-wsl: 2.2.0 lighthouse-logger: 1.3.0 @@ -17304,7 +17277,7 @@ packages: '@jest/environment': 27.5.1 '@jest/test-result': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.1 + '@types/node': 20.1.2 chalk: 4.1.2 co: 4.6.0 dedent: 0.7.0 @@ -17440,7 +17413,7 @@ packages: '@jest/environment': 27.5.1 '@jest/fake-timers': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.1 + '@types/node': 20.1.2 jest-mock: 27.5.1 jest-util: 27.5.1 jsdom: 16.7.0 @@ -17458,7 +17431,7 @@ packages: '@jest/environment': 27.5.1 '@jest/fake-timers': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.1 + '@types/node': 20.1.2 jest-mock: 27.5.1 jest-util: 27.5.1 dev: true @@ -17479,7 +17452,7 @@ packages: dependencies: '@jest/types': 26.6.2 '@types/graceful-fs': 4.1.5 - '@types/node': 20.4.1 + '@types/node': 20.1.2 anymatch: 3.1.2 fb-watchman: 2.0.1 graceful-fs: 4.2.10 @@ -17502,7 +17475,7 @@ packages: dependencies: '@jest/types': 27.5.1 '@types/graceful-fs': 4.1.5 - '@types/node': 20.4.1 + '@types/node': 20.1.2 anymatch: 3.1.2 fb-watchman: 2.0.1 graceful-fs: 4.2.10 @@ -17542,7 +17515,7 @@ packages: '@jest/source-map': 27.5.1 '@jest/test-result': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.1 + '@types/node': 20.1.2 chalk: 4.1.2 co: 4.6.0 expect: 27.5.1 @@ -17622,7 +17595,7 @@ packages: engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: '@jest/types': 27.5.1 - '@types/node': 20.4.1 + '@types/node': 20.1.2 dev: true /jest-pnp-resolver@1.2.3(jest-resolve@27.5.1): @@ -17683,7 +17656,7 @@ packages: '@jest/test-result': 27.5.1 '@jest/transform': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.1 + '@types/node': 20.1.2 chalk: 4.1.2 emittery: 0.8.1 graceful-fs: 4.2.10 @@ -17740,7 +17713,7 @@ packages: resolution: {integrity: sha512-S5wqyz0DXnNJPd/xfIzZ5Xnp1HrJWBczg8mMfMpN78OJ5eDxXyf+Ygld9wX1DnUWbIbhM1YDY95NjR4CBXkb2g==} engines: {node: '>= 10.14.2'} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.1.2 graceful-fs: 4.2.10 dev: true @@ -17748,7 +17721,7 @@ packages: resolution: {integrity: sha512-jZCyo6iIxO1aqUxpuBlwTDMkzOAJS4a3eYz3YzgxxVQFwLeSA7Jfq5cbqCY+JLvTDrWirgusI/0KwxKMgrdf7w==} engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.1.2 graceful-fs: 4.2.10 dev: true @@ -17787,7 +17760,7 @@ packages: engines: {node: '>= 10.14.2'} dependencies: '@jest/types': 26.6.2 - '@types/node': 20.4.1 + '@types/node': 20.1.2 chalk: 4.1.2 graceful-fs: 4.2.10 is-ci: 2.0.0 @@ -17799,7 +17772,7 @@ packages: engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: '@jest/types': 27.5.1 - '@types/node': 20.4.1 + '@types/node': 20.1.2 chalk: 4.1.2 ci-info: 3.8.0 graceful-fs: 4.2.10 @@ -17811,7 +17784,7 @@ packages: engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: '@jest/types': 29.0.1 - '@types/node': 20.4.1 + '@types/node': 20.1.2 chalk: 4.1.2 ci-info: 3.7.0 graceful-fs: 4.2.10 @@ -17836,7 +17809,7 @@ packages: dependencies: '@jest/test-result': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.1 + '@types/node': 20.1.2 ansi-escapes: 4.3.2 chalk: 4.1.2 jest-util: 27.5.1 @@ -17847,7 +17820,7 @@ packages: resolution: {integrity: sha512-KWYVV1c4i+jbMpaBC+U++4Va0cp8OisU185o73T1vo99hqi7w8tSJfUXYswwqqrjzwxa6KpRK54WhPvwf5w6PQ==} engines: {node: '>= 10.13.0'} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.1.2 merge-stream: 2.0.0 supports-color: 7.2.0 dev: true @@ -17856,7 +17829,7 @@ packages: resolution: {integrity: sha512-7vuh85V5cdDofPyxn58nrPjBktZo0u9x1g8WtjQol+jZDaE+fhN+cIvTj11GndBnMnyfrUOG1sZQxCdjKh+DKg==} engines: {node: '>= 10.13.0'} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.1.2 merge-stream: 2.0.0 supports-color: 8.1.1 dev: true @@ -19314,7 +19287,7 @@ packages: - supports-color dev: true - /msw@1.2.1(typescript@5.0.3): + /msw@1.2.1(typescript@5.0.4): resolution: {integrity: sha512-bF7qWJQSmKn6bwGYVPXOxhexTCGD5oJSZg8yt8IBClxvo3Dx/1W0zqE1nX9BSWmzRsCKWfeGWcB/vpqV6aclpw==} engines: {node: '>=14'} hasBin: true @@ -19343,7 +19316,7 @@ packages: path-to-regexp: 6.2.1 strict-event-emitter: 0.4.6 type-fest: 2.19.0 - typescript: 5.0.3 + typescript: 5.0.4 yargs: 17.7.1 transitivePeerDependencies: - encoding @@ -24088,7 +24061,7 @@ packages: magic-string: 0.27.0 mlly: 1.2.0 pathe: 1.1.0 - pkg-types: 1.0.2 + pkg-types: 1.0.3 scule: 1.0.0 strip-literal: 1.0.1 unplugin: 1.3.1 @@ -24782,8 +24755,8 @@ packages: fsevents: 2.3.2 dev: false - /vite@4.3.9(@types/node@20.4.1): - resolution: {integrity: sha512-qsTNZjO9NoJNW7KnOrgYwczm0WctJ8m/yqYAMAK9Lxt4SoySUfS5S8ia9K7JHpa3KEeMfyF8LoJ3c5NeBJy6pg==} + /vite@4.2.1(@types/node@20.1.2): + resolution: {integrity: sha512-7MKhqdy0ISo4wnvwtqZkjke6XN4taqQ2TBaTccLIpOKv7Vp2h4Y+NpmWCnGDeSvvn45KxvWgGyb0MkHvY1vgbg==} engines: {node: ^14.18.0 || >=16.0.0} hasBin: true peerDependencies: @@ -24807,15 +24780,16 @@ packages: terser: optional: true dependencies: - '@types/node': 20.4.1 - esbuild: 0.17.18 - postcss: 8.4.24 - rollup: 3.23.0 + '@types/node': 20.1.2 + esbuild: 0.17.15 + postcss: 8.4.21 + resolve: 1.22.1 + rollup: 3.20.2 optionalDependencies: fsevents: 2.3.2 dev: true - /vitefu@0.2.3(vite@4.3.9): + /vitefu@0.2.3(vite@4.2.1): resolution: {integrity: sha512-75l7TTuU8isAhz1QFtNKjDkqjxvndfMC1AfIMjJ0ZQ59ZD0Ow9QOIsJJX16Wv9PS8f+zMzp6fHy5cCbKG/yVUQ==} peerDependencies: vite: ^3.0.0 || ^4.0.0 From 8264ec6df03c493dfcf30f1279f4b9338251bac6 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Wed, 10 May 2023 17:00:18 +0200 Subject: [PATCH 24/87] chore: cleanup --- examples/mocks/vite.config.ts | 2 +- packages/vitest/src/runtime/entry-vm.ts | 12 +++++++----- packages/vitest/src/runtime/entry.ts | 2 +- packages/vitest/src/runtime/setup.node.ts | 18 ++++++++++-------- packages/vitest/src/runtime/vm.ts | 13 ++++++++++++- 5 files changed, 31 insertions(+), 16 deletions(-) diff --git a/examples/mocks/vite.config.ts b/examples/mocks/vite.config.ts index 320448de2c5e..6afaf98f75ff 100644 --- a/examples/mocks/vite.config.ts +++ b/examples/mocks/vite.config.ts @@ -30,7 +30,7 @@ export default defineConfig({ globals: true, environment: 'node', poolMatchGlobs: [ - ['**/*', 'vm'], + ['**/*', 'experimentalVmThreads'], ], deps: { external: [/src\/external/], diff --git a/packages/vitest/src/runtime/entry-vm.ts b/packages/vitest/src/runtime/entry-vm.ts index 19fbdaf195f4..33ae921c6426 100644 --- a/packages/vitest/src/runtime/entry-vm.ts +++ b/packages/vitest/src/runtime/entry-vm.ts @@ -20,11 +20,13 @@ export async function run(files: string[], config: ResolvedConfig, executor: Vit setupColors(createColors(isatty(1))) - const _require = createRequire(import.meta.url) - // always mock "required" `css` files, because we cannot process them - _require.extensions['.css'] = () => ({}) - _require.extensions['.scss'] = () => ({}) - _require.extensions['.sass'] = () => ({}) + if (workerState.environment !== 'node') { + const _require = createRequire(import.meta.url) + // always mock "required" `css` files, because we cannot process them + _require.extensions['.css'] = () => ({}) + _require.extensions['.scss'] = () => ({}) + _require.extensions['.sass'] = () => ({}) + } await startCoverageInsideWorker(config.coverage, executor) diff --git a/packages/vitest/src/runtime/entry.ts b/packages/vitest/src/runtime/entry.ts index 6ee9b78edaa2..fdd8d61df173 100644 --- a/packages/vitest/src/runtime/entry.ts +++ b/packages/vitest/src/runtime/entry.ts @@ -13,7 +13,7 @@ import { resolveTestRunner } from './runners' export async function run(files: string[], config: ResolvedConfig, environment: ResolvedTestEnvironment, executor: VitestExecutor): Promise { const workerState = getWorkerState() - await setupGlobalEnv(config) + await setupGlobalEnv(config, environment) await startCoverageInsideWorker(config.coverage, executor) if (config.chaiConfig) diff --git a/packages/vitest/src/runtime/setup.node.ts b/packages/vitest/src/runtime/setup.node.ts index 26a23dbd7a49..9675adbafbcd 100644 --- a/packages/vitest/src/runtime/setup.node.ts +++ b/packages/vitest/src/runtime/setup.node.ts @@ -2,7 +2,7 @@ import { createRequire } from 'node:module' import { isatty } from 'node:tty' import { installSourcemapsSupport } from 'vite-node/source-map' import { createColors, setupColors } from '@vitest/utils' -import type { EnvironmentOptions, ResolvedConfig, ResolvedTestEnvironment, WorkerGlobalState } from '../types' +import type { ContextTestEnvironment, EnvironmentOptions, ResolvedConfig, ResolvedTestEnvironment, WorkerGlobalState } from '../types' import { VitestSnapshotEnvironment } from '../integrations/snapshot/environments/node' import { getSafeTimers, getWorkerState } from '../utils' import * as VitestIndex from '../index' @@ -11,7 +11,7 @@ import { setupCommonEnv } from './setup.common' // this should only be used in Node let globalSetup = false -export async function setupGlobalEnv(config: ResolvedConfig) { +export async function setupGlobalEnv(config: ResolvedConfig, environment: ContextTestEnvironment) { await setupCommonEnv(config) Object.defineProperty(globalThis, '__vitest_index__', { @@ -30,12 +30,14 @@ export async function setupGlobalEnv(config: ResolvedConfig) { globalSetup = true setupColors(createColors(isatty(1))) - const _require = createRequire(import.meta.url) - // always mock "required" `css` files, because we cannot process them - _require.extensions['.css'] = () => ({}) - _require.extensions['.scss'] = () => ({}) - _require.extensions['.sass'] = () => ({}) - _require.extensions['.less'] = () => ({}) + if (environment.name !== 'node') { + const _require = createRequire(import.meta.url) + // always mock "required" `css` files, because we cannot process them + _require.extensions['.css'] = () => ({}) + _require.extensions['.scss'] = () => ({}) + _require.extensions['.sass'] = () => ({}) + _require.extensions['.less'] = () => ({}) + } installSourcemapsSupport({ getSourceMap: source => state.moduleCache.getSourceMap(source), diff --git a/packages/vitest/src/runtime/vm.ts b/packages/vitest/src/runtime/vm.ts index 5e188a6a90de..f4353900a8a0 100644 --- a/packages/vitest/src/runtime/vm.ts +++ b/packages/vitest/src/runtime/vm.ts @@ -4,6 +4,7 @@ import { workerId as poolId } from 'tinypool' import { createBirpc } from 'birpc' import { resolve } from 'pathe' import { installSourcemapsSupport } from 'vite-node/source-map' +import type { CancelReason } from '@vitest/runner' import type { RuntimeRPC, WorkerContext, WorkerGlobalState } from '../types' import { distDir } from '../paths' import { startVitestExecutor } from './execute' @@ -16,19 +17,29 @@ export async function run(ctx: WorkerContext) { const moduleCache = new ModuleCacheMap() const mockMap = new Map() const { config, port } = ctx + + let setCancel = (_reason: CancelReason) => {} + const onCancel = new Promise((resolve) => { + setCancel = resolve + }) + const rpc = createBirpc( - {}, + { + onCancel: setCancel, + }, { eventNames: ['onUserConsoleLog', 'onFinished', 'onCollected', 'onWorkerExit'], post(v) { port.postMessage(v) }, on(fn) { port.addListener('message', fn) }, }, ) + const state: WorkerGlobalState = { ctx, moduleCache, config, mockMap, + onCancel, environment: ctx.environment.name, durations: { environment: performance.now(), From 57a25b1766e1af0875965f2cd358fcbbf0c21116 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Wed, 10 May 2023 17:01:32 +0200 Subject: [PATCH 25/87] chore: process unknown vm pools --- packages/vitest/src/node/pool.ts | 2 ++ 1 file changed, 2 insertions(+) diff --git a/packages/vitest/src/node/pool.ts b/packages/vitest/src/node/pool.ts index 3b6ecc0cfaf6..329f16888309 100644 --- a/packages/vitest/src/node/pool.ts +++ b/packages/vitest/src/node/pool.ts @@ -96,6 +96,8 @@ export function createPool(ctx: Vitest): ProcessPool { for (const spec of files) { const pool = getPoolName(spec) + if (!(pool in filesByPool)) + throw new Error(`Unknown pool name "${pool}" for ${spec[1]}. Available pools: ${Object.keys(filesByPool).join(', ')}`) filesByPool[pool].push(spec) } From beeb8544b2a4e223a260cbe374115674e420492b Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Wed, 10 May 2023 18:25:08 +0200 Subject: [PATCH 26/87] chore: add experimentalVmWorkerMemoryLimit option --- packages/runner/src/types/runner.ts | 2 +- packages/vitest/src/node/cli.ts | 1 + packages/vitest/src/node/config.ts | 8 +- packages/vitest/src/node/pools/child.ts | 2 + packages/vitest/src/node/pools/vm-threads.ts | 16 +++- packages/vitest/src/types/config.ts | 12 ++- packages/vitest/src/utils/memory-limit.ts | 94 ++++++++++++++++++++ test/core/test/require.test.ts | 2 + test/core/vitest.config.ts | 1 + 9 files changed, 133 insertions(+), 5 deletions(-) create mode 100644 packages/vitest/src/utils/memory-limit.ts diff --git a/packages/runner/src/types/runner.ts b/packages/runner/src/types/runner.ts index eb1ee9edb24e..eda11ef84d14 100644 --- a/packages/runner/src/types/runner.ts +++ b/packages/runner/src/types/runner.ts @@ -29,7 +29,7 @@ export interface VitestRunnerConstructor { new(config: VitestRunnerConfig): VitestRunner } -export type CancelReason = 'keyboard-input' | 'test-failure' | string & {} +export type CancelReason = 'keyboard-input' | 'test-failure' | 'memory-limit' | string & {} export interface VitestRunner { /** diff --git a/packages/vitest/src/node/cli.ts b/packages/vitest/src/node/cli.ts index 722db4b83ab4..b159c8b76d5d 100644 --- a/packages/vitest/src/node/cli.ts +++ b/packages/vitest/src/node/cli.ts @@ -24,6 +24,7 @@ cli .option('--threads', 'Enabled threads (default: true)') .option('--single-thread', 'Run tests inside a single thread, requires --threads (default: false)') .option('--experimental-vm-threads', 'Run tests in a worker pool using VM isolation (default: false)') + .option('--experimental-vm-worker-memory-limit', 'Set maximum allowed memory for a worker. When reached, new worker will be created instead') .option('--silent', 'Silent console output from tests') .option('--hideSkippedTests', 'Hide logs for skipped tests') .option('--isolate', 'Isolate environment for each test file (default: true)') diff --git a/packages/vitest/src/node/config.ts b/packages/vitest/src/node/config.ts index 50ea5fd85c31..169c1f36a8e0 100644 --- a/packages/vitest/src/node/config.ts +++ b/packages/vitest/src/node/config.ts @@ -1,12 +1,13 @@ +import { totalmem } from 'node:os' import { resolveModule } from 'local-pkg' import { normalize, relative, resolve } from 'pathe' import c from 'picocolors' import type { ResolvedConfig as ResolvedViteConfig } from 'vite' - import type { ApiConfig, ResolvedConfig, UserConfig, VitestRunMode } from '../types' import { defaultBrowserPort, defaultPort } from '../constants' import { benchmarkConfigDefaults, configDefaults } from '../defaults' import { isCI, toArray } from '../utils' +import { getWorkerMemoryLimit, stringToBytes } from '../utils/memory-limit' import { VitestCache } from './cache' import { BaseSequencer } from './sequencers/BaseSequencer' import { RandomSequencer } from './sequencers/RandomSequencer' @@ -206,6 +207,11 @@ export function resolveConfig( snapshotEnvironment: null as any, } + resolved.experimentalVmWorkerMemoryLimit = stringToBytes( + getWorkerMemoryLimit(resolved), + totalmem(), + ) + if (options.resolveSnapshotPath) delete (resolved as UserConfig).resolveSnapshotPath diff --git a/packages/vitest/src/node/pools/child.ts b/packages/vitest/src/node/pools/child.ts index 8ba9fe620c67..a22e91fb3c12 100644 --- a/packages/vitest/src/node/pools/child.ts +++ b/packages/vitest/src/node/pools/child.ts @@ -72,6 +72,8 @@ export function createChildProcessPool(ctx: Vitest, { execArgv, env }: PoolProce const child = fork(childPath, [], { execArgv, env, + // TODO: investigate + // serialization: 'advanced', }) children.add(child) setupChildProcessChannel(project, child) diff --git a/packages/vitest/src/node/pools/vm-threads.ts b/packages/vitest/src/node/pools/vm-threads.ts index ee4a21a95d42..317d7420566e 100644 --- a/packages/vitest/src/node/pools/vm-threads.ts +++ b/packages/vitest/src/node/pools/vm-threads.ts @@ -6,7 +6,7 @@ import { resolve } from 'pathe' import type { Options as TinypoolOptions } from 'tinypool' import Tinypool from 'tinypool' import { distDir, rootDir } from '../../paths' -import type { ContextTestEnvironment, ResolvedConfig, RuntimeRPC, Vitest, WorkerContext } from '../../types' +import type { ContextTestEnvironment, ResolvedConfig, RunnerRPC, RuntimeRPC, Vitest, WorkerContext } from '../../types' import type { PoolProcessOptions, ProcessPool, RunWithFiles } from '../pool' import { groupFilesByEnv } from '../../utils/test-helpers' import { AggregateError } from '../../utils/base' @@ -21,9 +21,10 @@ function createWorkerChannel(project: WorkspaceProject) { const port = channel.port2 const workerPort = channel.port1 - createBirpc<{}, RuntimeRPC>( + const rpc = createBirpc( createMethodsRPC(project), { + eventNames: ['onCancel'], post(v) { port.postMessage(v) }, @@ -33,6 +34,8 @@ function createWorkerChannel(project: WorkspaceProject) { }, ) + project.ctx.onCancel(reason => rpc.onCancel(reason)) + return { workerPort, port } } @@ -62,6 +65,10 @@ export function createVmThreadsPool(ctx: Vitest, { execArgv, env }: PoolProcessO ], terminateTimeout: ctx.config.teardownTimeout, + + resourceLimits: { + maxOldGenerationSizeMb: 10, + }, } if (ctx.config.singleThread) { @@ -94,6 +101,11 @@ export function createVmThreadsPool(ctx: Vitest, { execArgv, env }: PoolProcessO // Worker got stuck and won't terminate - this may cause process to hang if (error instanceof Error && /Failed to terminate worker/.test(error.message)) ctx.state.addProcessTimeoutCause(`Failed to terminate worker while running ${files.join(', ')}.`) + + // Intentionally cancelled + else if (ctx.isCancelling && error instanceof Error && /The task has been cancelled/.test(error.message)) + ctx.state.cancelFiles(files, ctx.config.root) + else throw error } diff --git a/packages/vitest/src/types/config.ts b/packages/vitest/src/types/config.ts index af9c3b766be3..c4406085adce 100644 --- a/packages/vitest/src/types/config.ts +++ b/packages/vitest/src/types/config.ts @@ -308,6 +308,14 @@ export interface InlineConfig { */ experimentalVmThreads?: boolean + /** + * Specifies the memory limit for workers before they are recycled. + * If you see your worker leaking memory, try to tinker this value. + * + * This only has effect on workers that run tests in VM context. + */ + experimentalVmWorkerMemoryLimit?: string | number + // TODO: document that "--no-isolate" has no effect on experimentalVmThreads // TODO: workerIdleMemoryLimit for experimentalVmThreads, so they don't leak @@ -703,7 +711,7 @@ export interface UserConfig extends InlineConfig { shard?: string } -export interface ResolvedConfig extends Omit, 'config' | 'filters' | 'browser' | 'coverage' | 'testNamePattern' | 'related' | 'api' | 'reporters' | 'resolveSnapshotPath' | 'benchmark' | 'shard' | 'cache' | 'sequence' | 'typecheck' | 'runner'> { +export interface ResolvedConfig extends Omit, 'config' | 'filters' | 'browser' | 'coverage' | 'testNamePattern' | 'related' | 'api' | 'reporters' | 'resolveSnapshotPath' | 'benchmark' | 'shard' | 'cache' | 'sequence' | 'typecheck' | 'runner' | 'experimentalVmWorkerMemoryLimit'> { mode: VitestRunMode base?: string @@ -748,6 +756,8 @@ export interface ResolvedConfig extends Omit, 'config' | 'f typecheck: TypecheckConfig runner?: string + + experimentalVmWorkerMemoryLimit?: number | null } export type ProjectConfig = Omit< diff --git a/packages/vitest/src/utils/memory-limit.ts b/packages/vitest/src/utils/memory-limit.ts new file mode 100644 index 000000000000..9b428463bca1 --- /dev/null +++ b/packages/vitest/src/utils/memory-limit.ts @@ -0,0 +1,94 @@ +/** + * Copyright (c) Meta Platforms, Inc. and affiliates. + * + * This source code is licensed under the MIT license found in the + * LICENSE file in the root directory of facebook/jest GitHub project tree. + */ + +import { cpus } from 'node:os' +import type { ResolvedConfig } from '../types' + +function getDefaultThreadsCount(config: ResolvedConfig) { + return config.watch + ? Math.max(Math.floor(cpus().length / 2), 1) + : Math.max(cpus().length - 1, 1) +} + +export function getWorkerMemoryLimit(config: ResolvedConfig) { + if (config.experimentalVmWorkerMemoryLimit) + return config.experimentalVmWorkerMemoryLimit + return 1 / (config.maxThreads ?? getDefaultThreadsCount(config)) +} + +/** + * Converts a string representing an amount of memory to bytes. + * + * @param input The value to convert to bytes. + * @param percentageReference The reference value to use when a '%' value is supplied. + */ +export function stringToBytes( + input: string | number | null | undefined, + percentageReference?: number, +): number | null | undefined { + if (input === null || input === undefined) + return input + + if (typeof input === 'string') { + if (isNaN(Number.parseFloat(input.slice(-1)))) { + let [, numericString, trailingChars] + = input.match(/(.*?)([^0-9.-]+)$/i) || [] + + if (trailingChars && numericString) { + const numericValue = Number.parseFloat(numericString) + trailingChars = trailingChars.toLowerCase() + + switch (trailingChars) { + case '%': + input = numericValue / 100 + break + case 'kb': + case 'k': + return numericValue * 1000 + case 'kib': + return numericValue * 1024 + case 'mb': + case 'm': + return numericValue * 1000 * 1000 + case 'mib': + return numericValue * 1024 * 1024 + case 'gb': + case 'g': + return numericValue * 1000 * 1000 * 1000 + case 'gib': + return numericValue * 1024 * 1024 * 1024 + } + } + + // It ends in some kind of char so we need to do some parsing + } + else { + input = Number.parseFloat(input) + } + } + + if (typeof input === 'number') { + if (input <= 1 && input > 0) { + if (percentageReference) { + return Math.floor(input * percentageReference) + } + else { + throw new Error( + 'For a percentage based memory limit a percentageReference must be supplied', + ) + } + } + else if (input > 1) { + return Math.floor(input) + } + else { + throw new Error('Unexpected numerical input for "experimentalVmWorkerMemoryLimit"') + } + } + + return null +} diff --git a/test/core/test/require.test.ts b/test/core/test/require.test.ts index ba06ddc9cf5e..4d66074db582 100644 --- a/test/core/test/require.test.ts +++ b/test/core/test/require.test.ts @@ -1,3 +1,5 @@ +// @vitest-environment jsdom + import { describe, expect, it } from 'vitest' const _require = require diff --git a/test/core/vitest.config.ts b/test/core/vitest.config.ts index 5051031ceadf..50dde42c3112 100644 --- a/test/core/vitest.config.ts +++ b/test/core/vitest.config.ts @@ -49,6 +49,7 @@ export default defineConfig({ setupFiles: [ './test/setup.ts', ], + // TODO: remove this when PR is done poolMatchGlobs: [ ['**/*', 'experimentalVmThreads'], ], From 8e9088544041541f57b6df21f29e4398f22cc74a Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Thu, 11 May 2023 18:36:56 +0200 Subject: [PATCH 27/87] chore: remove debug --- packages/vitest/src/node/pools/vm-threads.ts | 4 ---- 1 file changed, 4 deletions(-) diff --git a/packages/vitest/src/node/pools/vm-threads.ts b/packages/vitest/src/node/pools/vm-threads.ts index 317d7420566e..bb5d0be70092 100644 --- a/packages/vitest/src/node/pools/vm-threads.ts +++ b/packages/vitest/src/node/pools/vm-threads.ts @@ -65,10 +65,6 @@ export function createVmThreadsPool(ctx: Vitest, { execArgv, env }: PoolProcessO ], terminateTimeout: ctx.config.teardownTimeout, - - resourceLimits: { - maxOldGenerationSizeMb: 10, - }, } if (ctx.config.singleThread) { From 638689189d8e98aecfeeffd92ac6d7a84f56a456 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Thu, 11 May 2023 19:18:54 +0200 Subject: [PATCH 28/87] chore: copy jest's node env --- .../vitest/src/integrations/env/happy-dom.ts | 3 - packages/vitest/src/integrations/env/node.ts | 105 ++++++++++++++++-- packages/vitest/src/runtime/vm.ts | 15 +-- packages/vitest/src/types/general.ts | 2 +- 4 files changed, 103 insertions(+), 22 deletions(-) diff --git a/packages/vitest/src/integrations/env/happy-dom.ts b/packages/vitest/src/integrations/env/happy-dom.ts index 5e05d0e527bf..cb05c9824b1f 100644 --- a/packages/vitest/src/integrations/env/happy-dom.ts +++ b/packages/vitest/src/integrations/env/happy-dom.ts @@ -16,9 +16,6 @@ export default ({ }) return { - getGlobal() { - return win.globalThis - }, getVmContext() { return win }, diff --git a/packages/vitest/src/integrations/env/node.ts b/packages/vitest/src/integrations/env/node.ts index 26df78a699ee..bb15a319707b 100644 --- a/packages/vitest/src/integrations/env/node.ts +++ b/packages/vitest/src/integrations/env/node.ts @@ -1,18 +1,109 @@ import { Console } from 'node:console' -import { importModule } from 'local-pkg' import type { Environment } from '../../types' +// some globals we do not want, either because deprecated or we set it ourselves +const denyList = new Set([ + 'GLOBAL', + 'root', + 'global', + 'Buffer', + 'ArrayBuffer', + 'Uint8Array', +]) + +const nodeGlobals = new Map( + Object.getOwnPropertyNames(globalThis) + .filter(global => !denyList.has(global)) + .map((nodeGlobalsKey) => { + const descriptor = Object.getOwnPropertyDescriptor( + globalThis, + nodeGlobalsKey, + ) + + if (!descriptor) { + throw new Error( + `No property descriptor for ${nodeGlobalsKey}, this is a bug in Jest.`, + ) + } + + return [nodeGlobalsKey, descriptor] + }), +) + export default ({ name: 'node', transformMode: 'ssr', - async setupVm() { - const vm = await importModule('node:vm') - const global = {} // TODO: copy more globals + // this is largely copied from jest's node environment + async setupVM() { + const vm = await import('node:vm') const context = vm.createContext() + const global = vm.runInContext( + 'this', + context, + ) + + const contextGlobals = new Set(Object.getOwnPropertyNames(global)) + for (const [nodeGlobalsKey, descriptor] of nodeGlobals) { + if (!contextGlobals.has(nodeGlobalsKey)) { + if (descriptor.configurable) { + Object.defineProperty(global, nodeGlobalsKey, { + configurable: true, + enumerable: descriptor.enumerable, + get() { + // @ts-expect-error: no index signature + const val = globalThis[nodeGlobalsKey] as unknown + + // override lazy getter + Object.defineProperty(global, nodeGlobalsKey, { + configurable: true, + enumerable: descriptor.enumerable, + value: val, + writable: + descriptor.writable === true + // Node 19 makes performance non-readable. This is probably not the correct solution. + || nodeGlobalsKey === 'performance', + }) + return val + }, + set(val: unknown) { + // override lazy getter + Object.defineProperty(global, nodeGlobalsKey, { + configurable: true, + enumerable: descriptor.enumerable, + value: val, + writable: true, + }) + }, + }) + } + else if ('value' in descriptor) { + Object.defineProperty(global, nodeGlobalsKey, { + configurable: false, + enumerable: descriptor.enumerable, + value: descriptor.value, + writable: descriptor.writable, + }) + } + else { + Object.defineProperty(global, nodeGlobalsKey, { + configurable: false, + enumerable: descriptor.enumerable, + get: descriptor.get, + set: descriptor.set, + }) + } + } + } + + global.global = global + global.Buffer = Buffer + global.ArrayBuffer = ArrayBuffer + // TextEncoder (global or via 'util') references a Uint8Array constructor + // different than the global one used by users in tests. This makes sure the + // same constructor is referenced by both. + global.Uint8Array = Uint8Array + return { - getGlobal() { - return global - }, getVmContext() { return context }, diff --git a/packages/vitest/src/runtime/vm.ts b/packages/vitest/src/runtime/vm.ts index f4353900a8a0..54861efbb09a 100644 --- a/packages/vitest/src/runtime/vm.ts +++ b/packages/vitest/src/runtime/vm.ts @@ -1,4 +1,5 @@ -import { URL, pathToFileURL } from 'node:url' +import { pathToFileURL } from 'node:url' +import { performance } from 'node:perf_hooks' import { ModuleCacheMap } from 'vite-node/client' import { workerId as poolId } from 'tinypool' import { createBirpc } from 'birpc' @@ -64,17 +65,9 @@ export async function run(ctx: WorkerContext) { const context = vm.getVmContext() context.__vitest_worker__ = state - // TODO: all globals for test/core to work - // TODO: copy more globals + // this is unfortunately needed for our own dependencies + // we need to find a way to not rely on this by default context.process = process - context.URL ??= URL - context.performance ??= performance - context.setImmediate = setImmediate - context.clearImmediate = clearImmediate - context.setTimeout = setTimeout - context.clearTimeout = clearTimeout - context.setInterval = setInterval - context.clearInterval = clearInterval context.global = context context.console = createCustomConsole(state) diff --git a/packages/vitest/src/types/general.ts b/packages/vitest/src/types/general.ts index 18c1eb205788..9ef0fe7881d5 100644 --- a/packages/vitest/src/types/general.ts +++ b/packages/vitest/src/types/general.ts @@ -20,7 +20,7 @@ export interface ModuleCache { } export interface EnvironmentReturn { - teardown: (global: any) => Awaitable + teardown(global: any): Awaitable } export interface VmEnvironmentReturn { From ef98c9932901c6c20a828079e5d3f3cee971bf55 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Thu, 11 May 2023 19:44:09 +0200 Subject: [PATCH 29/87] chore: cleanup --- packages/vitest/src/runtime/environment.ts | 8 +++++++- packages/vitest/src/runtime/vm.ts | 4 +++- 2 files changed, 10 insertions(+), 2 deletions(-) diff --git a/packages/vitest/src/runtime/environment.ts b/packages/vitest/src/runtime/environment.ts index f5aa85acc363..06b5e66cc289 100644 --- a/packages/vitest/src/runtime/environment.ts +++ b/packages/vitest/src/runtime/environment.ts @@ -5,11 +5,17 @@ export async function loadEnvironment(name: string, method: 'setup' | 'setupVM') if (name in environments) return environments[name as 'jsdom'] const pkg = await import(`vitest-environment-${name}`) - if (!pkg || !pkg.default || typeof pkg.default !== 'object' || typeof pkg.default[method] !== 'function') { + if (!pkg || !pkg.default || typeof pkg.default !== 'object') { throw new Error( `Environment "${name}" is not a valid environment. ` + `Package "vitest-environment-${name}" should have default export with "${method}" method.`, ) } + if (typeof pkg.default[method] !== 'function') { + throw new TypeError( + `Environment "${name}" is not a valid environment. ` + + `Package "vitest-environment-${name}" doesn't support ${method === 'setupVM' ? 'vm' : 'non-vm'} environment because it doesn't provide "${method}" method.`, + ) + } return pkg.default } diff --git a/packages/vitest/src/runtime/vm.ts b/packages/vitest/src/runtime/vm.ts index 54861efbb09a..829ba132c2c3 100644 --- a/packages/vitest/src/runtime/vm.ts +++ b/packages/vitest/src/runtime/vm.ts @@ -11,6 +11,7 @@ import { distDir } from '../paths' import { startVitestExecutor } from './execute' import { createCustomConsole } from './console' import { loadEnvironment } from './environment' +import { createSafeRpc } from './rpc' const entryFile = pathToFileURL(resolve(distDir, 'entry-vm.js')).href @@ -46,7 +47,7 @@ export async function run(ctx: WorkerContext) { environment: performance.now(), prepare: performance.now(), }, - rpc, + rpc: createSafeRpc(rpc), } installSourcemapsSupport({ @@ -67,6 +68,7 @@ export async function run(ctx: WorkerContext) { context.__vitest_worker__ = state // this is unfortunately needed for our own dependencies // we need to find a way to not rely on this by default + // because browser doesn't provide these globals context.process = process context.global = context context.console = createCustomConsole(state) From d0980d8429ff32942a2152b5248e2936357b3c63 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Mon, 19 Jun 2023 10:33:28 +0200 Subject: [PATCH 30/87] chore: cleanup --- packages/vitest/src/runtime/mocker.ts | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/packages/vitest/src/runtime/mocker.ts b/packages/vitest/src/runtime/mocker.ts index 7aa34a8f67e2..612747ccad38 100644 --- a/packages/vitest/src/runtime/mocker.ts +++ b/packages/vitest/src/runtime/mocker.ts @@ -42,7 +42,7 @@ function isSpecialProp(prop: Key, parentType: string) { } export class VitestMocker { - private static pendingIds: PendingSuiteMock[] = [] + static pendingIds: PendingSuiteMock[] = [] private spyModule?: typeof import('@vitest/spy') private resolveCache = new Map>() From 40966463d2cc39287dbfe35c1591e5db44014420 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Mon, 19 Jun 2023 11:21:40 +0200 Subject: [PATCH 31/87] chore: add support for require.extensions --- packages/vitest/src/runtime/entry-vm.ts | 3 + .../vitest/src/runtime/external-executor.ts | 88 +++--- pnpm-lock.yaml | 272 +++++++++--------- 3 files changed, 185 insertions(+), 178 deletions(-) diff --git a/packages/vitest/src/runtime/entry-vm.ts b/packages/vitest/src/runtime/entry-vm.ts index 33ae921c6426..d0e0981e5ce2 100644 --- a/packages/vitest/src/runtime/entry-vm.ts +++ b/packages/vitest/src/runtime/entry-vm.ts @@ -1,5 +1,6 @@ import { isatty } from 'node:tty' import { createRequire } from 'node:module' +import { performance } from 'node:perf_hooks' import { startTests } from '@vitest/runner' import { createColors, setupColors } from '@vitest/utils' import { setupChaiConfig } from '../integrations/chai/config' @@ -20,12 +21,14 @@ export async function run(files: string[], config: ResolvedConfig, executor: Vit setupColors(createColors(isatty(1))) + // TODO: look at environment.transformMode when #3491 is merged if (workerState.environment !== 'node') { const _require = createRequire(import.meta.url) // always mock "required" `css` files, because we cannot process them _require.extensions['.css'] = () => ({}) _require.extensions['.scss'] = () => ({}) _require.extensions['.sass'] = () => ({}) + _require.extensions['.less'] = () => ({}) } await startCoverageInsideWorker(config.coverage, executor) diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index 63a5580fcbbb..ffcb2de25e8f 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -85,11 +85,13 @@ const SourceTextModule: typeof VMSourceTextModule = (vm as any).SourceTextModule const _require = createRequire(import.meta.url) +// TODO: improve Node.js strict mode support in #2854 export class ExternalModulesExecutor { private context: vm.Context private requireCache = _require.cache private moduleCache = new Map() + private extensions: Record string> = Object.create(null) private esmLinkMap = new WeakMap>() @@ -97,6 +99,18 @@ export class ExternalModulesExecutor { this.context = context for (const file in this.requireCache) delete this.requireCache[file] + + this.extensions['.js'] = this.requireJs + this.extensions['.json'] = this.requireJson + } + + private requireJs = (m: NodeModule, filename: string) => { + return readFileSync(filename, 'utf-8') + } + + private requireJson = (m: NodeModule, filename: string) => { + const code = readFileSync(filename, 'utf-8') + return `module.exports = ${code}` } importModuleDynamically = async (specifier: string, referencer: VMModule) => { @@ -149,20 +163,29 @@ export class ExternalModulesExecutor { return m } - private createCommonJSNodeModule(filename: string) { + private createRequire = (filename: string) => { const _require = createRequire(filename) - // TODO: doesn't respect "extensions" - const require: NodeRequire = (id: string) => { + const require = ((id: string) => { const filename = _require.resolve(id) - if (isNodeBuiltin(filename)) + const ext = extname(filename) + if (ext === '.node' || isNodeBuiltin(filename)) return _require(filename) - const code = readFileSync(filename, 'utf-8') - return this.evaluateCommonJSModule(filename, code) - } + const module = this.createCommonJSNodeModule(filename) + return this.evaluateCommonJSModule(module, filename) + }) as NodeRequire require.resolve = _require.resolve - require.extensions = _require.extensions + Object.defineProperty(require, 'extensions', { + get: () => this.extensions, + writable: true, + configurable: true, + }) require.main = _require.main require.cache = this.requireCache + return require + } + + private createCommonJSNodeModule(filename: string) { + const require = this.createRequire(filename) const __dirname = dirname(filename) // dirty non-spec implementation - doesn't support children, parent, etc const module: NodeModule = { @@ -177,37 +200,21 @@ export class ExternalModulesExecutor { path: __dirname, paths: [], } - return module - } - - private evaluateJsonCommonJSModule(filename: string, code: string): Record { - const module = this.createCommonJSNodeModule(filename) this.requireCache[filename] = module - module.exports = JSON.parse(code) - module.loaded = true - return module.exports - } - - private evaluateCssCommonJSModule(filename: string): Record { - const module = this.createCommonJSNodeModule(filename) - this.requireCache[filename] = module - module.loaded = true - return module.exports + return module } // very naive implementation for Node.js require - private evaluateCommonJSModule(filename: string, code: string): Record { + private evaluateCommonJSModule(module: NodeModule, filename: string): Record { const cached = this.requireCache[filename] if (cached) return cached.exports const extension = extname(filename) + const loader = this.extensions[extension] || this.extensions['.js'] + const result = loader(module, filename) - if (extension === '.json') - return this.evaluateJsonCommonJSModule(filename, code) - // TODO: should respect "extensions" - if (extension === '.css' || extension === '.scss' || extension === '.sass') - return this.evaluateCssCommonJSModule(filename) + const code = typeof result === 'string' ? result : '' const cjsModule = `(function (exports, require, module, __filename, __dirname) { ${code}\n})` const script = new vm.Script(cjsModule, { @@ -218,11 +225,14 @@ export class ExternalModulesExecutor { script.identifier = filename const fn = script.runInContext(this.context) const __dirname = dirname(filename) - const module = this.createCommonJSNodeModule(filename) this.requireCache[filename] = module - fn(module.exports, module.require, module, filename, __dirname) - module.loaded = true - return module.exports + try { + fn(module.exports, module.require, module, filename, __dirname) + return module.exports + } + finally { + module.loaded = true + } } async createEsmModule(fileUrl: string, code: string) { @@ -237,6 +247,7 @@ export class ExternalModulesExecutor { importModuleDynamically: this.importModuleDynamically, initializeImportMeta: (meta, mod) => { meta.url = mod.identifier + // TODO: improve Node.js support with #2854 // meta.resolve = (specifier: string, importer?: string) => // this.resolveAsync(specifier, importer ?? mod.identifier) }, @@ -246,9 +257,11 @@ export class ExternalModulesExecutor { return m } - // TODO: return custom "createRequire" function for "node:module" private requireCoreModule(identifier: string) { - return _require(identifier) + const moduleExports = _require(identifier) + if (identifier === 'node:module' || identifier === 'module') + return { ...moduleExports, createRequire: this.createRequire } + return moduleExports } private getIdentifierCode(code: string) { @@ -270,9 +283,10 @@ export class ExternalModulesExecutor { const inlineCode = this.getIdentifierCode(identifier) const code = inlineCode || await readFile(pathUrl, 'utf-8') - // TODO: very dirty check for cjs, it should actually check filepath + // TODO: very dirty check for cjs, it should actually check filepath and package.json, improve in #2854 if (!inlineCode && (extension === '.cjs' || !hasESMSyntax(code))) { - const exports = this.evaluateCommonJSModule(pathUrl, code) + const module = this.createCommonJSNodeModule(pathUrl) + const exports = this.evaluateCommonJSModule(module, pathUrl) return this.wrapSynteticModule(fileUrl, 'cjs', exports) } diff --git a/pnpm-lock.yaml b/pnpm-lock.yaml index 1efc56c3be59..280180633bd7 100644 --- a/pnpm-lock.yaml +++ b/pnpm-lock.yaml @@ -325,10 +325,10 @@ importers: version: 13.3.0(react-dom@18.0.0)(react@18.0.0) '@types/node': specifier: latest - version: 20.1.2 + version: 20.3.1 '@types/react': specifier: latest - version: 18.2.3 + version: 18.2.12 '@vitejs/plugin-react': specifier: latest version: 4.0.3(vite@4.3.9) @@ -615,7 +615,7 @@ importers: version: 18.0.8 '@vitejs/plugin-react': specifier: latest - version: 4.0.0(vite@4.2.1) + version: 4.0.0(vite@4.3.9) '@vitest/coverage-c8': specifier: ^0.24.5 version: 0.24.5 @@ -804,10 +804,10 @@ importers: version: 22.1.0 unplugin-auto-import: specifier: latest - version: 0.12.1(rollup@3.20.2) + version: 0.16.4(rollup@3.20.2) unplugin-vue-components: specifier: latest - version: 0.22.12(rollup@3.20.2)(vue@3.2.47) + version: 0.25.1(rollup@3.20.2)(vue@3.3.4) vite: specifier: ^4.3.9 version: 4.3.9(@types/node@18.16.19) @@ -5868,7 +5868,7 @@ packages: engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: '@jest/types': 27.5.1 - '@types/node': 20.1.2 + '@types/node': 20.3.1 chalk: 4.1.2 jest-message-util: 27.5.1 jest-util: 27.5.1 @@ -5889,7 +5889,7 @@ packages: '@jest/test-result': 27.5.1 '@jest/transform': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.1.2 + '@types/node': 20.3.1 ansi-escapes: 4.3.2 chalk: 4.1.2 emittery: 0.8.1 @@ -5926,7 +5926,7 @@ packages: dependencies: '@jest/fake-timers': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.1.2 + '@types/node': 20.3.1 jest-mock: 27.5.1 dev: true @@ -5943,7 +5943,7 @@ packages: dependencies: '@jest/types': 27.5.1 '@sinonjs/fake-timers': 8.1.0 - '@types/node': 20.1.2 + '@types/node': 20.3.1 jest-message-util: 27.5.1 jest-mock: 27.5.1 jest-util: 27.5.1 @@ -5972,7 +5972,7 @@ packages: '@jest/test-result': 27.5.1 '@jest/transform': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.1.2 + '@types/node': 20.3.1 chalk: 4.1.2 collect-v8-coverage: 1.0.1 exit: 0.1.2 @@ -6085,7 +6085,7 @@ packages: dependencies: '@types/istanbul-lib-coverage': 2.0.4 '@types/istanbul-reports': 3.0.1 - '@types/node': 20.1.2 + '@types/node': 20.3.1 '@types/yargs': 15.0.14 chalk: 4.1.2 dev: true @@ -6096,7 +6096,7 @@ packages: dependencies: '@types/istanbul-lib-coverage': 2.0.4 '@types/istanbul-reports': 3.0.1 - '@types/node': 20.1.2 + '@types/node': 20.3.1 '@types/yargs': 16.0.5 chalk: 4.1.2 dev: true @@ -6108,7 +6108,7 @@ packages: '@jest/schemas': 29.4.3 '@types/istanbul-lib-coverage': 2.0.4 '@types/istanbul-reports': 3.0.1 - '@types/node': 20.1.2 + '@types/node': 20.3.1 '@types/yargs': 17.0.12 chalk: 4.1.2 dev: true @@ -6631,7 +6631,7 @@ packages: engines: {node: '>=14'} hasBin: true dependencies: - '@types/node': 20.1.2 + '@types/node': 20.3.1 playwright-core: 1.28.0 dev: true @@ -8343,7 +8343,26 @@ packages: svelte: ^3.54.0 || ^4.0.0 vite: ^4.0.0 dependencies: - '@sveltejs/vite-plugin-svelte-inspector': 1.0.3(@sveltejs/vite-plugin-svelte@2.4.2)(svelte@3.59.1)(vite@4.3.9) + debug: 4.3.4(supports-color@8.1.1) + deepmerge: 4.2.2 + kleur: 4.1.5 + magic-string: 0.27.0 + svelte: 3.59.1 + svelte-hmr: 0.15.1(svelte@3.59.1) + vite: 4.3.9(@types/node@18.16.3) + vitefu: 0.2.4(vite@4.3.9) + transitivePeerDependencies: + - supports-color + dev: true + + /@sveltejs/vite-plugin-svelte@2.4.1(svelte@3.59.1)(vite@4.3.9): + resolution: {integrity: sha512-bNNKvoRY89ptY7udeBSCmTdCVwkjmMcZ0j/z9J5MuedT8jPjq0zrknAo/jF1sToAza4NVaAgR9AkZoD9oJJmnA==} + engines: {node: ^14.18.0 || >= 16} + peerDependencies: + svelte: ^3.54.0 || ^4.0.0-next.0 + vite: ^4.0.0 + dependencies: + '@sveltejs/vite-plugin-svelte-inspector': 1.0.2(@sveltejs/vite-plugin-svelte@2.4.1)(svelte@3.59.1)(vite@4.3.9) debug: 4.3.4(supports-color@8.1.1) deepmerge: 4.3.1 kleur: 4.1.5 @@ -8610,7 +8629,7 @@ packages: /@types/cheerio@0.22.31: resolution: {integrity: sha512-Kt7Cdjjdi2XWSfrZ53v4Of0wG3ZcmaegFXjMmz9tfNrZSkzzo36G0AL1YqSdcIA78Etjt6E609pt5h1xnQkPUw==} dependencies: - '@types/node': 20.1.2 + '@types/node': 20.3.1 dev: true /@types/codemirror@5.60.8: @@ -8649,7 +8668,7 @@ packages: resolution: {integrity: sha512-xryQlOEIe1TduDWAOphR0ihfebKFSWOXpIsk+70JskCfRfW+xALdnJ0r1ZOTo85F9Qsjk6vtlU7edTYHbls9tA==} dependencies: '@types/cheerio': 0.22.31 - '@types/react': 18.2.6 + '@types/react': 18.2.12 dev: true /@types/eslint-scope@3.7.4: @@ -8680,33 +8699,33 @@ packages: resolution: {integrity: sha512-MxObHvNl4A69ofaTRU8DFqvgzzv8s9yRtaPPm5gud9HDNvpB3GPQFvNuTWAI59B9huVGV5jXYJwbCsmBsOGYWA==} dependencies: '@types/jsonfile': 6.1.1 - '@types/node': 20.1.2 + '@types/node': 20.3.1 dev: true /@types/fs-extra@9.0.13: resolution: {integrity: sha512-nEnwB++1u5lVDM2UI4c1+5R+FYaKfaAzS4OococimjVm3nQw3TuzH5UNsocrcTBbhnerblyHj4A49qXbIiZdpA==} dependencies: - '@types/node': 20.1.2 + '@types/node': 20.3.1 dev: true /@types/glob@7.2.0: resolution: {integrity: sha512-ZUxbzKl0IfJILTS6t7ip5fQQM/J3TJYubDm3nMbgubNNYS62eXeUpoLUC8/7fJNiFYHTrGPQn7hspDUzIHX3UA==} dependencies: '@types/minimatch': 5.1.1 - '@types/node': 20.1.2 + '@types/node': 20.3.1 dev: true /@types/glob@8.0.0: resolution: {integrity: sha512-l6NQsDDyQUVeoTynNpC9uRvCUint/gSUXQA2euwmTuWGvPY5LSDUu6tkCtJB2SvGQlJQzLaKqcGZP4//7EDveA==} dependencies: '@types/minimatch': 5.1.1 - '@types/node': 20.1.2 + '@types/node': 20.3.1 dev: true /@types/graceful-fs@4.1.5: resolution: {integrity: sha512-anKkLmZZ+xm4p8JWBf4hElkM4XR+EZeA2M9BAkkTldmcyDY4mbdIJnRghDJH3Ov5ooY7/UAoENtmdMSkaAd7Cw==} dependencies: - '@types/node': 20.1.2 + '@types/node': 20.3.1 dev: true /@types/hast@2.3.4: @@ -8778,7 +8797,7 @@ packages: /@types/jsdom@21.1.1: resolution: {integrity: sha512-cZFuoVLtzKP3gmq9eNosUL1R50U+USkbLtUQ1bYVgl/lKp0FZM7Cq4aIHAL8oIvQ17uSHi7jXPtfDOdjPwBE7A==} dependencies: - '@types/node': 20.1.2 + '@types/node': 20.3.1 '@types/tough-cookie': 4.0.2 parse5: 7.1.2 dev: true @@ -8790,7 +8809,7 @@ packages: /@types/jsonfile@6.1.1: resolution: {integrity: sha512-GSgiRCVeapDN+3pqA35IkQwasaCh/0YFH5dEF6S88iDvEn901DjOeH3/QPY+XYP1DFzDZPvIvfeEgk+7br5png==} dependencies: - '@types/node': 20.1.2 + '@types/node': 20.3.1 dev: true /@types/lodash@4.14.195: @@ -8824,7 +8843,7 @@ packages: /@types/node-fetch@2.6.2: resolution: {integrity: sha512-DHqhlq5jeESLy19TYhLakJ07kNumXWjcDdxXsLUMJZ6ue8VZJj4kLPQVE/2mdHh3xZziNF1xppu5lwmS53HR+A==} dependencies: - '@types/node': 20.1.2 + '@types/node': 20.3.1 form-data: 3.0.1 dev: true @@ -8843,8 +8862,8 @@ packages: resolution: {integrity: sha512-46yIhxSe5xEaJZXWdIBP7GU4HDTG8/eo0qd9atdiL+lFpA03y8KS+lkTN834TWJj5767GbWv4n/P6efyTFt1Dw==} dev: false - /@types/node@20.1.2: - resolution: {integrity: sha512-CTO/wa8x+rZU626cL2BlbCDzydgnFNgc19h4YvizpTO88MFQxab8wqisxaofQJ/9bLGugRdWIuX/TbIs6VVF6g==} + /@types/node@20.3.1: + resolution: {integrity: sha512-EhcH/wvidPy1WeML3TtYFGR83UzjxeWRen9V402T8aUGYsCHOmfoisV3ZSg03gAFIbLq8TnWOJ0f4cALtnSEUg==} dev: true /@types/normalize-package-data@2.4.1: @@ -8873,7 +8892,7 @@ packages: /@types/prompts@2.4.4: resolution: {integrity: sha512-p5N9uoTH76lLvSAaYSZtBCdEXzpOOufsRjnhjVSrZGXikVGHX9+cc9ERtHRV4hvBKHyZb1bg4K+56Bd2TqUn4A==} dependencies: - '@types/node': 20.1.2 + '@types/node': 20.3.1 kleur: 3.0.3 dev: true @@ -8897,19 +8916,19 @@ packages: /@types/react-dom@18.0.6: resolution: {integrity: sha512-/5OFZgfIPSwy+YuIBP/FgJnQnsxhZhjjrnxudMddeblOouIodEQ75X14Rr4wGSG/bknL+Omy9iWlLo1u/9GzAA==} dependencies: - '@types/react': 18.2.6 + '@types/react': 18.2.12 dev: true /@types/react-dom@18.0.8: resolution: {integrity: sha512-C3GYO0HLaOkk9dDAz3Dl4sbe4AKUGTCfFIZsz3n/82dPNN8Du533HzKatDxeUYWu24wJgMP1xICqkWk1YOLOIw==} dependencies: - '@types/react': 18.2.6 + '@types/react': 18.2.12 dev: true /@types/react-is@17.0.3: resolution: {integrity: sha512-aBTIWg1emtu95bLTLx0cpkxwGW3ueZv71nE2YFBpL8k/z5czEW8yYpOo8Dp+UUAFAtKwNaOsh/ioSeQnWlZcfw==} dependencies: - '@types/react': 18.2.6 + '@types/react': 18.2.12 dev: false /@types/react-test-renderer@17.0.2: @@ -8921,7 +8940,7 @@ packages: /@types/react-transition-group@4.4.5: resolution: {integrity: sha512-juKD/eiSM3/xZYzjuzH6ZwpP+/lejltmiS3QEzV/vmb/Q8+HfDmxu+Baga8UEMGBqV88Nbg4l2hY/K2DkyaLLA==} dependencies: - '@types/react': 18.2.6 + '@types/react': 18.2.12 dev: false /@types/react@17.0.49: @@ -8940,25 +8959,17 @@ packages: csstype: 3.1.0 dev: true - /@types/react@18.2.3: - resolution: {integrity: sha512-myU58XyFvSCcF9stRlhYnPbHZu9md7VZNsLukY6D68JHzIHLvqxvutD5luAJLnrUKMswvAgGwdSlEUKKSD+9Fw==} + /@types/react@18.2.12: + resolution: {integrity: sha512-ndmBMLCgn38v3SntMeoJaIrO6tGHYKMEBohCUmw8HoLLQdRMOIGXfeYaBTLe2lsFaSB3MOK1VXscYFnmLtTSmw==} dependencies: '@types/prop-types': 15.7.5 '@types/scheduler': 0.16.2 - csstype: 3.1.0 - dev: true - - /@types/react@18.2.6: - resolution: {integrity: sha512-wRZClXn//zxCFW+ye/D2qY65UsYP1Fpex2YXorHc8awoNamkMZSvBxwxdYVInsHOZZd2Ppq8isnSzJL5Mpf8OA==} - dependencies: - '@types/prop-types': 15.7.5 - '@types/scheduler': 0.16.2 - csstype: 3.1.0 + csstype: 3.1.2 /@types/resolve@1.17.1: resolution: {integrity: sha512-yy7HuzQhj0dhGpD8RLXSZWEkLsV9ibvxvi6EiJ3bkqLAO1RGo0WbkWQiwpRlSFymTJRz0d3k5LM3kkx8ArDbLw==} dependencies: - '@types/node': 20.1.2 + '@types/node': 20.3.1 dev: true /@types/resolve@1.20.2: @@ -8975,7 +8986,7 @@ packages: /@types/set-cookie-parser@2.4.2: resolution: {integrity: sha512-fBZgytwhYAUkj/jC/FAV4RQ5EerRup1YQsXQCh8rZfiHkc4UahC192oH0smGwsXol3cL3A5oETuAHeQHmhXM4w==} dependencies: - '@types/node': 20.1.2 + '@types/node': 20.3.1 dev: true /@types/sinonjs__fake-timers@8.1.1: @@ -9055,7 +9066,7 @@ packages: /@types/webpack-sources@3.2.0: resolution: {integrity: sha512-Ft7YH3lEVRQ6ls8k4Ff1oB4jN6oy/XmU6tQISKdhfh+1mR+viZFphS6WL0IrtDOzvefmJg5a0s7ZQoRXwqTEFg==} dependencies: - '@types/node': 20.1.2 + '@types/node': 20.3.1 '@types/source-list-map': 0.1.2 source-map: 0.7.4 dev: true @@ -9063,7 +9074,7 @@ packages: /@types/webpack@4.41.32: resolution: {integrity: sha512-cb+0ioil/7oz5//7tZUSwbrSAN/NWHrQylz5cW8G0dWTcF/g+/dSdMlKVZspBYuMAN1+WnwHrkxiRrLcwd0Heg==} dependencies: - '@types/node': 20.1.2 + '@types/node': 20.3.1 '@types/tapable': 1.0.8 '@types/uglify-js': 3.17.0 '@types/webpack-sources': 3.2.0 @@ -9078,7 +9089,7 @@ packages: /@types/ws@8.5.5: resolution: {integrity: sha512-lwhs8hktwxSjf9UaZ9tG5M03PGogvFaH8gUgLNbN9HKIg0dvv6q+gkSuJ8HN4/VbyxkuLzCjlN7GquQ0gUJfIg==} dependencies: - '@types/node': 20.1.2 + '@types/node': 20.3.1 dev: true /@types/yargs-parser@21.0.0: @@ -9107,7 +9118,7 @@ packages: resolution: {integrity: sha512-Cn6WYCm0tXv8p6k+A8PvbDG763EDpBoTzHdA+Q/MF6H3sapGjCm9NzoaJncJS9tUKSuCoDs9XHxYYsQDgxR6kw==} requiresBuild: true dependencies: - '@types/node': 20.1.2 + '@types/node': 20.3.1 dev: true optional: true @@ -9524,7 +9535,7 @@ packages: - supports-color dev: true - /@vitejs/plugin-react@4.0.0(vite@4.2.1): + /@vitejs/plugin-react@4.0.0(vite@4.3.9): resolution: {integrity: sha512-HX0XzMjL3hhOYm+0s95pb0Z7F8O81G7joUHgfDd/9J/ZZf5k4xX6QAMFkKsHFxaHlf6X7GD7+XuaZ66ULiJuhQ==} engines: {node: ^14.18.0 || >=16.0.0} peerDependencies: @@ -9534,7 +9545,7 @@ packages: '@babel/plugin-transform-react-jsx-self': 7.22.5(@babel/core@7.22.5) '@babel/plugin-transform-react-jsx-source': 7.22.5(@babel/core@7.22.5) react-refresh: 0.14.0 - vite: 4.2.1(@types/node@20.1.2) + vite: 4.3.9(@types/node@20.3.1) transitivePeerDependencies: - supports-color dev: true @@ -11342,8 +11353,8 @@ packages: dev: true optional: true - /birpc@0.2.11: - resolution: {integrity: sha512-OcUm84SBHRsmvSQhOLZRt5Awmw8WVknVcMDMaPE8GPwYxzc4mGE0EIytkWXayPjheGvm7s/Ci1wQZGwk7YPU6A==} + /birpc@0.2.12: + resolution: {integrity: sha512-6Wz9FXuJ/FE4gDH+IGQhrYdalAvAQU1Yrtcu1UlMk3+9mMXxIRXiL+MxUcGokso42s+Fy+YoUXGLOdOs0siV3A==} /bl@4.1.0: resolution: {integrity: sha512-1W07cM9gS6DcLperZfFSj+bWLtaPGSOHWhPiGzXmvVJbRLdG82sH/Kn8EtW1VqWVA54AKf2h5k5BbnIbwF3h6w==} @@ -12001,7 +12012,7 @@ packages: engines: {node: '>=12.13.0'} hasBin: true dependencies: - '@types/node': 20.1.2 + '@types/node': 20.3.1 escape-string-regexp: 4.0.0 is-wsl: 2.2.0 lighthouse-logger: 1.3.0 @@ -15751,7 +15762,7 @@ packages: defu: 6.1.2 https-proxy-agent: 5.0.1 mri: 1.2.0 - node-fetch-native: 1.2.0 + node-fetch-native: 1.1.0 pathe: 1.1.1 tar: 6.1.13 transitivePeerDependencies: @@ -17277,7 +17288,7 @@ packages: '@jest/environment': 27.5.1 '@jest/test-result': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.1.2 + '@types/node': 20.3.1 chalk: 4.1.2 co: 4.6.0 dedent: 0.7.0 @@ -17413,7 +17424,7 @@ packages: '@jest/environment': 27.5.1 '@jest/fake-timers': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.1.2 + '@types/node': 20.3.1 jest-mock: 27.5.1 jest-util: 27.5.1 jsdom: 16.7.0 @@ -17431,7 +17442,7 @@ packages: '@jest/environment': 27.5.1 '@jest/fake-timers': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.1.2 + '@types/node': 20.3.1 jest-mock: 27.5.1 jest-util: 27.5.1 dev: true @@ -17452,7 +17463,7 @@ packages: dependencies: '@jest/types': 26.6.2 '@types/graceful-fs': 4.1.5 - '@types/node': 20.1.2 + '@types/node': 20.3.1 anymatch: 3.1.2 fb-watchman: 2.0.1 graceful-fs: 4.2.10 @@ -17475,7 +17486,7 @@ packages: dependencies: '@jest/types': 27.5.1 '@types/graceful-fs': 4.1.5 - '@types/node': 20.1.2 + '@types/node': 20.3.1 anymatch: 3.1.2 fb-watchman: 2.0.1 graceful-fs: 4.2.10 @@ -17515,7 +17526,7 @@ packages: '@jest/source-map': 27.5.1 '@jest/test-result': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.1.2 + '@types/node': 20.3.1 chalk: 4.1.2 co: 4.6.0 expect: 27.5.1 @@ -17595,7 +17606,7 @@ packages: engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: '@jest/types': 27.5.1 - '@types/node': 20.1.2 + '@types/node': 20.3.1 dev: true /jest-pnp-resolver@1.2.3(jest-resolve@27.5.1): @@ -17656,7 +17667,7 @@ packages: '@jest/test-result': 27.5.1 '@jest/transform': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.1.2 + '@types/node': 20.3.1 chalk: 4.1.2 emittery: 0.8.1 graceful-fs: 4.2.10 @@ -17713,7 +17724,7 @@ packages: resolution: {integrity: sha512-S5wqyz0DXnNJPd/xfIzZ5Xnp1HrJWBczg8mMfMpN78OJ5eDxXyf+Ygld9wX1DnUWbIbhM1YDY95NjR4CBXkb2g==} engines: {node: '>= 10.14.2'} dependencies: - '@types/node': 20.1.2 + '@types/node': 20.3.1 graceful-fs: 4.2.10 dev: true @@ -17721,7 +17732,7 @@ packages: resolution: {integrity: sha512-jZCyo6iIxO1aqUxpuBlwTDMkzOAJS4a3eYz3YzgxxVQFwLeSA7Jfq5cbqCY+JLvTDrWirgusI/0KwxKMgrdf7w==} engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: - '@types/node': 20.1.2 + '@types/node': 20.3.1 graceful-fs: 4.2.10 dev: true @@ -17760,7 +17771,7 @@ packages: engines: {node: '>= 10.14.2'} dependencies: '@jest/types': 26.6.2 - '@types/node': 20.1.2 + '@types/node': 20.3.1 chalk: 4.1.2 graceful-fs: 4.2.10 is-ci: 2.0.0 @@ -17772,7 +17783,7 @@ packages: engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: '@jest/types': 27.5.1 - '@types/node': 20.1.2 + '@types/node': 20.3.1 chalk: 4.1.2 ci-info: 3.8.0 graceful-fs: 4.2.10 @@ -17784,7 +17795,7 @@ packages: engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: '@jest/types': 29.0.1 - '@types/node': 20.1.2 + '@types/node': 20.3.1 chalk: 4.1.2 ci-info: 3.7.0 graceful-fs: 4.2.10 @@ -17809,7 +17820,7 @@ packages: dependencies: '@jest/test-result': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.1.2 + '@types/node': 20.3.1 ansi-escapes: 4.3.2 chalk: 4.1.2 jest-util: 27.5.1 @@ -17820,7 +17831,7 @@ packages: resolution: {integrity: sha512-KWYVV1c4i+jbMpaBC+U++4Va0cp8OisU185o73T1vo99hqi7w8tSJfUXYswwqqrjzwxa6KpRK54WhPvwf5w6PQ==} engines: {node: '>= 10.13.0'} dependencies: - '@types/node': 20.1.2 + '@types/node': 20.3.1 merge-stream: 2.0.0 supports-color: 7.2.0 dev: true @@ -17829,7 +17840,7 @@ packages: resolution: {integrity: sha512-7vuh85V5cdDofPyxn58nrPjBktZo0u9x1g8WtjQol+jZDaE+fhN+cIvTj11GndBnMnyfrUOG1sZQxCdjKh+DKg==} engines: {node: '>= 10.13.0'} dependencies: - '@types/node': 20.1.2 + '@types/node': 20.3.1 merge-stream: 2.0.0 supports-color: 8.1.1 dev: true @@ -19179,7 +19190,7 @@ packages: /mlly@1.3.0: resolution: {integrity: sha512-HT5mcgIQKkOrZecOjOX3DJorTikWXwsBfpcr/MGBkhfWcjiqvnaL/9ppxvIUXfjT6xt4DVIAsN9fMUz1ev4bIw==} dependencies: - acorn: 8.9.0 + acorn: 8.8.2 pathe: 1.1.1 pkg-types: 1.0.3 ufo: 1.1.2 @@ -20301,6 +20312,9 @@ packages: /pathe@1.1.1: resolution: {integrity: sha512-d+RQGp0MAYTIaDBIMmOfMwz3E+LOZnxx1HZd5R18mmCZY0QBlK0LDZfPc8FW8Ed2DlvsuE6PRjroDY+wg4+j/Q==} + /pathe@1.1.1: + resolution: {integrity: sha512-d+RQGp0MAYTIaDBIMmOfMwz3E+LOZnxx1HZd5R18mmCZY0QBlK0LDZfPc8FW8Ed2DlvsuE6PRjroDY+wg4+j/Q==} + /pathval@1.1.1: resolution: {integrity: sha512-Dp6zGqpTdETdR63lehJYPeIOqpiNBNtc7BpWSLrOje7UaIsE5aY92r/AunQA7rsXvet3lrJ3JnZX29UPTKXyKQ==} dev: false @@ -24051,26 +24065,8 @@ packages: vfile: 4.2.1 dev: true - /unimport@1.3.0(rollup@3.20.2): - resolution: {integrity: sha512-fOkrdxglsHd428yegH0wPH/6IfaSdDeMXtdRGn6en/ccyzc2aaoxiUTMrJyc6Bu+xoa18RJRPMfLUHEzjz8atw==} - dependencies: - '@rollup/pluginutils': 5.0.2(rollup@3.20.2) - escape-string-regexp: 5.0.0 - fast-glob: 3.2.12 - local-pkg: 0.4.3 - magic-string: 0.27.0 - mlly: 1.2.0 - pathe: 1.1.0 - pkg-types: 1.0.3 - scule: 1.0.0 - strip-literal: 1.0.1 - unplugin: 1.3.1 - transitivePeerDependencies: - - rollup - dev: true - - /unimport@3.0.6(rollup@3.20.2): - resolution: {integrity: sha512-GYxGJ1Bri1oqx8VFDjdgooGzeK7jBk3bvhXmamTIpu3nONOcUMGwZbX7X0L5RA7OWMXpR4vzpSQP7pXUzJg1/Q==} + /unimport@3.0.8(rollup@3.20.2): + resolution: {integrity: sha512-AOt6xj3QMwqcTZRPB+NhFkyVEjCKnpTVoPm5x6424zz2NYYtCfym2bpJofzPHIJKPNIh5ko2/t2q46ZIMgdmbw==} dependencies: '@rollup/pluginutils': 5.0.2(rollup@3.26.0) escape-string-regexp: 5.0.0 @@ -24259,25 +24255,6 @@ packages: engines: {node: '>= 0.8'} dev: true - /unplugin-auto-import@0.12.1(rollup@3.20.2): - resolution: {integrity: sha512-J/3ZORq5YGKG+8D5vLLOgqaHNK77izlVN07mQ752yRLqBNDbJiwPRSnUwwYqH5N6rDay1SqnJCHaUdbJ9QMI2w==} - engines: {node: '>=14'} - peerDependencies: - '@vueuse/core': '*' - peerDependenciesMeta: - '@vueuse/core': - optional: true - dependencies: - '@antfu/utils': 0.7.2 - '@rollup/pluginutils': 5.0.2(rollup@3.20.2) - local-pkg: 0.4.3 - magic-string: 0.27.0 - unimport: 1.3.0(rollup@3.20.2) - unplugin: 1.3.1 - transitivePeerDependencies: - - rollup - dev: true - /unplugin-auto-import@0.15.3(@vueuse/core@10.1.2)(rollup@3.20.2): resolution: {integrity: sha512-RLT8SqbPn4bT7yBshZId0uPSofKWnwr66RyDaxWaFb/+f7OTDOWAsVNz+hOQLBWSjvbekr2xZY9ccS8TDHJbCQ==} engines: {node: '>=14'} @@ -24296,14 +24273,14 @@ packages: local-pkg: 0.4.3 magic-string: 0.30.1 minimatch: 9.0.1 - unimport: 3.0.7(rollup@3.26.0) + unimport: 3.0.8(rollup@3.20.2) unplugin: 1.3.1 transitivePeerDependencies: - rollup dev: true - /unplugin-vue-components@0.22.12(rollup@3.20.2)(vue@3.2.47): - resolution: {integrity: sha512-FxyzsuBvMCYPIk+8cgscGBQ345tvwVu+qY5IhE++eorkyvA4Z1TiD/HCiim+Kbqozl10i4K+z+NCa2WO2jexRA==} + /unplugin-auto-import@0.16.4(rollup@3.20.2): + resolution: {integrity: sha512-xdgBa9NAS3JG8HjkAZHSbGSMlrjKpaWKXGUzaF6RzEtr980RCl1t0Zsu0skUInNYrEQfqaHc7aGWPv41DLTK/w==} engines: {node: '>=14'} peerDependencies: '@nuxt/kit': ^3.2.2 @@ -24316,15 +24293,11 @@ packages: dependencies: '@antfu/utils': 0.7.4 '@rollup/pluginutils': 5.0.2(rollup@3.20.2) - chokidar: 3.5.3 - debug: 4.3.4(supports-color@8.1.1) - fast-glob: 3.2.12 local-pkg: 0.4.3 - magic-string: 0.27.0 - minimatch: 5.1.1 - resolve: 1.22.1 + magic-string: 0.30.0 + minimatch: 9.0.1 + unimport: 3.0.8(rollup@3.20.2) unplugin: 1.3.1 - vue: 3.2.47 transitivePeerDependencies: - rollup dev: true @@ -24387,6 +24360,35 @@ packages: - supports-color dev: true + /unplugin-vue-components@0.25.1(rollup@3.20.2)(vue@3.3.4): + resolution: {integrity: sha512-kzS2ZHVMaGU2XEO2keYQcMjNZkanDSGDdY96uQT9EPe+wqSZwwgbFfKVJ5ti0+8rGAcKHColwKUvctBhq2LJ3A==} + engines: {node: '>=14'} + peerDependencies: + '@babel/parser': ^7.15.8 + '@nuxt/kit': ^3.2.2 + vue: 2 || 3 + peerDependenciesMeta: + '@babel/parser': + optional: true + '@nuxt/kit': + optional: true + dependencies: + '@antfu/utils': 0.7.4 + '@rollup/pluginutils': 5.0.2(rollup@3.20.2) + chokidar: 3.5.3 + debug: 4.3.4(supports-color@8.1.1) + fast-glob: 3.2.12 + local-pkg: 0.4.3 + magic-string: 0.30.0 + minimatch: 9.0.1 + resolve: 1.22.2 + unplugin: 1.3.1 + vue: 3.3.4 + transitivePeerDependencies: + - rollup + - supports-color + dev: true + /unplugin@1.3.1: resolution: {integrity: sha512-h4uUTIvFBQRxUKS2Wjys6ivoeofGhxzTe2sRWlooyjHXVttcVfV/JiavNd3d4+jty0SVV0dxGw9AkY9MwiaCEw==} dependencies: @@ -24684,8 +24686,8 @@ packages: merge-anything: 5.1.4 solid-js: 1.5.2 solid-refresh: 0.4.1(solid-js@1.5.2) - vite: 4.3.9(@types/node@18.16.19) - vitefu: 0.2.3(vite@4.3.9) + vite: 4.3.9(@types/node@18.16.3) + vitefu: 0.2.4(vite@4.3.9) transitivePeerDependencies: - supports-color dev: true @@ -24755,8 +24757,8 @@ packages: fsevents: 2.3.2 dev: false - /vite@4.2.1(@types/node@20.1.2): - resolution: {integrity: sha512-7MKhqdy0ISo4wnvwtqZkjke6XN4taqQ2TBaTccLIpOKv7Vp2h4Y+NpmWCnGDeSvvn45KxvWgGyb0MkHvY1vgbg==} + /vite@4.3.9(@types/node@20.3.1): + resolution: {integrity: sha512-qsTNZjO9NoJNW7KnOrgYwczm0WctJ8m/yqYAMAK9Lxt4SoySUfS5S8ia9K7JHpa3KEeMfyF8LoJ3c5NeBJy6pg==} engines: {node: ^14.18.0 || >=16.0.0} hasBin: true peerDependencies: @@ -24780,26 +24782,14 @@ packages: terser: optional: true dependencies: - '@types/node': 20.1.2 - esbuild: 0.17.15 - postcss: 8.4.21 - resolve: 1.22.1 - rollup: 3.20.2 + '@types/node': 20.3.1 + esbuild: 0.17.18 + postcss: 8.4.24 + rollup: 3.23.0 optionalDependencies: fsevents: 2.3.2 dev: true - /vitefu@0.2.3(vite@4.2.1): - resolution: {integrity: sha512-75l7TTuU8isAhz1QFtNKjDkqjxvndfMC1AfIMjJ0ZQ59ZD0Ow9QOIsJJX16Wv9PS8f+zMzp6fHy5cCbKG/yVUQ==} - peerDependencies: - vite: ^3.0.0 || ^4.0.0 - peerDependenciesMeta: - vite: - optional: true - dependencies: - vite: 4.3.9(@types/node@18.16.19) - dev: true - /vitefu@0.2.4(vite@4.3.9): resolution: {integrity: sha512-fanAXjSaf9xXtOOeno8wZXIhgia+CZury481LsDaV++lSvcU2R9Ch2bPh3PYFyoHW+w9LqAeYRISVQjUIew14g==} peerDependencies: From 67c2b98a520441f7aaf1a767a812744656f5609f Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Mon, 19 Jun 2023 11:54:27 +0200 Subject: [PATCH 32/87] chore: fix caching --- packages/ui/client/auto-imports.d.ts | 2 -- packages/vitest/src/runtime/execute.ts | 3 +++ .../vitest/src/runtime/external-executor.ts | 24 ++++++++++++------- packages/vitest/src/types/general.ts | 4 +--- 4 files changed, 19 insertions(+), 14 deletions(-) diff --git a/packages/ui/client/auto-imports.d.ts b/packages/ui/client/auto-imports.d.ts index 8185410d6a10..1c97dd711fb4 100644 --- a/packages/ui/client/auto-imports.d.ts +++ b/packages/ui/client/auto-imports.d.ts @@ -129,8 +129,6 @@ declare global { const toRef: typeof import('vue')['toRef'] const toRefs: typeof import('vue')['toRefs'] const toValue: typeof import('vue')['toValue'] - const toggleDark: typeof import('./composables/dark')['toggleDark'] - const totalTests: typeof import('./composables/summary')['totalTests'] const triggerRef: typeof import('vue')['triggerRef'] const tryOnBeforeMount: typeof import('@vueuse/core')['tryOnBeforeMount'] const tryOnBeforeUnmount: typeof import('@vueuse/core')['tryOnBeforeUnmount'] diff --git a/packages/vitest/src/runtime/execute.ts b/packages/vitest/src/runtime/execute.ts index a0cfdf5d275f..4b54d732b030 100644 --- a/packages/vitest/src/runtime/execute.ts +++ b/packages/vitest/src/runtime/execute.ts @@ -218,6 +218,9 @@ export class VitestExecutor extends ViteNodeRunner { Object.defineProperty(context.__vite_ssr_import_meta__, 'vitest', { get: () => globalThis.__vitest_index__ }) } + if (this.options.context && this.externalModules) + context.require = this.externalModules.createRequire(context.__filename) + return context } } diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index ffcb2de25e8f..21744a5fb243 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -89,7 +89,7 @@ const _require = createRequire(import.meta.url) export class ExternalModulesExecutor { private context: vm.Context - private requireCache = _require.cache + private requireCache: Record = Object.create(null) private moduleCache = new Map() private extensions: Record string> = Object.create(null) @@ -97,8 +97,7 @@ export class ExternalModulesExecutor { constructor(context: vm.Context) { this.context = context - for (const file in this.requireCache) - delete this.requireCache[file] + this.requireCache = Object.create(null) this.extensions['.js'] = this.requireJs this.extensions['.json'] = this.requireJson @@ -163,20 +162,20 @@ export class ExternalModulesExecutor { return m } - private createRequire = (filename: string) => { + public createRequire = (filename: string) => { const _require = createRequire(filename) const require = ((id: string) => { const filename = _require.resolve(id) const ext = extname(filename) if (ext === '.node' || isNodeBuiltin(filename)) - return _require(filename) + return this.requireCoreModule(filename) const module = this.createCommonJSNodeModule(filename) return this.evaluateCommonJSModule(module, filename) }) as NodeRequire require.resolve = _require.resolve Object.defineProperty(require, 'extensions', { get: () => this.extensions, - writable: true, + set: () => {}, configurable: true, }) require.main = _require.main @@ -200,7 +199,6 @@ export class ExternalModulesExecutor { path: __dirname, paths: [], } - this.requireCache[filename] = module return module } @@ -258,9 +256,17 @@ export class ExternalModulesExecutor { } private requireCoreModule(identifier: string) { + const normalized = identifier.replace(/^node:/, '') + if (this.requireCache[normalized]) + return this.requireCache[normalized].exports const moduleExports = _require(identifier) - if (identifier === 'node:module' || identifier === 'module') - return { ...moduleExports, createRequire: this.createRequire } + if (identifier === 'node:module' || identifier === 'module') { + const exports = { ...moduleExports, createRequire: this.createRequire } + const cached = _require.cache[normalized]! + this.requireCache[normalized] = { ...cached, exports } + return exports + } + this.requireCache[normalized] = _require.cache[normalized]! return moduleExports } diff --git a/packages/vitest/src/types/general.ts b/packages/vitest/src/types/general.ts index 9ef0fe7881d5..826bd71477bc 100644 --- a/packages/vitest/src/types/general.ts +++ b/packages/vitest/src/types/general.ts @@ -1,5 +1,3 @@ -import type { Context } from 'node:vm' - export type { ErrorWithDiff, ParsedStack } from '@vitest/utils' export type Awaitable = T | PromiseLike @@ -24,7 +22,7 @@ export interface EnvironmentReturn { } export interface VmEnvironmentReturn { - getVmContext(): Context + getVmContext(): Record teardown(): Awaitable } From eb3a5a216e07597a15148411ffdeaaca136f0a3c Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Mon, 19 Jun 2023 12:10:20 +0200 Subject: [PATCH 33/87] chore: remove import.meta.resolve from vite-node deps --- packages/vitest/src/runtime/external-executor.ts | 12 ++++++------ pnpm-lock.yaml | 10 +++------- 2 files changed, 9 insertions(+), 13 deletions(-) diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index 21744a5fb243..f612014d5edc 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -112,17 +112,17 @@ export class ExternalModulesExecutor { return `module.exports = ${code}` } - importModuleDynamically = async (specifier: string, referencer: VMModule) => { + public importModuleDynamically = async (specifier: string, referencer: VMModule) => { const module = await this.resolveModule(specifier, referencer) return this.evaluateModule(module) } - resolveModule = async (specifier: string, referencer: VMModule) => { + private resolveModule = async (specifier: string, referencer: VMModule) => { const identifier = await this.resolveAsync(specifier, referencer.identifier) return await this.createModule(identifier) } - async resolveAsync(specifier: string, parent: string) { + private async resolveAsync(specifier: string, parent: string) { return resolveModule(specifier, parent) } @@ -146,7 +146,7 @@ export class ExternalModulesExecutor { return m } - async evaluateModule(m: T): Promise { + private async evaluateModule(m: T): Promise { if (m.status === 'unlinked') { this.esmLinkMap.set( m, @@ -233,7 +233,7 @@ export class ExternalModulesExecutor { } } - async createEsmModule(fileUrl: string, code: string) { + private async createEsmModule(fileUrl: string, code: string) { const cached = this.moduleCache.get(fileUrl) if (cached) return cached @@ -275,7 +275,7 @@ export class ExternalModulesExecutor { return code.match(/data:text\/javascript;.*,(.*)/)?.[1] } - async createModule(identifier: string): Promise { + private async createModule(identifier: string): Promise { const extension = extname(identifier) if (extension === '.node' || isNodeBuiltin(identifier)) { diff --git a/pnpm-lock.yaml b/pnpm-lock.yaml index 280180633bd7..381530a54b87 100644 --- a/pnpm-lock.yaml +++ b/pnpm-lock.yaml @@ -1238,9 +1238,6 @@ importers: '@types/debug': specifier: ^4.1.7 version: 4.1.7 - import-meta-resolve: - specifier: ^2.2.2 - version: 2.2.2 rollup: specifier: ^2.79.1 version: 2.79.1 @@ -11649,10 +11646,8 @@ packages: dotenv: 16.0.3 giget: 1.1.2 jiti: 1.18.2 - mlly: 1.4.0 - ohash: 1.1.2 + mlly: 1.3.0 pathe: 1.1.1 - perfect-debounce: 0.1.3 pkg-types: 1.0.3 rc9: 2.1.0 transitivePeerDependencies: @@ -16525,6 +16520,7 @@ packages: /import-meta-resolve@2.2.2: resolution: {integrity: sha512-f8KcQ1D80V7RnqVm+/lirO9zkOxjGxhaTC1IPrBGd3MEfNgmNG67tSUO9gTi2F3Blr2Az6g1vocaxzkVnWl9MA==} + dev: false /import-meta-resolve@3.0.0: resolution: {integrity: sha512-4IwhLhNNA8yy445rPjD/lWh++7hMDOml2eHtd58eG7h+qK3EryMuuRbsHGPikCoAgIkkDnckKfWSk2iDla/ejg==} @@ -20472,7 +20468,7 @@ packages: dependencies: jsonc-parser: 3.2.0 mlly: 1.3.0 - pathe: 1.1.0 + pathe: 1.1.1 /pkg-types@1.0.3: resolution: {integrity: sha512-nN7pYi0AQqJnoLPC9eHFQ8AcyaixBUOwvqc5TDnIKCMEE6I0y8P7OKA7fPexsXGCGxQDl/cmrLAp26LhcwxZ4A==} From da29e4c6d24ddbac57eb5252a549eb6ab1d3482d Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Mon, 19 Jun 2023 12:12:07 +0200 Subject: [PATCH 34/87] chore: fix types --- packages/vitest/src/types/general.ts | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/packages/vitest/src/types/general.ts b/packages/vitest/src/types/general.ts index 826bd71477bc..6ca86146f7ef 100644 --- a/packages/vitest/src/types/general.ts +++ b/packages/vitest/src/types/general.ts @@ -22,7 +22,7 @@ export interface EnvironmentReturn { } export interface VmEnvironmentReturn { - getVmContext(): Record + getVmContext(): { [key: string]: any } teardown(): Awaitable } From f08ebaad8fba8d34395c0d3a30fcf05b03a781f4 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Thu, 22 Jun 2023 10:47:59 +0200 Subject: [PATCH 35/87] chore: fix cached vite-node --- packages/vitest/src/runtime/execute.ts | 11 ++++++----- 1 file changed, 6 insertions(+), 5 deletions(-) diff --git a/packages/vitest/src/runtime/execute.ts b/packages/vitest/src/runtime/execute.ts index 4b54d732b030..d4bdbed14f5b 100644 --- a/packages/vitest/src/runtime/execute.ts +++ b/packages/vitest/src/runtime/execute.ts @@ -9,6 +9,7 @@ import type { MockMap } from '../types/mocker' import type { ContextRPC, Environment, ResolvedConfig, ResolvedTestEnvironment, WorkerGlobalState } from '../types' import { distDir } from '../paths' import { loadEnvironment } from '../integrations/env' +import { getWorkerState } from '../utils/global' import { VitestMocker } from './mocker' import { ExternalModulesExecutor } from './external-executor' @@ -65,7 +66,7 @@ export interface ContextExecutorOptions { export async function startVitestExecutor(ctx: ContextRPC, options: ContextExecutorOptions) { const { config } = ctx - const rpc = () => options.state.rpc + const rpc = () => getWorkerState().rpc const processExit = process.exit @@ -103,10 +104,10 @@ export async function startVitestExecutor(ctx: ContextRPC, options: ContextExecu }, moduleCache, mockMap, - interopDefault: config.deps.interopDefault, - moduleDirectories: config.deps.moduleDirectories, - root: config.root, - base: config.base, + get interopDefault() { return config.deps.interopDefault }, + get moduleDirectories() { return config.deps.moduleDirectories }, + get root() { return config.root }, + get base() { return config.base }, ...options, }) } From 8ca3a1e6ba4fca9e153f8bfc74aed7654716a257 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Thu, 22 Jun 2023 11:22:26 +0200 Subject: [PATCH 36/87] chore: fix lockfile --- pnpm-lock.yaml | 159 ++++++++++++++++--------------------------------- 1 file changed, 52 insertions(+), 107 deletions(-) diff --git a/pnpm-lock.yaml b/pnpm-lock.yaml index 381530a54b87..1643a0aba4d3 100644 --- a/pnpm-lock.yaml +++ b/pnpm-lock.yaml @@ -328,7 +328,7 @@ importers: version: 20.3.1 '@types/react': specifier: latest - version: 18.2.12 + version: 18.2.13 '@vitejs/plugin-react': specifier: latest version: 4.0.3(vite@4.3.9) @@ -615,7 +615,7 @@ importers: version: 18.0.8 '@vitejs/plugin-react': specifier: latest - version: 4.0.0(vite@4.3.9) + version: 4.0.1(vite@4.3.9) '@vitest/coverage-c8': specifier: ^0.24.5 version: 0.24.5 @@ -673,7 +673,7 @@ importers: version: 22.1.0 msw: specifier: ^1.2.1 - version: 1.2.1(typescript@5.0.4) + version: 1.2.1(typescript@5.1.3) vite: specifier: ^4.3.9 version: 4.3.9(@types/node@18.16.19) @@ -804,7 +804,7 @@ importers: version: 22.1.0 unplugin-auto-import: specifier: latest - version: 0.16.4(rollup@3.20.2) + version: 0.16.4(@vueuse/core@10.2.0)(rollup@3.20.2) unplugin-vue-components: specifier: latest version: 0.25.1(rollup@3.20.2)(vue@3.3.4) @@ -1236,8 +1236,11 @@ importers: specifier: ^0.3.18 version: 0.3.18 '@types/debug': - specifier: ^4.1.7 - version: 4.1.7 + specifier: ^4.1.8 + version: 4.1.8 + import-meta-resolve: + specifier: ^2.2.2 + version: 2.2.2 rollup: specifier: ^2.79.1 version: 2.79.1 @@ -2446,8 +2449,8 @@ packages: semver: 6.3.0 dev: true - /@babel/helper-compilation-targets@7.21.4(@babel/core@7.20.5): - resolution: {integrity: sha512-Fa0tTuOXZ1iL8IeDFUWCzjZcn+sJGd9RZdH9esYVjEejGmzf+FFYQpMi/kZUk2kPy/q1H3/GPw7np8qar/stfg==} + /@babel/helper-compilation-targets@7.22.5(@babel/core@7.20.5): + resolution: {integrity: sha512-Ji+ywpHeuqxB8WDxraCiqR0xfhYjiDE/e6k7FuIaANnoOFxAHskHChz4vA1mJC9Lbm01s1PVAGhQY4FUKSkGZw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0 @@ -4252,7 +4255,7 @@ packages: '@babel/plugin-transform-react-jsx': 7.19.0(@babel/core@7.18.13) dev: true - /@babel/plugin-transform-react-jsx-development@7.18.6(@babel/core@7.21.4): + /@babel/plugin-transform-react-jsx-development@7.18.6(@babel/core@7.22.5): resolution: {integrity: sha512-SA6HEjwYFKF7WDjWcMcMGUimmw/nhNRDWxr+KaLSCrkD/LMDBvWRmHAYgE1HDeF8KUuI8OAu+RT6EOtKxSW2qA==} engines: {node: '>=6.9.0'} peerDependencies: @@ -4272,8 +4275,8 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-react-jsx-self@7.21.0(@babel/core@7.21.4): - resolution: {integrity: sha512-f/Eq+79JEu+KUANFks9UZCcvydOOGMgF7jBrcwjHa5jTZD8JivnhCJYvmlhR/WTXBWonDExPoW0eO/CR4QJirA==} + /@babel/plugin-transform-react-jsx-self@7.22.5(@babel/core@7.22.5): + resolution: {integrity: sha512-nTh2ogNUtxbiSbxaT4Ds6aXnXEipHweN9YRgOX/oNXdf0cCrGn/+2LozFa3lnPV5D90MkjhgckCPBrsoSc1a7g==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 @@ -4292,8 +4295,8 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-react-jsx-source@7.19.6(@babel/core@7.21.4): - resolution: {integrity: sha512-RpAi004QyMNisst/pvSanoRdJ4q+jMCWyk9zdw/CyLB9j8RXEahodR6l2GyttDRyEVWZtbN+TpLiHJ3t34LbsQ==} + /@babel/plugin-transform-react-jsx-source@7.22.5(@babel/core@7.22.5): + resolution: {integrity: sha512-yIiRO6yobeEIaI0RTbIr8iAK9FcBHLtZq0S89ZPjDLQXBA4xvghaKqI0etp/tF3htTM0sazJKKLz9oEiGRtu7w==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 @@ -4330,7 +4333,7 @@ packages: '@babel/types': 7.22.5 dev: true - /@babel/plugin-transform-react-jsx@7.19.0(@babel/core@7.21.4): + /@babel/plugin-transform-react-jsx@7.19.0(@babel/core@7.22.5): resolution: {integrity: sha512-UVEvX3tXie3Szm3emi1+G63jyw1w5IcMY0FSKM+CRnKRI5Mr1YbCNgsSTwoTwKphQEG9P+QqmuRFneJPZuHNhg==} engines: {node: '>=6.9.0'} peerDependencies: @@ -8346,8 +8349,8 @@ packages: magic-string: 0.27.0 svelte: 3.59.1 svelte-hmr: 0.15.1(svelte@3.59.1) - vite: 4.3.9(@types/node@18.16.3) - vitefu: 0.2.4(vite@4.3.9) + vite: 4.3.9(@types/node@18.16.18) + vitefu: 0.2.3(vite@4.3.9) transitivePeerDependencies: - supports-color dev: true @@ -8665,7 +8668,7 @@ packages: resolution: {integrity: sha512-xryQlOEIe1TduDWAOphR0ihfebKFSWOXpIsk+70JskCfRfW+xALdnJ0r1ZOTo85F9Qsjk6vtlU7edTYHbls9tA==} dependencies: '@types/cheerio': 0.22.31 - '@types/react': 18.2.12 + '@types/react': 18.2.13 dev: true /@types/eslint-scope@3.7.4: @@ -8913,19 +8916,19 @@ packages: /@types/react-dom@18.0.6: resolution: {integrity: sha512-/5OFZgfIPSwy+YuIBP/FgJnQnsxhZhjjrnxudMddeblOouIodEQ75X14Rr4wGSG/bknL+Omy9iWlLo1u/9GzAA==} dependencies: - '@types/react': 18.2.12 + '@types/react': 18.2.13 dev: true /@types/react-dom@18.0.8: resolution: {integrity: sha512-C3GYO0HLaOkk9dDAz3Dl4sbe4AKUGTCfFIZsz3n/82dPNN8Du533HzKatDxeUYWu24wJgMP1xICqkWk1YOLOIw==} dependencies: - '@types/react': 18.2.12 + '@types/react': 18.2.13 dev: true /@types/react-is@17.0.3: resolution: {integrity: sha512-aBTIWg1emtu95bLTLx0cpkxwGW3ueZv71nE2YFBpL8k/z5czEW8yYpOo8Dp+UUAFAtKwNaOsh/ioSeQnWlZcfw==} dependencies: - '@types/react': 18.2.12 + '@types/react': 18.2.13 dev: false /@types/react-test-renderer@17.0.2: @@ -8937,7 +8940,7 @@ packages: /@types/react-transition-group@4.4.5: resolution: {integrity: sha512-juKD/eiSM3/xZYzjuzH6ZwpP+/lejltmiS3QEzV/vmb/Q8+HfDmxu+Baga8UEMGBqV88Nbg4l2hY/K2DkyaLLA==} dependencies: - '@types/react': 18.2.12 + '@types/react': 18.2.13 dev: false /@types/react@17.0.49: @@ -8956,8 +8959,8 @@ packages: csstype: 3.1.0 dev: true - /@types/react@18.2.12: - resolution: {integrity: sha512-ndmBMLCgn38v3SntMeoJaIrO6tGHYKMEBohCUmw8HoLLQdRMOIGXfeYaBTLe2lsFaSB3MOK1VXscYFnmLtTSmw==} + /@types/react@18.2.13: + resolution: {integrity: sha512-vJ+zElvi/Zn9cVXB5slX2xL8PZodPCwPRDpittQdw43JR2AJ5k3vKdgJJyneV/cYgIbLQUwXa9JVDvUZXGba+Q==} dependencies: '@types/prop-types': 15.7.5 '@types/scheduler': 0.16.2 @@ -9532,8 +9535,8 @@ packages: - supports-color dev: true - /@vitejs/plugin-react@4.0.0(vite@4.3.9): - resolution: {integrity: sha512-HX0XzMjL3hhOYm+0s95pb0Z7F8O81G7joUHgfDd/9J/ZZf5k4xX6QAMFkKsHFxaHlf6X7GD7+XuaZ66ULiJuhQ==} + /@vitejs/plugin-react@4.0.1(vite@4.3.9): + resolution: {integrity: sha512-g25lL98essfeSj43HJ0o4DMp0325XK0ITkxpgChzJU/CyemgyChtlxfnRbjfwxDGCTRxTiXtQAsdebQXKMRSOA==} engines: {node: ^14.18.0 || >=16.0.0} peerDependencies: vite: ^4.2.0 @@ -11647,7 +11650,9 @@ packages: giget: 1.1.2 jiti: 1.18.2 mlly: 1.3.0 + ohash: 1.1.2 pathe: 1.1.1 + perfect-debounce: 0.1.3 pkg-types: 1.0.3 rc9: 2.1.0 transitivePeerDependencies: @@ -15757,7 +15762,7 @@ packages: defu: 6.1.2 https-proxy-agent: 5.0.1 mri: 1.2.0 - node-fetch-native: 1.1.0 + node-fetch-native: 1.2.0 pathe: 1.1.1 tar: 6.1.13 transitivePeerDependencies: @@ -16520,7 +16525,6 @@ packages: /import-meta-resolve@2.2.2: resolution: {integrity: sha512-f8KcQ1D80V7RnqVm+/lirO9zkOxjGxhaTC1IPrBGd3MEfNgmNG67tSUO9gTi2F3Blr2Az6g1vocaxzkVnWl9MA==} - dev: false /import-meta-resolve@3.0.0: resolution: {integrity: sha512-4IwhLhNNA8yy445rPjD/lWh++7hMDOml2eHtd58eG7h+qK3EryMuuRbsHGPikCoAgIkkDnckKfWSk2iDla/ejg==} @@ -19175,18 +19179,10 @@ packages: hasBin: true dev: true - /mlly@1.2.0: - resolution: {integrity: sha512-+c7A3CV0KGdKcylsI6khWyts/CYrGTrRVo4R/I7u/cUsy0Conxa6LUhiEzVKIw14lc2L5aiO4+SeVe4TeGRKww==} - dependencies: - acorn: 8.8.2 - pathe: 1.1.0 - pkg-types: 1.0.2 - ufo: 1.1.1 - /mlly@1.3.0: resolution: {integrity: sha512-HT5mcgIQKkOrZecOjOX3DJorTikWXwsBfpcr/MGBkhfWcjiqvnaL/9ppxvIUXfjT6xt4DVIAsN9fMUz1ev4bIw==} dependencies: - acorn: 8.8.2 + acorn: 8.9.0 pathe: 1.1.1 pkg-types: 1.0.3 ufo: 1.1.2 @@ -19294,7 +19290,7 @@ packages: - supports-color dev: true - /msw@1.2.1(typescript@5.0.4): + /msw@1.2.1(typescript@5.1.3): resolution: {integrity: sha512-bF7qWJQSmKn6bwGYVPXOxhexTCGD5oJSZg8yt8IBClxvo3Dx/1W0zqE1nX9BSWmzRsCKWfeGWcB/vpqV6aclpw==} engines: {node: '>=14'} hasBin: true @@ -19323,7 +19319,7 @@ packages: path-to-regexp: 6.2.1 strict-event-emitter: 0.4.6 type-fest: 2.19.0 - typescript: 5.0.4 + typescript: 5.1.3 yargs: 17.7.1 transitivePeerDependencies: - encoding @@ -20308,9 +20304,6 @@ packages: /pathe@1.1.1: resolution: {integrity: sha512-d+RQGp0MAYTIaDBIMmOfMwz3E+LOZnxx1HZd5R18mmCZY0QBlK0LDZfPc8FW8Ed2DlvsuE6PRjroDY+wg4+j/Q==} - /pathe@1.1.1: - resolution: {integrity: sha512-d+RQGp0MAYTIaDBIMmOfMwz3E+LOZnxx1HZd5R18mmCZY0QBlK0LDZfPc8FW8Ed2DlvsuE6PRjroDY+wg4+j/Q==} - /pathval@1.1.1: resolution: {integrity: sha512-Dp6zGqpTdETdR63lehJYPeIOqpiNBNtc7BpWSLrOje7UaIsE5aY92r/AunQA7rsXvet3lrJ3JnZX29UPTKXyKQ==} dev: false @@ -20463,13 +20456,6 @@ packages: find-up: 5.0.0 dev: true - /pkg-types@1.0.2: - resolution: {integrity: sha512-hM58GKXOcj8WTqUXnsQyJYXdeAPbythQgEF3nTcEo+nkD49chjQ9IKm/QJy9xf6JakXptz86h7ecP2024rrLaQ==} - dependencies: - jsonc-parser: 3.2.0 - mlly: 1.3.0 - pathe: 1.1.1 - /pkg-types@1.0.3: resolution: {integrity: sha512-nN7pYi0AQqJnoLPC9eHFQ8AcyaixBUOwvqc5TDnIKCMEE6I0y8P7OKA7fPexsXGCGxQDl/cmrLAp26LhcwxZ4A==} dependencies: @@ -24061,8 +24047,8 @@ packages: vfile: 4.2.1 dev: true - /unimport@3.0.8(rollup@3.20.2): - resolution: {integrity: sha512-AOt6xj3QMwqcTZRPB+NhFkyVEjCKnpTVoPm5x6424zz2NYYtCfym2bpJofzPHIJKPNIh5ko2/t2q46ZIMgdmbw==} + /unimport@3.0.7(rollup@3.20.2): + resolution: {integrity: sha512-2dVQUxJEGcrSZ0U4qtwJVODrlfyGcwmIOoHVqbAFFUx7kPoEN5JWr1cZFhLwoAwTmZOvqAm3YIkzv1engIQocg==} dependencies: '@rollup/pluginutils': 5.0.2(rollup@3.26.0) escape-string-regexp: 5.0.0 @@ -24251,31 +24237,7 @@ packages: engines: {node: '>= 0.8'} dev: true - /unplugin-auto-import@0.15.3(@vueuse/core@10.1.2)(rollup@3.20.2): - resolution: {integrity: sha512-RLT8SqbPn4bT7yBshZId0uPSofKWnwr66RyDaxWaFb/+f7OTDOWAsVNz+hOQLBWSjvbekr2xZY9ccS8TDHJbCQ==} - engines: {node: '>=14'} - peerDependencies: - '@nuxt/kit': ^3.2.2 - '@vueuse/core': '*' - peerDependenciesMeta: - '@nuxt/kit': - optional: true - '@vueuse/core': - optional: true - dependencies: - '@antfu/utils': 0.7.4 - '@rollup/pluginutils': 5.0.2(rollup@3.20.2) - '@vueuse/core': 10.1.2(vue@3.2.47) - local-pkg: 0.4.3 - magic-string: 0.30.1 - minimatch: 9.0.1 - unimport: 3.0.8(rollup@3.20.2) - unplugin: 1.3.1 - transitivePeerDependencies: - - rollup - dev: true - - /unplugin-auto-import@0.16.4(rollup@3.20.2): + /unplugin-auto-import@0.16.4(@vueuse/core@10.2.0)(rollup@3.20.2): resolution: {integrity: sha512-xdgBa9NAS3JG8HjkAZHSbGSMlrjKpaWKXGUzaF6RzEtr980RCl1t0Zsu0skUInNYrEQfqaHc7aGWPv41DLTK/w==} engines: {node: '>=14'} peerDependencies: @@ -24289,10 +24251,11 @@ packages: dependencies: '@antfu/utils': 0.7.4 '@rollup/pluginutils': 5.0.2(rollup@3.20.2) + '@vueuse/core': 10.2.0(vue@3.3.4) local-pkg: 0.4.3 magic-string: 0.30.0 minimatch: 9.0.1 - unimport: 3.0.8(rollup@3.20.2) + unimport: 3.0.7(rollup@3.20.2) unplugin: 1.3.1 transitivePeerDependencies: - rollup @@ -24327,35 +24290,6 @@ packages: - supports-color dev: true - /unplugin-vue-components@0.24.1(rollup@3.20.2)(vue@3.2.47): - resolution: {integrity: sha512-T3A8HkZoIE1Cja95xNqolwza0yD5IVlgZZ1PVAGvVCx8xthmjsv38xWRCtHtwl+rvZyL9uif42SRkDGw9aCfMA==} - engines: {node: '>=14'} - peerDependencies: - '@babel/parser': ^7.15.8 - '@nuxt/kit': ^3.2.2 - vue: 2 || 3 - peerDependenciesMeta: - '@babel/parser': - optional: true - '@nuxt/kit': - optional: true - dependencies: - '@antfu/utils': 0.7.4 - '@rollup/pluginutils': 5.0.2(rollup@3.26.0) - chokidar: 3.5.3 - debug: 4.3.4(supports-color@8.1.1) - fast-glob: 3.3.0 - local-pkg: 0.4.3 - magic-string: 0.30.0 - minimatch: 7.4.2 - resolve: 1.22.2 - unplugin: 1.3.1 - vue: 3.2.47 - transitivePeerDependencies: - - rollup - - supports-color - dev: true - /unplugin-vue-components@0.25.1(rollup@3.20.2)(vue@3.3.4): resolution: {integrity: sha512-kzS2ZHVMaGU2XEO2keYQcMjNZkanDSGDdY96uQT9EPe+wqSZwwgbFfKVJ5ti0+8rGAcKHColwKUvctBhq2LJ3A==} engines: {node: '>=14'} @@ -24682,8 +24616,8 @@ packages: merge-anything: 5.1.4 solid-js: 1.5.2 solid-refresh: 0.4.1(solid-js@1.5.2) - vite: 4.3.9(@types/node@18.16.3) - vitefu: 0.2.4(vite@4.3.9) + vite: 4.3.9(@types/node@18.16.18) + vitefu: 0.2.3(vite@4.3.9) transitivePeerDependencies: - supports-color dev: true @@ -24786,6 +24720,17 @@ packages: fsevents: 2.3.2 dev: true + /vitefu@0.2.3(vite@4.3.9): + resolution: {integrity: sha512-75l7TTuU8isAhz1QFtNKjDkqjxvndfMC1AfIMjJ0ZQ59ZD0Ow9QOIsJJX16Wv9PS8f+zMzp6fHy5cCbKG/yVUQ==} + peerDependencies: + vite: ^3.0.0 || ^4.0.0 + peerDependenciesMeta: + vite: + optional: true + dependencies: + vite: 4.3.9(@types/node@18.16.18) + dev: true + /vitefu@0.2.4(vite@4.3.9): resolution: {integrity: sha512-fanAXjSaf9xXtOOeno8wZXIhgia+CZury481LsDaV++lSvcU2R9Ch2bPh3PYFyoHW+w9LqAeYRISVQjUIew14g==} peerDependencies: From 6efb22548d5067b115bd0517613e3744003cb82f Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Thu, 22 Jun 2023 11:34:02 +0200 Subject: [PATCH 37/87] chore: cleanup --- packages/vitest/src/runtime/execute.ts | 2 +- packages/vitest/src/runtime/external-executor.ts | 2 ++ packages/vitest/src/utils/memory-limit.ts | 2 +- 3 files changed, 4 insertions(+), 2 deletions(-) diff --git a/packages/vitest/src/runtime/execute.ts b/packages/vitest/src/runtime/execute.ts index d4bdbed14f5b..3a5921f78619 100644 --- a/packages/vitest/src/runtime/execute.ts +++ b/packages/vitest/src/runtime/execute.ts @@ -66,7 +66,7 @@ export interface ContextExecutorOptions { export async function startVitestExecutor(ctx: ContextRPC, options: ContextExecutorOptions) { const { config } = ctx - const rpc = () => getWorkerState().rpc + const rpc = () => getWorkerState()?.rpc || options.state.rpc const processExit = process.exit diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index f612014d5edc..6a5df9e9d06d 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -1,3 +1,5 @@ +/* eslint-disable antfu/no-cjs-exports */ + import vm from 'node:vm' import { fileURLToPath, pathToFileURL } from 'node:url' import { dirname } from 'node:path' diff --git a/packages/vitest/src/utils/memory-limit.ts b/packages/vitest/src/utils/memory-limit.ts index 9b428463bca1..581b19f8c68f 100644 --- a/packages/vitest/src/utils/memory-limit.ts +++ b/packages/vitest/src/utils/memory-limit.ts @@ -34,7 +34,7 @@ export function stringToBytes( return input if (typeof input === 'string') { - if (isNaN(Number.parseFloat(input.slice(-1)))) { + if (Number.isNaN(Number.parseFloat(input.slice(-1)))) { let [, numericString, trailingChars] = input.match(/(.*?)([^0-9.-]+)$/i) || [] From ee3a95c4586cb5d09e4288b7a82c996c959fda40 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Thu, 22 Jun 2023 11:51:38 +0200 Subject: [PATCH 38/87] chore: cleanup --- packages/vitest/src/integrations/env/index.ts | 9 ++--- packages/vitest/src/integrations/env/jsdom.ts | 2 +- packages/vitest/src/runtime/child.ts | 2 +- packages/vitest/src/runtime/entry.ts | 2 +- packages/vitest/src/runtime/environment.ts | 21 ------------ packages/vitest/src/runtime/execute.ts | 34 ++++++++----------- packages/vitest/src/runtime/setup.node.ts | 12 +++---- packages/vitest/src/runtime/vm.ts | 17 +++++++--- packages/vitest/src/runtime/worker.ts | 19 +++++++---- packages/vitest/src/types/rpc.ts | 3 +- packages/vitest/src/types/worker.ts | 5 +-- 11 files changed, 56 insertions(+), 70 deletions(-) delete mode 100644 packages/vitest/src/runtime/environment.ts diff --git a/packages/vitest/src/integrations/env/index.ts b/packages/vitest/src/integrations/env/index.ts index 0cbd7261df8d..081e68059109 100644 --- a/packages/vitest/src/integrations/env/index.ts +++ b/packages/vitest/src/integrations/env/index.ts @@ -1,5 +1,6 @@ +import { pathToFileURL } from 'node:url' +import { resolve } from 'pathe' import type { BuiltinEnvironment, VitestEnvironment } from '../../types/config' -import type { VitestExecutor } from '../../node' import type { Environment } from '../../types' import node from './node' import jsdom from './jsdom' @@ -33,11 +34,11 @@ export function getEnvPackageName(env: VitestEnvironment) { return `vitest-environment-${env}` } -export async function loadEnvironment(name: VitestEnvironment, executor: VitestExecutor): Promise { +export async function loadEnvironment(name: VitestEnvironment, root: string): Promise { if (isBuiltinEnvironment(name)) return environments[name] - const packageId = (name[0] === '.' || name[0] === '/') ? name : `vitest-environment-${name}` - const pkg = await executor.executeId(packageId) + const packageId = (name[0] === '.' || name[0] === '/') ? resolve(root, name) : `vitest-environment-${name}` + const pkg = await import(pathToFileURL(packageId).href) if (!pkg || !pkg.default || typeof pkg.default !== 'object' || typeof pkg.default.setup !== 'function') { throw new Error( `Environment "${name}" is not a valid environment. ` diff --git a/packages/vitest/src/integrations/env/jsdom.ts b/packages/vitest/src/integrations/env/jsdom.ts index 2f7c1b8090bb..2e1c08c0c800 100644 --- a/packages/vitest/src/integrations/env/jsdom.ts +++ b/packages/vitest/src/integrations/env/jsdom.ts @@ -56,7 +56,7 @@ export default ({ resources: resources ?? (userAgent ? new ResourceLoader({ userAgent }) : undefined), runScripts, url, - virtualConsole: (console && global.console) ? new VirtualConsole().sendTo(global.console) : undefined, + virtualConsole: (console && globalThis.console) ? new VirtualConsole().sendTo(globalThis.console) : undefined, cookieJar: cookieJar ? new CookieJar() : undefined, includeNodeLocations, contentType, diff --git a/packages/vitest/src/runtime/child.ts b/packages/vitest/src/runtime/child.ts index 12abf7c30bab..967a10844a4f 100644 --- a/packages/vitest/src/runtime/child.ts +++ b/packages/vitest/src/runtime/child.ts @@ -82,7 +82,7 @@ export async function run(ctx: ChildContext) { try { const state = init(ctx) - const { run, executor } = await startViteNode(ctx, { + const { run, executor } = await startViteNode({ state, }) await run(ctx.files, ctx.config, ctx.environment, executor) diff --git a/packages/vitest/src/runtime/entry.ts b/packages/vitest/src/runtime/entry.ts index fdd8d61df173..0dffd3f2b648 100644 --- a/packages/vitest/src/runtime/entry.ts +++ b/packages/vitest/src/runtime/entry.ts @@ -24,7 +24,7 @@ export async function run(files: string[], config: ResolvedConfig, environment: workerState.durations.prepare = performance.now() - workerState.durations.prepare - workerState.environment = environment.name + workerState.environment = environment.environment workerState.durations.environment = performance.now() diff --git a/packages/vitest/src/runtime/environment.ts b/packages/vitest/src/runtime/environment.ts deleted file mode 100644 index 06b5e66cc289..000000000000 --- a/packages/vitest/src/runtime/environment.ts +++ /dev/null @@ -1,21 +0,0 @@ -import { environments } from '../integrations/env' -import type { Environment } from '../types' - -export async function loadEnvironment(name: string, method: 'setup' | 'setupVM'): Promise { - if (name in environments) - return environments[name as 'jsdom'] - const pkg = await import(`vitest-environment-${name}`) - if (!pkg || !pkg.default || typeof pkg.default !== 'object') { - throw new Error( - `Environment "${name}" is not a valid environment. ` - + `Package "vitest-environment-${name}" should have default export with "${method}" method.`, - ) - } - if (typeof pkg.default[method] !== 'function') { - throw new TypeError( - `Environment "${name}" is not a valid environment. ` - + `Package "vitest-environment-${name}" doesn't support ${method === 'setupVM' ? 'vm' : 'non-vm'} environment because it doesn't provide "${method}" method.`, - ) - } - return pkg.default -} diff --git a/packages/vitest/src/runtime/execute.ts b/packages/vitest/src/runtime/execute.ts index 3a5921f78619..ba1499b724a3 100644 --- a/packages/vitest/src/runtime/execute.ts +++ b/packages/vitest/src/runtime/execute.ts @@ -6,9 +6,8 @@ import type { ViteNodeRunnerOptions } from 'vite-node' import { normalize, relative, resolve } from 'pathe' import { processError } from '@vitest/utils/error' import type { MockMap } from '../types/mocker' -import type { ContextRPC, Environment, ResolvedConfig, ResolvedTestEnvironment, WorkerGlobalState } from '../types' +import type { ResolvedConfig, ResolvedTestEnvironment, WorkerGlobalState } from '../types' import { distDir } from '../paths' -import { loadEnvironment } from '../integrations/env' import { getWorkerState } from '../utils/global' import { VitestMocker } from './mocker' import { ExternalModulesExecutor } from './external-executor' @@ -34,24 +33,20 @@ export async function createVitestExecutor(options: ExecuteOptions) { let _viteNode: { run: (files: string[], config: ResolvedConfig, environment: ResolvedTestEnvironment, executor: VitestExecutor) => Promise executor: VitestExecutor - environment: Environment } export const moduleCache = new ModuleCacheMap() export const mockMap: MockMap = new Map() -export async function startViteNode(ctx: ContextRPC, options: ContextExecutorOptions) { +export async function startViteNode(options: ContextExecutorOptions) { if (_viteNode) return _viteNode - const executor = await startVitestExecutor(ctx, options) - - const environment = await loadEnvironment(ctx.environment.name, executor) - ctx.environment.environment = environment + const executor = await startVitestExecutor(options) const { run } = await import(entryUrl) - _viteNode = { run, executor, environment } + _viteNode = { run, executor } return _viteNode } @@ -63,10 +58,9 @@ export interface ContextExecutorOptions { state: WorkerGlobalState } -export async function startVitestExecutor(ctx: ContextRPC, options: ContextExecutorOptions) { - const { config } = ctx - - const rpc = () => getWorkerState()?.rpc || options.state.rpc +export async function startVitestExecutor(options: ContextExecutorOptions) { + const state = () => getWorkerState() || options.state + const rpc = () => state().rpc const processExit = process.exit @@ -82,7 +76,7 @@ export async function startVitestExecutor(ctx: ContextRPC, options: ContextExecu if (!isPrimitive(error)) { error.VITEST_TEST_NAME = worker.current?.name if (worker.filepath) - error.VITEST_TEST_PATH = relative(config.root, worker.filepath) + error.VITEST_TEST_PATH = relative(state().config.root, worker.filepath) error.VITEST_AFTER_ENV_TEARDOWN = worker.environmentTeardownRun } rpc().onUnhandledError(error, type) @@ -92,7 +86,7 @@ export async function startVitestExecutor(ctx: ContextRPC, options: ContextExecu process.on('unhandledRejection', e => catchError(e, 'Unhandled Rejection')) const getTransformMode = () => { - return ctx.environment.transformMode ?? ctx.environment.environment?.transformMode ?? 'ssr' + return state().environment.transformMode ?? 'ssr' } return await createVitestExecutor({ @@ -104,10 +98,10 @@ export async function startVitestExecutor(ctx: ContextRPC, options: ContextExecu }, moduleCache, mockMap, - get interopDefault() { return config.deps.interopDefault }, - get moduleDirectories() { return config.deps.moduleDirectories }, - get root() { return config.root }, - get base() { return config.base }, + get interopDefault() { return state().config.deps.interopDefault }, + get moduleDirectories() { return state().config.deps.moduleDirectories }, + get root() { return state().config.root }, + get base() { return state().config.base }, ...options, }) } @@ -140,7 +134,7 @@ export class VitestExecutor extends ViteNodeRunner { shouldResolveId(id: string, _importee?: string | undefined): boolean { if (isInternalRequest(id) || id.startsWith('data:')) return false - const environment = this.options.state.environment + const environment = this.options.state.environment.name // do not try and resolve node builtins in Node // import('url') returns Node internal even if 'url' package is installed return environment === 'node' ? !isNodeBuiltin(id) : !id.startsWith('node:') diff --git a/packages/vitest/src/runtime/setup.node.ts b/packages/vitest/src/runtime/setup.node.ts index 9675adbafbcd..2e1a1aa3ee89 100644 --- a/packages/vitest/src/runtime/setup.node.ts +++ b/packages/vitest/src/runtime/setup.node.ts @@ -2,7 +2,7 @@ import { createRequire } from 'node:module' import { isatty } from 'node:tty' import { installSourcemapsSupport } from 'vite-node/source-map' import { createColors, setupColors } from '@vitest/utils' -import type { ContextTestEnvironment, EnvironmentOptions, ResolvedConfig, ResolvedTestEnvironment, WorkerGlobalState } from '../types' +import type { EnvironmentOptions, ResolvedConfig, ResolvedTestEnvironment, WorkerGlobalState } from '../types' import { VitestSnapshotEnvironment } from '../integrations/snapshot/environments/node' import { getSafeTimers, getWorkerState } from '../utils' import * as VitestIndex from '../index' @@ -11,7 +11,7 @@ import { setupCommonEnv } from './setup.common' // this should only be used in Node let globalSetup = false -export async function setupGlobalEnv(config: ResolvedConfig, environment: ContextTestEnvironment) { +export async function setupGlobalEnv(config: ResolvedConfig, { environment }: ResolvedTestEnvironment) { await setupCommonEnv(config) Object.defineProperty(globalThis, '__vitest_index__', { @@ -30,7 +30,7 @@ export async function setupGlobalEnv(config: ResolvedConfig, environment: Contex globalSetup = true setupColors(createColors(isatty(1))) - if (environment.name !== 'node') { + if (environment.transformMode === 'web') { const _require = createRequire(import.meta.url) // always mock "required" `css` files, because we cannot process them _require.extensions['.css'] = () => ({}) @@ -53,14 +53,14 @@ export async function setupConsoleLogSpy(state: WorkerGlobalState) { } export async function withEnv( - { environment, name }: ResolvedTestEnvironment, + { environment }: ResolvedTestEnvironment, options: EnvironmentOptions, fn: () => Promise, ) { // @ts-expect-error untyped global - globalThis.__vitest_environment__ = name + globalThis.__vitest_environment__ = environment.name expect.setState({ - environment: name, + environment: environment.name, }) const env = await environment.setup(globalThis, options) try { diff --git a/packages/vitest/src/runtime/vm.ts b/packages/vitest/src/runtime/vm.ts index 829ba132c2c3..7c3bcae9ae1c 100644 --- a/packages/vitest/src/runtime/vm.ts +++ b/packages/vitest/src/runtime/vm.ts @@ -8,9 +8,9 @@ import { installSourcemapsSupport } from 'vite-node/source-map' import type { CancelReason } from '@vitest/runner' import type { RuntimeRPC, WorkerContext, WorkerGlobalState } from '../types' import { distDir } from '../paths' +import { loadEnvironment } from '../integrations/env' import { startVitestExecutor } from './execute' import { createCustomConsole } from './console' -import { loadEnvironment } from './environment' import { createSafeRpc } from './rpc' const entryFile = pathToFileURL(resolve(distDir, 'entry-vm.js')).href @@ -36,13 +36,22 @@ export async function run(ctx: WorkerContext) { }, ) + const environment = await loadEnvironment(ctx.environment.name, ctx.config.root) + + if (!environment.setupVM) { + throw new TypeError( + `Environment "${ctx.environment.name}" is not a valid environment. ` + + `Package "vitest-environment-${name}" doesn't support vm environment because it doesn't provide "setupVM" method.`, + ) + } + const state: WorkerGlobalState = { ctx, moduleCache, config, mockMap, onCancel, - environment: ctx.environment.name, + environment, durations: { environment: performance.now(), prepare: performance.now(), @@ -54,8 +63,6 @@ export async function run(ctx: WorkerContext) { getSourceMap: source => moduleCache.getSourceMap(source), }) - const environment = await loadEnvironment(ctx.environment.name, 'setupVM') - const vm = await environment.setupVM!(ctx.environment.options || {}) state.durations.environment = performance.now() - state.durations.environment @@ -81,7 +88,7 @@ export async function run(ctx: WorkerContext) { } ctx.files.forEach(i => moduleCache.delete(i)) - const executor = await startVitestExecutor(ctx, { + const executor = await startVitestExecutor({ context, moduleCache, mockMap, diff --git a/packages/vitest/src/runtime/worker.ts b/packages/vitest/src/runtime/worker.ts index 34355cf3c3c9..7bb1118c6d4c 100644 --- a/packages/vitest/src/runtime/worker.ts +++ b/packages/vitest/src/runtime/worker.ts @@ -4,11 +4,12 @@ import { workerId as poolId } from 'tinypool' import type { CancelReason } from '@vitest/runner' import type { RunnerRPC, RuntimeRPC, WorkerContext, WorkerGlobalState } from '../types' import { getWorkerState } from '../utils/global' +import { loadEnvironment } from '../integrations/env' import { mockMap, moduleCache, startViteNode } from './execute' import { setupInspect } from './inspector' import { createSafeRpc, rpcDone } from './rpc' -function init(ctx: WorkerContext) { +async function init(ctx: WorkerContext) { // @ts-expect-error untyped global if (typeof __vitest_worker__ !== 'undefined' && ctx.config.threads && ctx.config.isolate) throw new Error(`worker for ${ctx.files.join(',')} already initialized by ${getWorkerState().ctx.files.join(',')}. This is probably an internal bug of Vitest.`) @@ -34,13 +35,17 @@ function init(ctx: WorkerContext) { }, ) - const state = { + const environment = await loadEnvironment(ctx.environment.name, ctx.config.root) + if (ctx.environment.transformMode) + environment.transformMode = ctx.environment.transformMode + + const state: WorkerGlobalState = { ctx, moduleCache, config, mockMap, onCancel, - environment: ctx.environment.name, + environment, durations: { environment: 0, prepare: performance.now(), @@ -59,16 +64,16 @@ function init(ctx: WorkerContext) { } ctx.files.forEach(i => moduleCache.delete(i)) - return state as WorkerGlobalState + return state } export async function run(ctx: WorkerContext) { const inspectorCleanup = setupInspect(ctx.config) try { - const state = init(ctx) - const { run, executor } = await startViteNode(ctx, { state }) - await run(ctx.files, ctx.config, ctx.environment, executor) + const state = await init(ctx) + const { run, executor } = await startViteNode({ state }) + await run(ctx.files, ctx.config, { environment: state.environment, options: ctx.environment.options }, executor) await rpcDone() } finally { diff --git a/packages/vitest/src/types/rpc.ts b/packages/vitest/src/types/rpc.ts index 6f875b088be9..e3f0f9e5acef 100644 --- a/packages/vitest/src/types/rpc.ts +++ b/packages/vitest/src/types/rpc.ts @@ -39,8 +39,7 @@ export interface ContextTestEnvironment { options: EnvironmentOptions | null } -export interface ResolvedTestEnvironment extends ContextTestEnvironment { - name: VitestEnvironment +export interface ResolvedTestEnvironment { environment: Environment options: EnvironmentOptions | null } diff --git a/packages/vitest/src/types/worker.ts b/packages/vitest/src/types/worker.ts index f5aed5f41499..0657ba6ab0fc 100644 --- a/packages/vitest/src/types/worker.ts +++ b/packages/vitest/src/types/worker.ts @@ -3,8 +3,9 @@ import type { CancelReason, Test } from '@vitest/runner' import type { ModuleCacheMap, ViteNodeResolveId } from 'vite-node' import type { BirpcReturn } from 'birpc' import type { MockMap } from './mocker' -import type { ResolvedConfig, VitestEnvironment } from './config' +import type { ResolvedConfig } from './config' import type { ContextRPC, RuntimeRPC } from './rpc' +import type { Environment } from './general' export interface WorkerContext extends ContextRPC { workerId: number @@ -25,7 +26,7 @@ export interface WorkerGlobalState { rpc: WorkerRPC current?: Test filepath?: string - environment: VitestEnvironment + environment: Environment environmentTeardownRun?: boolean onCancel: Promise moduleCache: ModuleCacheMap From f7aa86909a82bec6e51720f04e7be618193933a9 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Thu, 22 Jun 2023 11:53:41 +0200 Subject: [PATCH 39/87] chore: cleanup --- packages/vitest/src/integrations/env/jsdom.ts | 3 +++ 1 file changed, 3 insertions(+) diff --git a/packages/vitest/src/integrations/env/jsdom.ts b/packages/vitest/src/integrations/env/jsdom.ts index 2e1c08c0c800..6310f00a9d80 100644 --- a/packages/vitest/src/integrations/env/jsdom.ts +++ b/packages/vitest/src/integrations/env/jsdom.ts @@ -64,11 +64,14 @@ export default ({ ...restOptions, }, ) + const clearWindowErrors = catchWindowErrors(dom.window as any) + return { getVmContext() { return dom.getInternalVMContext() }, teardown() { + clearWindowErrors() dom.window.close() }, } From 19b27523fbfceb3483504b7382635bc3f855b3ba Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Thu, 6 Jul 2023 16:09:23 +0200 Subject: [PATCH 40/87] chore: support resolve --- packages/vitest/src/runtime/external-executor.ts | 10 +++++++--- 1 file changed, 7 insertions(+), 3 deletions(-) diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index 6a5df9e9d06d..2805e4d5913b 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -87,6 +87,8 @@ const SourceTextModule: typeof VMSourceTextModule = (vm as any).SourceTextModule const _require = createRequire(import.meta.url) +const nativeResolve = import.meta.resolve + // TODO: improve Node.js strict mode support in #2854 export class ExternalModulesExecutor { private context: vm.Context @@ -247,9 +249,11 @@ export class ExternalModulesExecutor { importModuleDynamically: this.importModuleDynamically, initializeImportMeta: (meta, mod) => { meta.url = mod.identifier - // TODO: improve Node.js support with #2854 - // meta.resolve = (specifier: string, importer?: string) => - // this.resolveAsync(specifier, importer ?? mod.identifier) + if (nativeResolve) { + meta.resolve = (specifier: string, importer?: string) => { + return nativeResolve(specifier, importer ?? mod.identifier) + } + } }, }, ) From dae6c8f673c7389aac3afa13a97ef441ed5823b9 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 11 Jul 2023 12:40:32 +0200 Subject: [PATCH 41/87] chore: cleanup --- packages/vitest/src/runtime/child.ts | 19 +- packages/vitest/src/runtime/entry-vm.ts | 3 +- packages/vitest/src/types/worker.ts | 2 +- packages/vitest/src/utils/global.ts | 2 +- pnpm-lock.yaml | 236 ++++++++++++------------ 5 files changed, 128 insertions(+), 134 deletions(-) diff --git a/packages/vitest/src/runtime/child.ts b/packages/vitest/src/runtime/child.ts index 967a10844a4f..5bdf6cd984ad 100644 --- a/packages/vitest/src/runtime/child.ts +++ b/packages/vitest/src/runtime/child.ts @@ -6,12 +6,13 @@ import type { CancelReason } from '@vitest/runner' import type { ResolvedConfig, WorkerGlobalState } from '../types' import type { RunnerRPC, RuntimeRPC } from '../types/rpc' import type { ChildContext } from '../types/child' +import { loadEnvironment } from '../integrations/env' import { mockMap, moduleCache, startViteNode } from './execute' import { createSafeRpc, rpcDone } from './rpc' import { setupInspect } from './inspector' -function init(ctx: ChildContext) { - const { config, environment } = ctx +async function init(ctx: ChildContext) { + const { config } = ctx process.env.VITEST_WORKER_ID = '1' process.env.VITEST_POOL_ID = '1' @@ -36,13 +37,17 @@ function init(ctx: ChildContext) { }, ) - const state = { + const environment = await loadEnvironment(ctx.environment.name, ctx.config.root) + if (ctx.environment.transformMode) + environment.transformMode = ctx.environment.transformMode + + const state: WorkerGlobalState = { ctx, moduleCache, config, mockMap, onCancel, - environment: config.environment, + environment, durations: { environment: 0, prepare: performance.now(), @@ -61,7 +66,7 @@ function init(ctx: ChildContext) { } ctx.files.forEach(i => moduleCache.delete(i)) - return state as unknown as WorkerGlobalState + return state } function parsePossibleRegexp(str: string | RegExp) { @@ -81,11 +86,11 @@ export async function run(ctx: ChildContext) { const inspectorCleanup = setupInspect(ctx.config) try { - const state = init(ctx) + const state = await init(ctx) const { run, executor } = await startViteNode({ state, }) - await run(ctx.files, ctx.config, ctx.environment, executor) + await run(ctx.files, ctx.config, { environment: state.environment, options: ctx.environment.options }, executor) await rpcDone() } finally { diff --git a/packages/vitest/src/runtime/entry-vm.ts b/packages/vitest/src/runtime/entry-vm.ts index d0e0981e5ce2..72b9b7f2df41 100644 --- a/packages/vitest/src/runtime/entry-vm.ts +++ b/packages/vitest/src/runtime/entry-vm.ts @@ -21,8 +21,7 @@ export async function run(files: string[], config: ResolvedConfig, executor: Vit setupColors(createColors(isatty(1))) - // TODO: look at environment.transformMode when #3491 is merged - if (workerState.environment !== 'node') { + if (workerState.environment.transformMode === 'web') { const _require = createRequire(import.meta.url) // always mock "required" `css` files, because we cannot process them _require.extensions['.css'] = () => ({}) diff --git a/packages/vitest/src/types/worker.ts b/packages/vitest/src/types/worker.ts index 0657ba6ab0fc..7d3c4cde3a6f 100644 --- a/packages/vitest/src/types/worker.ts +++ b/packages/vitest/src/types/worker.ts @@ -21,7 +21,7 @@ export interface AfterSuiteRunMeta { export type WorkerRPC = BirpcReturn export interface WorkerGlobalState { - ctx: WorkerContext + ctx: ContextRPC config: ResolvedConfig rpc: WorkerRPC current?: Test diff --git a/packages/vitest/src/utils/global.ts b/packages/vitest/src/utils/global.ts index 6239d58685fb..ea7398b6eb1e 100644 --- a/packages/vitest/src/utils/global.ts +++ b/packages/vitest/src/utils/global.ts @@ -7,5 +7,5 @@ export function getWorkerState(): WorkerGlobalState { export function getCurrentEnvironment(): string { const state = getWorkerState() - return state?.environment + return state?.environment.name } diff --git a/pnpm-lock.yaml b/pnpm-lock.yaml index 1643a0aba4d3..377fa082f01c 100644 --- a/pnpm-lock.yaml +++ b/pnpm-lock.yaml @@ -325,10 +325,10 @@ importers: version: 13.3.0(react-dom@18.0.0)(react@18.0.0) '@types/node': specifier: latest - version: 20.3.1 + version: 20.4.1 '@types/react': specifier: latest - version: 18.2.13 + version: 18.2.14 '@vitejs/plugin-react': specifier: latest version: 4.0.3(vite@4.3.9) @@ -615,10 +615,10 @@ importers: version: 18.0.8 '@vitejs/plugin-react': specifier: latest - version: 4.0.1(vite@4.3.9) - '@vitest/coverage-c8': - specifier: ^0.24.5 - version: 0.24.5 + version: 4.0.3(vite@4.3.9) + '@vitest/coverage-v8': + specifier: latest + version: link:../../packages/coverage-v8 '@vitest/ui': specifier: latest version: link:../../packages/ui @@ -673,7 +673,7 @@ importers: version: 22.1.0 msw: specifier: ^1.2.1 - version: 1.2.1(typescript@5.1.3) + version: 1.2.1(typescript@5.1.6) vite: specifier: ^4.3.9 version: 4.3.9(@types/node@18.16.19) @@ -804,10 +804,10 @@ importers: version: 22.1.0 unplugin-auto-import: specifier: latest - version: 0.16.4(@vueuse/core@10.2.0)(rollup@3.20.2) + version: 0.16.4(@vueuse/core@10.2.1)(rollup@3.26.0) unplugin-vue-components: specifier: latest - version: 0.25.1(rollup@3.20.2)(vue@3.3.4) + version: 0.25.1(rollup@3.26.0)(vue@3.3.4) vite: specifier: ^4.3.9 version: 4.3.9(@types/node@18.16.19) @@ -4265,16 +4265,6 @@ packages: '@babel/plugin-transform-react-jsx': 7.19.0(@babel/core@7.22.5) dev: true - /@babel/plugin-transform-react-jsx-self@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-A0LQGx4+4Jv7u/tWzoJF7alZwnBDQd6cGLh9P+Ttk4dpiL+J5p7NSNv/9tlEFFJDq3kjxOavWmbm6t0Gk+A3Ig==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - /@babel/plugin-transform-react-jsx-self@7.22.5(@babel/core@7.22.5): resolution: {integrity: sha512-nTh2ogNUtxbiSbxaT4Ds6aXnXEipHweN9YRgOX/oNXdf0cCrGn/+2LozFa3lnPV5D90MkjhgckCPBrsoSc1a7g==} engines: {node: '>=6.9.0'} @@ -4285,16 +4275,6 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-react-jsx-source@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-utZmlASneDfdaMh0m/WausbjUjEdGrQJz0vFK93d7wD3xf5wBtX219+q6IlCNZeguIcxS2f/CvLZrlLSvSHQXw==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - /@babel/plugin-transform-react-jsx-source@7.22.5(@babel/core@7.22.5): resolution: {integrity: sha512-yIiRO6yobeEIaI0RTbIr8iAK9FcBHLtZq0S89ZPjDLQXBA4xvghaKqI0etp/tF3htTM0sazJKKLz9oEiGRtu7w==} engines: {node: '>=6.9.0'} @@ -5868,7 +5848,7 @@ packages: engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: '@jest/types': 27.5.1 - '@types/node': 20.3.1 + '@types/node': 20.4.1 chalk: 4.1.2 jest-message-util: 27.5.1 jest-util: 27.5.1 @@ -5889,7 +5869,7 @@ packages: '@jest/test-result': 27.5.1 '@jest/transform': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.3.1 + '@types/node': 20.4.1 ansi-escapes: 4.3.2 chalk: 4.1.2 emittery: 0.8.1 @@ -5926,7 +5906,7 @@ packages: dependencies: '@jest/fake-timers': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.3.1 + '@types/node': 20.4.1 jest-mock: 27.5.1 dev: true @@ -5943,7 +5923,7 @@ packages: dependencies: '@jest/types': 27.5.1 '@sinonjs/fake-timers': 8.1.0 - '@types/node': 20.3.1 + '@types/node': 20.4.1 jest-message-util: 27.5.1 jest-mock: 27.5.1 jest-util: 27.5.1 @@ -5972,7 +5952,7 @@ packages: '@jest/test-result': 27.5.1 '@jest/transform': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.3.1 + '@types/node': 20.4.1 chalk: 4.1.2 collect-v8-coverage: 1.0.1 exit: 0.1.2 @@ -6085,7 +6065,7 @@ packages: dependencies: '@types/istanbul-lib-coverage': 2.0.4 '@types/istanbul-reports': 3.0.1 - '@types/node': 20.3.1 + '@types/node': 20.4.1 '@types/yargs': 15.0.14 chalk: 4.1.2 dev: true @@ -6096,7 +6076,7 @@ packages: dependencies: '@types/istanbul-lib-coverage': 2.0.4 '@types/istanbul-reports': 3.0.1 - '@types/node': 20.3.1 + '@types/node': 20.4.1 '@types/yargs': 16.0.5 chalk: 4.1.2 dev: true @@ -6108,7 +6088,7 @@ packages: '@jest/schemas': 29.4.3 '@types/istanbul-lib-coverage': 2.0.4 '@types/istanbul-reports': 3.0.1 - '@types/node': 20.3.1 + '@types/node': 20.4.1 '@types/yargs': 17.0.12 chalk: 4.1.2 dev: true @@ -6631,7 +6611,7 @@ packages: engines: {node: '>=14'} hasBin: true dependencies: - '@types/node': 20.3.1 + '@types/node': 20.4.1 playwright-core: 1.28.0 dev: true @@ -8343,26 +8323,7 @@ packages: svelte: ^3.54.0 || ^4.0.0 vite: ^4.0.0 dependencies: - debug: 4.3.4(supports-color@8.1.1) - deepmerge: 4.2.2 - kleur: 4.1.5 - magic-string: 0.27.0 - svelte: 3.59.1 - svelte-hmr: 0.15.1(svelte@3.59.1) - vite: 4.3.9(@types/node@18.16.18) - vitefu: 0.2.3(vite@4.3.9) - transitivePeerDependencies: - - supports-color - dev: true - - /@sveltejs/vite-plugin-svelte@2.4.1(svelte@3.59.1)(vite@4.3.9): - resolution: {integrity: sha512-bNNKvoRY89ptY7udeBSCmTdCVwkjmMcZ0j/z9J5MuedT8jPjq0zrknAo/jF1sToAza4NVaAgR9AkZoD9oJJmnA==} - engines: {node: ^14.18.0 || >= 16} - peerDependencies: - svelte: ^3.54.0 || ^4.0.0-next.0 - vite: ^4.0.0 - dependencies: - '@sveltejs/vite-plugin-svelte-inspector': 1.0.2(@sveltejs/vite-plugin-svelte@2.4.1)(svelte@3.59.1)(vite@4.3.9) + '@sveltejs/vite-plugin-svelte-inspector': 1.0.3(@sveltejs/vite-plugin-svelte@2.4.2)(svelte@3.59.1)(vite@4.3.9) debug: 4.3.4(supports-color@8.1.1) deepmerge: 4.3.1 kleur: 4.1.5 @@ -8629,7 +8590,7 @@ packages: /@types/cheerio@0.22.31: resolution: {integrity: sha512-Kt7Cdjjdi2XWSfrZ53v4Of0wG3ZcmaegFXjMmz9tfNrZSkzzo36G0AL1YqSdcIA78Etjt6E609pt5h1xnQkPUw==} dependencies: - '@types/node': 20.3.1 + '@types/node': 20.4.1 dev: true /@types/codemirror@5.60.8: @@ -8668,7 +8629,7 @@ packages: resolution: {integrity: sha512-xryQlOEIe1TduDWAOphR0ihfebKFSWOXpIsk+70JskCfRfW+xALdnJ0r1ZOTo85F9Qsjk6vtlU7edTYHbls9tA==} dependencies: '@types/cheerio': 0.22.31 - '@types/react': 18.2.13 + '@types/react': 18.2.14 dev: true /@types/eslint-scope@3.7.4: @@ -8699,33 +8660,33 @@ packages: resolution: {integrity: sha512-MxObHvNl4A69ofaTRU8DFqvgzzv8s9yRtaPPm5gud9HDNvpB3GPQFvNuTWAI59B9huVGV5jXYJwbCsmBsOGYWA==} dependencies: '@types/jsonfile': 6.1.1 - '@types/node': 20.3.1 + '@types/node': 20.4.1 dev: true /@types/fs-extra@9.0.13: resolution: {integrity: sha512-nEnwB++1u5lVDM2UI4c1+5R+FYaKfaAzS4OococimjVm3nQw3TuzH5UNsocrcTBbhnerblyHj4A49qXbIiZdpA==} dependencies: - '@types/node': 20.3.1 + '@types/node': 20.4.1 dev: true /@types/glob@7.2.0: resolution: {integrity: sha512-ZUxbzKl0IfJILTS6t7ip5fQQM/J3TJYubDm3nMbgubNNYS62eXeUpoLUC8/7fJNiFYHTrGPQn7hspDUzIHX3UA==} dependencies: '@types/minimatch': 5.1.1 - '@types/node': 20.3.1 + '@types/node': 20.4.1 dev: true /@types/glob@8.0.0: resolution: {integrity: sha512-l6NQsDDyQUVeoTynNpC9uRvCUint/gSUXQA2euwmTuWGvPY5LSDUu6tkCtJB2SvGQlJQzLaKqcGZP4//7EDveA==} dependencies: '@types/minimatch': 5.1.1 - '@types/node': 20.3.1 + '@types/node': 20.4.1 dev: true /@types/graceful-fs@4.1.5: resolution: {integrity: sha512-anKkLmZZ+xm4p8JWBf4hElkM4XR+EZeA2M9BAkkTldmcyDY4mbdIJnRghDJH3Ov5ooY7/UAoENtmdMSkaAd7Cw==} dependencies: - '@types/node': 20.3.1 + '@types/node': 20.4.1 dev: true /@types/hast@2.3.4: @@ -8797,7 +8758,7 @@ packages: /@types/jsdom@21.1.1: resolution: {integrity: sha512-cZFuoVLtzKP3gmq9eNosUL1R50U+USkbLtUQ1bYVgl/lKp0FZM7Cq4aIHAL8oIvQ17uSHi7jXPtfDOdjPwBE7A==} dependencies: - '@types/node': 20.3.1 + '@types/node': 20.4.1 '@types/tough-cookie': 4.0.2 parse5: 7.1.2 dev: true @@ -8809,7 +8770,7 @@ packages: /@types/jsonfile@6.1.1: resolution: {integrity: sha512-GSgiRCVeapDN+3pqA35IkQwasaCh/0YFH5dEF6S88iDvEn901DjOeH3/QPY+XYP1DFzDZPvIvfeEgk+7br5png==} dependencies: - '@types/node': 20.3.1 + '@types/node': 20.4.1 dev: true /@types/lodash@4.14.195: @@ -8843,7 +8804,7 @@ packages: /@types/node-fetch@2.6.2: resolution: {integrity: sha512-DHqhlq5jeESLy19TYhLakJ07kNumXWjcDdxXsLUMJZ6ue8VZJj4kLPQVE/2mdHh3xZziNF1xppu5lwmS53HR+A==} dependencies: - '@types/node': 20.3.1 + '@types/node': 20.4.1 form-data: 3.0.1 dev: true @@ -8862,8 +8823,8 @@ packages: resolution: {integrity: sha512-46yIhxSe5xEaJZXWdIBP7GU4HDTG8/eo0qd9atdiL+lFpA03y8KS+lkTN834TWJj5767GbWv4n/P6efyTFt1Dw==} dev: false - /@types/node@20.3.1: - resolution: {integrity: sha512-EhcH/wvidPy1WeML3TtYFGR83UzjxeWRen9V402T8aUGYsCHOmfoisV3ZSg03gAFIbLq8TnWOJ0f4cALtnSEUg==} + /@types/node@20.4.1: + resolution: {integrity: sha512-JIzsAvJeA/5iY6Y/OxZbv1lUcc8dNSE77lb2gnBH+/PJ3lFR1Ccvgwl5JWnHAkNHcRsT0TbpVOsiMKZ1F/yyJg==} dev: true /@types/normalize-package-data@2.4.1: @@ -8892,7 +8853,7 @@ packages: /@types/prompts@2.4.4: resolution: {integrity: sha512-p5N9uoTH76lLvSAaYSZtBCdEXzpOOufsRjnhjVSrZGXikVGHX9+cc9ERtHRV4hvBKHyZb1bg4K+56Bd2TqUn4A==} dependencies: - '@types/node': 20.3.1 + '@types/node': 20.4.1 kleur: 3.0.3 dev: true @@ -8916,19 +8877,19 @@ packages: /@types/react-dom@18.0.6: resolution: {integrity: sha512-/5OFZgfIPSwy+YuIBP/FgJnQnsxhZhjjrnxudMddeblOouIodEQ75X14Rr4wGSG/bknL+Omy9iWlLo1u/9GzAA==} dependencies: - '@types/react': 18.2.13 + '@types/react': 18.2.14 dev: true /@types/react-dom@18.0.8: resolution: {integrity: sha512-C3GYO0HLaOkk9dDAz3Dl4sbe4AKUGTCfFIZsz3n/82dPNN8Du533HzKatDxeUYWu24wJgMP1xICqkWk1YOLOIw==} dependencies: - '@types/react': 18.2.13 + '@types/react': 18.2.14 dev: true /@types/react-is@17.0.3: resolution: {integrity: sha512-aBTIWg1emtu95bLTLx0cpkxwGW3ueZv71nE2YFBpL8k/z5czEW8yYpOo8Dp+UUAFAtKwNaOsh/ioSeQnWlZcfw==} dependencies: - '@types/react': 18.2.13 + '@types/react': 18.2.14 dev: false /@types/react-test-renderer@17.0.2: @@ -8940,7 +8901,7 @@ packages: /@types/react-transition-group@4.4.5: resolution: {integrity: sha512-juKD/eiSM3/xZYzjuzH6ZwpP+/lejltmiS3QEzV/vmb/Q8+HfDmxu+Baga8UEMGBqV88Nbg4l2hY/K2DkyaLLA==} dependencies: - '@types/react': 18.2.13 + '@types/react': 18.2.14 dev: false /@types/react@17.0.49: @@ -8959,8 +8920,8 @@ packages: csstype: 3.1.0 dev: true - /@types/react@18.2.13: - resolution: {integrity: sha512-vJ+zElvi/Zn9cVXB5slX2xL8PZodPCwPRDpittQdw43JR2AJ5k3vKdgJJyneV/cYgIbLQUwXa9JVDvUZXGba+Q==} + /@types/react@18.2.14: + resolution: {integrity: sha512-A0zjq+QN/O0Kpe30hA1GidzyFjatVvrpIvWLxD+xv67Vt91TWWgco9IvrJBkeyHm1trGaFS/FSGqPlhyeZRm0g==} dependencies: '@types/prop-types': 15.7.5 '@types/scheduler': 0.16.2 @@ -8969,7 +8930,7 @@ packages: /@types/resolve@1.17.1: resolution: {integrity: sha512-yy7HuzQhj0dhGpD8RLXSZWEkLsV9ibvxvi6EiJ3bkqLAO1RGo0WbkWQiwpRlSFymTJRz0d3k5LM3kkx8ArDbLw==} dependencies: - '@types/node': 20.3.1 + '@types/node': 20.4.1 dev: true /@types/resolve@1.20.2: @@ -8986,7 +8947,7 @@ packages: /@types/set-cookie-parser@2.4.2: resolution: {integrity: sha512-fBZgytwhYAUkj/jC/FAV4RQ5EerRup1YQsXQCh8rZfiHkc4UahC192oH0smGwsXol3cL3A5oETuAHeQHmhXM4w==} dependencies: - '@types/node': 20.3.1 + '@types/node': 20.4.1 dev: true /@types/sinonjs__fake-timers@8.1.1: @@ -9066,7 +9027,7 @@ packages: /@types/webpack-sources@3.2.0: resolution: {integrity: sha512-Ft7YH3lEVRQ6ls8k4Ff1oB4jN6oy/XmU6tQISKdhfh+1mR+viZFphS6WL0IrtDOzvefmJg5a0s7ZQoRXwqTEFg==} dependencies: - '@types/node': 20.3.1 + '@types/node': 20.4.1 '@types/source-list-map': 0.1.2 source-map: 0.7.4 dev: true @@ -9074,7 +9035,7 @@ packages: /@types/webpack@4.41.32: resolution: {integrity: sha512-cb+0ioil/7oz5//7tZUSwbrSAN/NWHrQylz5cW8G0dWTcF/g+/dSdMlKVZspBYuMAN1+WnwHrkxiRrLcwd0Heg==} dependencies: - '@types/node': 20.3.1 + '@types/node': 20.4.1 '@types/tapable': 1.0.8 '@types/uglify-js': 3.17.0 '@types/webpack-sources': 3.2.0 @@ -9089,7 +9050,7 @@ packages: /@types/ws@8.5.5: resolution: {integrity: sha512-lwhs8hktwxSjf9UaZ9tG5M03PGogvFaH8gUgLNbN9HKIg0dvv6q+gkSuJ8HN4/VbyxkuLzCjlN7GquQ0gUJfIg==} dependencies: - '@types/node': 20.3.1 + '@types/node': 20.4.1 dev: true /@types/yargs-parser@21.0.0: @@ -9118,7 +9079,7 @@ packages: resolution: {integrity: sha512-Cn6WYCm0tXv8p6k+A8PvbDG763EDpBoTzHdA+Q/MF6H3sapGjCm9NzoaJncJS9tUKSuCoDs9XHxYYsQDgxR6kw==} requiresBuild: true dependencies: - '@types/node': 20.3.1 + '@types/node': 20.4.1 dev: true optional: true @@ -9535,8 +9496,8 @@ packages: - supports-color dev: true - /@vitejs/plugin-react@4.0.1(vite@4.3.9): - resolution: {integrity: sha512-g25lL98essfeSj43HJ0o4DMp0325XK0ITkxpgChzJU/CyemgyChtlxfnRbjfwxDGCTRxTiXtQAsdebQXKMRSOA==} + /@vitejs/plugin-react@4.0.3(vite@4.3.9): + resolution: {integrity: sha512-pwXDog5nwwvSIzwrvYYmA2Ljcd/ZNlcsSG2Q9CNDBwnsd55UGAyr2doXtB5j+2uymRCnCfExlznzzSFbBRcoCg==} engines: {node: ^14.18.0 || >=16.0.0} peerDependencies: vite: ^4.2.0 @@ -9545,7 +9506,7 @@ packages: '@babel/plugin-transform-react-jsx-self': 7.22.5(@babel/core@7.22.5) '@babel/plugin-transform-react-jsx-source': 7.22.5(@babel/core@7.22.5) react-refresh: 0.14.0 - vite: 4.3.9(@types/node@20.3.1) + vite: 4.3.9(@types/node@20.4.1) transitivePeerDependencies: - supports-color dev: true @@ -10616,6 +10577,7 @@ packages: /ansi-regex@5.0.1: resolution: {integrity: sha512-quJQXlTSUGL2LH9SUXo8VwsY4soanhgo6LNSm84E1LBcE8s3O0wpdiRzyR9z/ZZJMlMWv37qOOb9pdJlMUEKFQ==} engines: {node: '>=8'} + dev: true /ansi-regex@6.0.1: resolution: {integrity: sha512-n5M855fKb2SsfMIiFFoVrABHJC8QtHwVx+mHWP3QcEqBHYienj5dHSgjbxtC0WEZXYt4wcD6zrQElDPhFuZgfA==} @@ -10642,6 +10604,7 @@ packages: engines: {node: '>=8'} dependencies: color-convert: 2.0.1 + dev: true /ansi-styles@5.2.0: resolution: {integrity: sha512-Cxwpt2SfTzTtXcfOlzGEee8O+c+MmUgGrNiBcXnuWxuFJHe6a5Hz7qwhwe5OgaSYI0IJvkLqWX1ASG+cJOkEiA==} @@ -11649,7 +11612,7 @@ packages: dotenv: 16.0.3 giget: 1.1.2 jiti: 1.18.2 - mlly: 1.3.0 + mlly: 1.4.0 ohash: 1.1.2 pathe: 1.1.1 perfect-debounce: 0.1.3 @@ -12012,7 +11975,7 @@ packages: engines: {node: '>=12.13.0'} hasBin: true dependencies: - '@types/node': 20.3.1 + '@types/node': 20.4.1 escape-string-regexp: 4.0.0 is-wsl: 2.2.0 lighthouse-logger: 1.3.0 @@ -12157,6 +12120,7 @@ packages: string-width: 4.2.3 strip-ansi: 6.0.1 wrap-ansi: 7.0.0 + dev: true /cliui@8.0.1: resolution: {integrity: sha512-BSeNnyus75C4//NQ9gQt1/csTXyo/8Sb+afLAkzAptFuMsod9HFokGNudZpi/oQV73hnVK+sR+5PVRMd+Dr7YQ==} @@ -12225,12 +12189,14 @@ packages: engines: {node: '>=7.0.0'} dependencies: color-name: 1.1.4 + dev: true /color-name@1.1.3: resolution: {integrity: sha512-72fSenhMw2HZMTVHeCA9KCmpEIbzWiQsjN+BHcBbS9vr1mtt+vJjPdksIBNUmKAW8TFUDPJK5SUU3QhE9NEXDw==} /color-name@1.1.4: resolution: {integrity: sha512-dOy+3AuW3a2wNbZHIuMZpTcgjGuLU/uBL/ubcZF9OXbDo8ff4O8yVp5Bf0efS8uEoYo5q4Fx7dY9OgQGXgAsQA==} + dev: true /color-string@1.9.1: resolution: {integrity: sha512-shrVawQFojnZv6xM40anx4CkoDP+fZsw/ZerEMsW/pyzsRbElpsL/DBVW7q3ExxwusdNXI3lXpuhEZkzs8p5Eg==} @@ -12606,6 +12572,7 @@ packages: path-key: 3.1.1 shebang-command: 2.0.0 which: 2.0.2 + dev: true /crypto-browserify@3.12.0: resolution: {integrity: sha512-fz4spIh+znjO2VjL+IdhEpRJ3YN6sMzITSBijk6FK2UvTqruSQW+/cCZTSNsMiZNvUeq0CqurF+dAbyiGOY6Wg==} @@ -13582,6 +13549,7 @@ packages: /emoji-regex@8.0.0: resolution: {integrity: sha512-MSjYzcWNOA0ewAHpz0MxpYFvwg6yjy1NG3xteoqz644VCo/RPgnr1/GGt+ic3iJTzQ8Eu3TdM14SawnVUmGE6A==} + dev: true /emoji-regex@9.2.2: resolution: {integrity: sha512-L18DaJsXSUk2+42pv8mLs5jJT2hqFkFE4j21wOmgbUqsZ2hL72NsUU785g9RXgo3s0ZNgVl42TiHp3ZtOv/Vyg==} @@ -15103,8 +15071,8 @@ packages: - supports-color dev: true - /fast-glob@3.2.12: - resolution: {integrity: sha512-DVj4CQIYYow0BlaelwK1pHl5n5cRSJfM60UA0zK891sVInoPri2Ekj7+e1CT3/3qxXenpI+nBBmQAcJPJgaj4w==} + /fast-glob@3.3.0: + resolution: {integrity: sha512-ChDuvbOypPuNjO8yIDf36x7BlZX1smcUMTTcyoIjycexOxd6DFsKsg21qVBzEmr3G7fUKIRy2/psii+CIUt7FA==} engines: {node: '>=8.6.0'} dependencies: '@nodelib/fs.stat': 2.0.5 @@ -15342,6 +15310,7 @@ packages: dependencies: locate-path: 6.0.0 path-exists: 4.0.0 + dev: true /find-up@6.3.0: resolution: {integrity: sha512-v2ZsoEuVHYy8ZIlYqwPe/39Cy+cFDzp4dXPaxNvkEuouymu+2Jbz0PxpKarJHYJTmv2HWT3O382qY8l4jMWthw==} @@ -15416,6 +15385,7 @@ packages: dependencies: cross-spawn: 7.0.3 signal-exit: 3.0.7 + dev: true /foreground-child@3.1.1: resolution: {integrity: sha512-TMKDUnIte6bfb5nWv7V/caI169OHgvwjb7V4WkeUvbQQdjr5rWKqHFiKWb/fcOwB+CzBT+qbWjvj+DVwRskpIg==} @@ -15671,6 +15641,7 @@ packages: /get-caller-file@2.0.5: resolution: {integrity: sha512-DyFP3BM/3YHTQOCUL/w0OZHR0lpKeGrxotcHWcqNEdnltqFwXVfhEBQ94eIo34AfQpo0rGki4cyIiftY06h2Fg==} engines: {node: 6.* || 8.* || >= 10.*} + dev: true /get-func-name@2.0.0: resolution: {integrity: sha512-Hm0ixYtaSZ/V7C8FJrtZIuBBI+iSgL+1Aq82zSu8VQNB4S3Gk8e7Qs3VwBDJAhmRZcFqkl3tQu36g/Foh5I5ig==} @@ -16860,6 +16831,7 @@ packages: /is-fullwidth-code-point@3.0.0: resolution: {integrity: sha512-zymm5+u+sCsSWyD9qNaejV3DFvhCKclKdizYaJUuHA83RLjb7nSuGnddCHGv0hk+KY7BMAlsWeK4Ueg6EV6XQg==} engines: {node: '>=8'} + dev: true /is-fullwidth-code-point@4.0.0: resolution: {integrity: sha512-O4L094N2/dZ7xqVdrXhh9r1KODPJpFms8B5sGdJLPy664AgvXsreZUyCQQNItZRDlYug4xStLjNp/sz3HvBowQ==} @@ -17155,6 +17127,7 @@ packages: /isexe@2.0.0: resolution: {integrity: sha512-RHxMLp9lnKHGHRng9QFhRCMbYAcVpn69smSGcq3f36xjgVVWThj4qqLbTLlq7Ssj8B+fIQ1EuCEGI2lKsyQeIw==} + dev: true /isobject@2.1.0: resolution: {integrity: sha512-+OUdGJlgjOBZDfxnDjYYG6zp487z0JGNQq3cYQYg5f5hKR+syHMsaztzGeml/4kGG55CSpKSpWTY+jYGgsHLgA==} @@ -17288,7 +17261,7 @@ packages: '@jest/environment': 27.5.1 '@jest/test-result': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.3.1 + '@types/node': 20.4.1 chalk: 4.1.2 co: 4.6.0 dedent: 0.7.0 @@ -17424,7 +17397,7 @@ packages: '@jest/environment': 27.5.1 '@jest/fake-timers': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.3.1 + '@types/node': 20.4.1 jest-mock: 27.5.1 jest-util: 27.5.1 jsdom: 16.7.0 @@ -17442,7 +17415,7 @@ packages: '@jest/environment': 27.5.1 '@jest/fake-timers': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.3.1 + '@types/node': 20.4.1 jest-mock: 27.5.1 jest-util: 27.5.1 dev: true @@ -17463,7 +17436,7 @@ packages: dependencies: '@jest/types': 26.6.2 '@types/graceful-fs': 4.1.5 - '@types/node': 20.3.1 + '@types/node': 20.4.1 anymatch: 3.1.2 fb-watchman: 2.0.1 graceful-fs: 4.2.10 @@ -17486,7 +17459,7 @@ packages: dependencies: '@jest/types': 27.5.1 '@types/graceful-fs': 4.1.5 - '@types/node': 20.3.1 + '@types/node': 20.4.1 anymatch: 3.1.2 fb-watchman: 2.0.1 graceful-fs: 4.2.10 @@ -17526,7 +17499,7 @@ packages: '@jest/source-map': 27.5.1 '@jest/test-result': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.3.1 + '@types/node': 20.4.1 chalk: 4.1.2 co: 4.6.0 expect: 27.5.1 @@ -17606,7 +17579,7 @@ packages: engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: '@jest/types': 27.5.1 - '@types/node': 20.3.1 + '@types/node': 20.4.1 dev: true /jest-pnp-resolver@1.2.3(jest-resolve@27.5.1): @@ -17667,7 +17640,7 @@ packages: '@jest/test-result': 27.5.1 '@jest/transform': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.3.1 + '@types/node': 20.4.1 chalk: 4.1.2 emittery: 0.8.1 graceful-fs: 4.2.10 @@ -17724,7 +17697,7 @@ packages: resolution: {integrity: sha512-S5wqyz0DXnNJPd/xfIzZ5Xnp1HrJWBczg8mMfMpN78OJ5eDxXyf+Ygld9wX1DnUWbIbhM1YDY95NjR4CBXkb2g==} engines: {node: '>= 10.14.2'} dependencies: - '@types/node': 20.3.1 + '@types/node': 20.4.1 graceful-fs: 4.2.10 dev: true @@ -17732,7 +17705,7 @@ packages: resolution: {integrity: sha512-jZCyo6iIxO1aqUxpuBlwTDMkzOAJS4a3eYz3YzgxxVQFwLeSA7Jfq5cbqCY+JLvTDrWirgusI/0KwxKMgrdf7w==} engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: - '@types/node': 20.3.1 + '@types/node': 20.4.1 graceful-fs: 4.2.10 dev: true @@ -17771,7 +17744,7 @@ packages: engines: {node: '>= 10.14.2'} dependencies: '@jest/types': 26.6.2 - '@types/node': 20.3.1 + '@types/node': 20.4.1 chalk: 4.1.2 graceful-fs: 4.2.10 is-ci: 2.0.0 @@ -17783,7 +17756,7 @@ packages: engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: '@jest/types': 27.5.1 - '@types/node': 20.3.1 + '@types/node': 20.4.1 chalk: 4.1.2 ci-info: 3.8.0 graceful-fs: 4.2.10 @@ -17795,7 +17768,7 @@ packages: engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: '@jest/types': 29.0.1 - '@types/node': 20.3.1 + '@types/node': 20.4.1 chalk: 4.1.2 ci-info: 3.7.0 graceful-fs: 4.2.10 @@ -17820,7 +17793,7 @@ packages: dependencies: '@jest/test-result': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.3.1 + '@types/node': 20.4.1 ansi-escapes: 4.3.2 chalk: 4.1.2 jest-util: 27.5.1 @@ -17831,7 +17804,7 @@ packages: resolution: {integrity: sha512-KWYVV1c4i+jbMpaBC+U++4Va0cp8OisU185o73T1vo99hqi7w8tSJfUXYswwqqrjzwxa6KpRK54WhPvwf5w6PQ==} engines: {node: '>= 10.13.0'} dependencies: - '@types/node': 20.3.1 + '@types/node': 20.4.1 merge-stream: 2.0.0 supports-color: 7.2.0 dev: true @@ -17840,7 +17813,7 @@ packages: resolution: {integrity: sha512-7vuh85V5cdDofPyxn58nrPjBktZo0u9x1g8WtjQol+jZDaE+fhN+cIvTj11GndBnMnyfrUOG1sZQxCdjKh+DKg==} engines: {node: '>= 10.13.0'} dependencies: - '@types/node': 20.3.1 + '@types/node': 20.4.1 merge-stream: 2.0.0 supports-color: 8.1.1 dev: true @@ -18516,6 +18489,7 @@ packages: engines: {node: '>=10'} dependencies: p-locate: 5.0.0 + dev: true /locate-path@7.1.1: resolution: {integrity: sha512-vJXaRMJgRVD3+cUZs3Mncj2mxpt5mP0EmNOsxRSZRMlbqjvxzDEOIUWXGmavo0ZC9+tNZCBLQ66reA11nbpHZg==} @@ -19179,8 +19153,8 @@ packages: hasBin: true dev: true - /mlly@1.3.0: - resolution: {integrity: sha512-HT5mcgIQKkOrZecOjOX3DJorTikWXwsBfpcr/MGBkhfWcjiqvnaL/9ppxvIUXfjT6xt4DVIAsN9fMUz1ev4bIw==} + /mlly@1.4.0: + resolution: {integrity: sha512-ua8PAThnTwpprIaU47EPeZ/bPUVp2QYBbWMphUQpVdBI3Lgqzm5KZQ45Agm3YJedHXaIHl6pBGabaLSUPPSptg==} dependencies: acorn: 8.9.0 pathe: 1.1.1 @@ -19290,7 +19264,7 @@ packages: - supports-color dev: true - /msw@1.2.1(typescript@5.1.3): + /msw@1.2.1(typescript@5.1.6): resolution: {integrity: sha512-bF7qWJQSmKn6bwGYVPXOxhexTCGD5oJSZg8yt8IBClxvo3Dx/1W0zqE1nX9BSWmzRsCKWfeGWcB/vpqV6aclpw==} engines: {node: '>=14'} hasBin: true @@ -19319,7 +19293,7 @@ packages: path-to-regexp: 6.2.1 strict-event-emitter: 0.4.6 type-fest: 2.19.0 - typescript: 5.1.3 + typescript: 5.1.6 yargs: 17.7.1 transitivePeerDependencies: - encoding @@ -20013,6 +19987,7 @@ packages: engines: {node: '>=10'} dependencies: yocto-queue: 0.1.0 + dev: true /p-limit@4.0.0: resolution: {integrity: sha512-5b0R4txpzjPWVw/cXXUResoD4hb6U/x9BH08L7nw+GN1sezDzPdxeRvpc9c433fZhBan/wusjbCsqwqm4EIBIQ==} @@ -20039,6 +20014,7 @@ packages: engines: {node: '>=10'} dependencies: p-limit: 3.1.0 + dev: true /p-locate@6.0.0: resolution: {integrity: sha512-wPrq66Llhl7/4AGC6I+cqxT07LhXvWL08LNXz1fENOw0Ap4sRZZ/gZpTTJ5jpurzzzfS2W/Ge9BY3LgLjCShcw==} @@ -20229,6 +20205,7 @@ packages: /path-exists@4.0.0: resolution: {integrity: sha512-ak9Qy5Q7jYb2Wwcey5Fpvg2KoAc/ZIhLSLOSBmRmygPsGwkVVt0fZa0qrtMz+m6tJTAHfZQ8FnmB4MG4LWy7/w==} engines: {node: '>=8'} + dev: true /path-exists@5.0.0: resolution: {integrity: sha512-RjhtfwJOxzcFmNOi6ltcbcu4Iu+FL3zEj83dk4kAS+fVpTxXLO1b38RvJgT/0QwvV/L3aY9TAnyv0EOqW4GoMQ==} @@ -20247,6 +20224,7 @@ packages: /path-key@3.1.1: resolution: {integrity: sha512-ojmeN0qd+y0jszEtoY48r0Peq5dwMEkIlCOu6Q5f41lfkswXuKtYrhgoTpLnyIcHm24Uhqx+5Tqm2InSwLhE6Q==} engines: {node: '>=8'} + dev: true /path-key@4.0.0: resolution: {integrity: sha512-haREypq7xkM7ErfgIyA0z+Bj4AGKlMSdlQE2jvJo6huWD1EdkKYV+G/T4nq0YEF2vgTT8kqMFKo1uHn950r4SQ==} @@ -21735,6 +21713,7 @@ packages: /require-directory@2.1.1: resolution: {integrity: sha512-fGxEI7+wsG9xrvdjsrlmL22OMTTiHRwAMroiEeMgq8gzoLC/PQr7RsRDSTLUg/bZAZtF+TVIkHc6/4RIKrui+Q==} engines: {node: '>=0.10.0'} + dev: true /require-from-string@2.0.2: resolution: {integrity: sha512-Xf0nWe6RseziFMu+Ap9biiUbmplq6S9/p+7w7YXP/JBHhrUDDUhwa+vANyubuqfZWTveU//DYVGsDG7RKL/vEw==} @@ -22368,6 +22347,7 @@ packages: engines: {node: '>=8'} dependencies: shebang-regex: 3.0.0 + dev: true /shebang-regex@1.0.0: resolution: {integrity: sha512-wpoSFAxys6b2a2wHZ1XpDSgD7N9iVjg29Ph9uV/uaP9Ex/KXlkTZTeddxDPSYQpgvzKLGJke2UU0AzoGCjNIvQ==} @@ -22377,6 +22357,7 @@ packages: /shebang-regex@3.0.0: resolution: {integrity: sha512-7++dFhtcx3353uBaq8DDR4NuxBetBzC7ZQOhmTQInHEd6bSrXdiEyzCvG07Z44UYdLShWUyXt5M/yhz8ekcb1A==} engines: {node: '>=8'} + dev: true /shell-quote@1.7.4: resolution: {integrity: sha512-8o/QEhSSRb1a5i7TFR0iM4G16Z0vYB2OQVs4G3aAFXjn3T6yEx8AZxy1PgDF7I00LZHYA3WxaSYIf5e5sAX8Rw==} @@ -22409,6 +22390,7 @@ packages: /signal-exit@3.0.7: resolution: {integrity: sha512-wnD2ZE+l+SPC/uoS0vXeE9L1+0wuaMqKlfz9AMUo38JsyLSBWSFcHR1Rri62LZc12vLr1gb3jl7iwQhgwpAbGQ==} + dev: true /signal-exit@4.0.1: resolution: {integrity: sha512-uUWsN4aOxJAS8KOuf3QMyFtgm1pkb6I+KRZbRF/ghdf5T7sM+B1lLLzPDxswUjkmHyxQAVzEgG35E3NzDM9GVw==} @@ -22868,6 +22850,7 @@ packages: emoji-regex: 8.0.0 is-fullwidth-code-point: 3.0.0 strip-ansi: 6.0.1 + dev: true /string-width@5.1.2: resolution: {integrity: sha512-HnLOCR3vjcY8beoNLtcjZ5/nxn2afmME6lhrDrebokqMap+XbeW8n9TXpPDOqdGK5qcI3oT0GKTW6wC7EMiVqA==} @@ -22967,6 +22950,7 @@ packages: engines: {node: '>=8'} dependencies: ansi-regex: 5.0.1 + dev: true /strip-ansi@7.0.1: resolution: {integrity: sha512-cXNxvT8dFNRVfhVME3JAe98mkXDYN2O1l7jmcwMnOslDeESg1rF/OZMtK0nRAhiari1unG5cD4jG3rapUAkLbw==} @@ -24047,7 +24031,7 @@ packages: vfile: 4.2.1 dev: true - /unimport@3.0.7(rollup@3.20.2): + /unimport@3.0.7(rollup@3.26.0): resolution: {integrity: sha512-2dVQUxJEGcrSZ0U4qtwJVODrlfyGcwmIOoHVqbAFFUx7kPoEN5JWr1cZFhLwoAwTmZOvqAm3YIkzv1engIQocg==} dependencies: '@rollup/pluginutils': 5.0.2(rollup@3.26.0) @@ -24237,7 +24221,7 @@ packages: engines: {node: '>= 0.8'} dev: true - /unplugin-auto-import@0.16.4(@vueuse/core@10.2.0)(rollup@3.20.2): + /unplugin-auto-import@0.16.4(@vueuse/core@10.2.1)(rollup@3.26.0): resolution: {integrity: sha512-xdgBa9NAS3JG8HjkAZHSbGSMlrjKpaWKXGUzaF6RzEtr980RCl1t0Zsu0skUInNYrEQfqaHc7aGWPv41DLTK/w==} engines: {node: '>=14'} peerDependencies: @@ -24250,12 +24234,12 @@ packages: optional: true dependencies: '@antfu/utils': 0.7.4 - '@rollup/pluginutils': 5.0.2(rollup@3.20.2) - '@vueuse/core': 10.2.0(vue@3.3.4) + '@rollup/pluginutils': 5.0.2(rollup@3.26.0) + '@vueuse/core': 10.2.1(vue@3.3.4) local-pkg: 0.4.3 - magic-string: 0.30.0 + magic-string: 0.30.1 minimatch: 9.0.1 - unimport: 3.0.7(rollup@3.20.2) + unimport: 3.0.7(rollup@3.26.0) unplugin: 1.3.1 transitivePeerDependencies: - rollup @@ -24290,7 +24274,7 @@ packages: - supports-color dev: true - /unplugin-vue-components@0.25.1(rollup@3.20.2)(vue@3.3.4): + /unplugin-vue-components@0.25.1(rollup@3.26.0)(vue@3.3.4): resolution: {integrity: sha512-kzS2ZHVMaGU2XEO2keYQcMjNZkanDSGDdY96uQT9EPe+wqSZwwgbFfKVJ5ti0+8rGAcKHColwKUvctBhq2LJ3A==} engines: {node: '>=14'} peerDependencies: @@ -24304,10 +24288,10 @@ packages: optional: true dependencies: '@antfu/utils': 0.7.4 - '@rollup/pluginutils': 5.0.2(rollup@3.20.2) + '@rollup/pluginutils': 5.0.2(rollup@3.26.0) chokidar: 3.5.3 debug: 4.3.4(supports-color@8.1.1) - fast-glob: 3.2.12 + fast-glob: 3.3.0 local-pkg: 0.4.3 magic-string: 0.30.0 minimatch: 9.0.1 @@ -24616,7 +24600,7 @@ packages: merge-anything: 5.1.4 solid-js: 1.5.2 solid-refresh: 0.4.1(solid-js@1.5.2) - vite: 4.3.9(@types/node@18.16.18) + vite: 4.3.9(@types/node@18.16.19) vitefu: 0.2.3(vite@4.3.9) transitivePeerDependencies: - supports-color @@ -24687,7 +24671,7 @@ packages: fsevents: 2.3.2 dev: false - /vite@4.3.9(@types/node@20.3.1): + /vite@4.3.9(@types/node@20.4.1): resolution: {integrity: sha512-qsTNZjO9NoJNW7KnOrgYwczm0WctJ8m/yqYAMAK9Lxt4SoySUfS5S8ia9K7JHpa3KEeMfyF8LoJ3c5NeBJy6pg==} engines: {node: ^14.18.0 || >=16.0.0} hasBin: true @@ -24712,7 +24696,7 @@ packages: terser: optional: true dependencies: - '@types/node': 20.3.1 + '@types/node': 20.4.1 esbuild: 0.17.18 postcss: 8.4.24 rollup: 3.23.0 @@ -24728,7 +24712,7 @@ packages: vite: optional: true dependencies: - vite: 4.3.9(@types/node@18.16.18) + vite: 4.3.9(@types/node@18.16.19) dev: true /vitefu@0.2.4(vite@4.3.9): @@ -25343,6 +25327,7 @@ packages: hasBin: true dependencies: isexe: 2.0.0 + dev: true /which@3.0.0: resolution: {integrity: sha512-nla//68K9NU6yRiwDY/Q8aU6siKlSs64aEC7+IV56QoAuyQT2ovsJcgGYGyqMOmI/CGN1BOR6mM5EN0FBO+zyQ==} @@ -25557,6 +25542,7 @@ packages: ansi-styles: 4.3.0 string-width: 4.2.3 strip-ansi: 6.0.1 + dev: true /wrap-ansi@8.0.1: resolution: {integrity: sha512-QFF+ufAqhoYHvoHdajT/Po7KoXVBPXS2bgjIam5isfWJPfIOnQZ50JtUiVvCv/sjgacf3yRrt2ZKUZ/V4itN4g==} @@ -25662,6 +25648,7 @@ packages: /y18n@5.0.8: resolution: {integrity: sha512-0pfFzegeDWJHJIAmTLRP2DwHjdF5s7jo9tuztdQxAhINCdvS+3nGINqPd00AphqJR/0LhANUS6/+7SCb98YOfA==} engines: {node: '>=10'} + dev: true /yallist@2.1.2: resolution: {integrity: sha512-ncTzHV7NvsQZkYe1DW7cbDLm0YpzHmZF5r/iyP3ZnQtMiJ+pjzisCiMNI+Sj+xQF5pXhSHxSB3uDbsBTzY/c2A==} @@ -25695,6 +25682,7 @@ packages: /yargs-parser@20.2.9: resolution: {integrity: sha512-y11nGElTIV+CT3Zv9t7VKl+Q3hTQoT9a1Qzezhhl6Rp21gJ/IVTW7Z3y9EWXhuUBC2Shnf+DX0antecpAwSP8w==} engines: {node: '>=10'} + dev: true /yargs-parser@21.1.1: resolution: {integrity: sha512-tVpsJW7DdjecAiFpbIB1e3qxIQsE6NoPc5/eTdrbbIC4h0LVsWhnoa3g+m2HclBIujHzsxZ4VJVA+GUuc2/LBw==} @@ -25712,6 +25700,7 @@ packages: string-width: 4.2.3 y18n: 5.0.8 yargs-parser: 20.2.9 + dev: true /yargs@17.5.1: resolution: {integrity: sha512-t6YAJcxDkNX7NFYiVtKvWUz8l+PaKTLiL63mJYWR2GnHq2gjEWISzsLp9wg3aY36dY1j+gfIEL3pIF+XlJJfbA==} @@ -25754,6 +25743,7 @@ packages: /yocto-queue@0.1.0: resolution: {integrity: sha512-rVksvsnNCdJ/ohGc6xgPwyN8eheCxsiLM8mxuE/t/mOVqJewPuO1miLpTHQiRgTKCLexL4MeAFVagts7HmNZ2Q==} engines: {node: '>=10'} + dev: true /yocto-queue@1.0.0: resolution: {integrity: sha512-9bnSc/HEW2uRy67wc+T8UwauLuPJVn28jb+GtJY16iiKWyvmYJRXVT4UamsAEGQfPohgr2q4Tq0sQbQlxTfi1g==} From 5aa323ba85a960a46bdeca01923a5c96d761ed6f Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 11 Jul 2023 12:47:05 +0200 Subject: [PATCH 42/87] chore: fix environment --- packages/ui/client/auto-imports.d.ts | 2 ++ packages/vitest/src/integrations/env/edge-runtime.ts | 7 ++++--- packages/vitest/src/integrations/env/happy-dom.ts | 6 +++--- packages/vitest/src/integrations/env/jsdom.ts | 4 ++-- packages/vitest/src/integrations/env/node.ts | 4 ++-- packages/vitest/src/runtime/vm.ts | 4 +++- test/core/vitest.config.ts | 4 ---- 7 files changed, 16 insertions(+), 15 deletions(-) diff --git a/packages/ui/client/auto-imports.d.ts b/packages/ui/client/auto-imports.d.ts index 1c97dd711fb4..8185410d6a10 100644 --- a/packages/ui/client/auto-imports.d.ts +++ b/packages/ui/client/auto-imports.d.ts @@ -129,6 +129,8 @@ declare global { const toRef: typeof import('vue')['toRef'] const toRefs: typeof import('vue')['toRefs'] const toValue: typeof import('vue')['toValue'] + const toggleDark: typeof import('./composables/dark')['toggleDark'] + const totalTests: typeof import('./composables/summary')['totalTests'] const triggerRef: typeof import('vue')['triggerRef'] const tryOnBeforeMount: typeof import('@vueuse/core')['tryOnBeforeMount'] const tryOnBeforeUnmount: typeof import('@vueuse/core')['tryOnBeforeUnmount'] diff --git a/packages/vitest/src/integrations/env/edge-runtime.ts b/packages/vitest/src/integrations/env/edge-runtime.ts index 1ccc055d7e64..5761a1339ae5 100644 --- a/packages/vitest/src/integrations/env/edge-runtime.ts +++ b/packages/vitest/src/integrations/env/edge-runtime.ts @@ -1,8 +1,9 @@ +import type vm from 'node:vm' import { importModule } from 'local-pkg' import type { Environment } from '../../types' import { populateGlobal } from './utils' -export default ({ +export default ({ name: 'edge-runtime', transformMode: 'ssr', async setupVM() { @@ -16,7 +17,7 @@ export default ({ }) return { getVmContext() { - return vm.context + return vm.context as vm.Context }, teardown() { // TODO @@ -40,4 +41,4 @@ export default ({ }, } }, -}) +}) satisfies Environment diff --git a/packages/vitest/src/integrations/env/happy-dom.ts b/packages/vitest/src/integrations/env/happy-dom.ts index cb05c9824b1f..f5c1c1a52b27 100644 --- a/packages/vitest/src/integrations/env/happy-dom.ts +++ b/packages/vitest/src/integrations/env/happy-dom.ts @@ -2,10 +2,10 @@ import { importModule } from 'local-pkg' import type { Environment } from '../../types' import { populateGlobal } from './utils' -export default ({ +export default ({ name: 'happy-dom', transformMode: 'web', - async setupVm() { + async setupVM() { const { Window } = await importModule('happy-dom') as typeof import('happy-dom') const win = new Window() @@ -40,4 +40,4 @@ export default ({ }, } }, -}) +}) satisfies Environment diff --git a/packages/vitest/src/integrations/env/jsdom.ts b/packages/vitest/src/integrations/env/jsdom.ts index 6310f00a9d80..26a983b84551 100644 --- a/packages/vitest/src/integrations/env/jsdom.ts +++ b/packages/vitest/src/integrations/env/jsdom.ts @@ -26,7 +26,7 @@ function catchWindowErrors(window: Window) { } } -export default ({ +export default ({ name: 'jsdom', transformMode: 'web', async setupVM({ jsdom = {} }) { @@ -125,4 +125,4 @@ export default ({ }, } }, -}) +}) satisfies Environment diff --git a/packages/vitest/src/integrations/env/node.ts b/packages/vitest/src/integrations/env/node.ts index bb15a319707b..3434267d9f14 100644 --- a/packages/vitest/src/integrations/env/node.ts +++ b/packages/vitest/src/integrations/env/node.ts @@ -30,7 +30,7 @@ const nodeGlobals = new Map( }), ) -export default ({ +export default ({ name: 'node', transformMode: 'ssr', // this is largely copied from jest's node environment @@ -120,4 +120,4 @@ export default ({ }, } }, -}) +}) satisfies Environment diff --git a/packages/vitest/src/runtime/vm.ts b/packages/vitest/src/runtime/vm.ts index 7c3bcae9ae1c..2595ab30960a 100644 --- a/packages/vitest/src/runtime/vm.ts +++ b/packages/vitest/src/runtime/vm.ts @@ -39,9 +39,11 @@ export async function run(ctx: WorkerContext) { const environment = await loadEnvironment(ctx.environment.name, ctx.config.root) if (!environment.setupVM) { + const envName = ctx.environment.name + const packageId = envName[0] === '.' ? envName : `vitest-environment-${envName}` throw new TypeError( `Environment "${ctx.environment.name}" is not a valid environment. ` - + `Package "vitest-environment-${name}" doesn't support vm environment because it doesn't provide "setupVM" method.`, + + `Path "${packageId}" doesn't support vm environment because it doesn't provide "setupVM" method.`, ) } diff --git a/test/core/vitest.config.ts b/test/core/vitest.config.ts index 50dde42c3112..9da89210a05d 100644 --- a/test/core/vitest.config.ts +++ b/test/core/vitest.config.ts @@ -49,10 +49,6 @@ export default defineConfig({ setupFiles: [ './test/setup.ts', ], - // TODO: remove this when PR is done - poolMatchGlobs: [ - ['**/*', 'experimentalVmThreads'], - ], testNamePattern: '^((?!does not include test that).)*$', coverage: { provider: 'istanbul', From 31cc8fa5ab39bad68f93199d0967e2bf841d40b8 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 11 Jul 2023 12:53:28 +0200 Subject: [PATCH 43/87] fix: revert satisfies --- .../src/integrations/env/edge-runtime.ts | 7 +++---- .../vitest/src/integrations/env/happy-dom.ts | 4 ++-- packages/vitest/src/integrations/env/jsdom.ts | 4 ++-- packages/vitest/src/integrations/env/node.ts | 4 ++-- packages/vitest/src/runtime/environment.ts | 21 +++++++++++++++++++ 5 files changed, 30 insertions(+), 10 deletions(-) create mode 100644 packages/vitest/src/runtime/environment.ts diff --git a/packages/vitest/src/integrations/env/edge-runtime.ts b/packages/vitest/src/integrations/env/edge-runtime.ts index 5761a1339ae5..1ccc055d7e64 100644 --- a/packages/vitest/src/integrations/env/edge-runtime.ts +++ b/packages/vitest/src/integrations/env/edge-runtime.ts @@ -1,9 +1,8 @@ -import type vm from 'node:vm' import { importModule } from 'local-pkg' import type { Environment } from '../../types' import { populateGlobal } from './utils' -export default ({ +export default ({ name: 'edge-runtime', transformMode: 'ssr', async setupVM() { @@ -17,7 +16,7 @@ export default ({ }) return { getVmContext() { - return vm.context as vm.Context + return vm.context }, teardown() { // TODO @@ -41,4 +40,4 @@ export default ({ }, } }, -}) satisfies Environment +}) diff --git a/packages/vitest/src/integrations/env/happy-dom.ts b/packages/vitest/src/integrations/env/happy-dom.ts index f5c1c1a52b27..5b092ac72028 100644 --- a/packages/vitest/src/integrations/env/happy-dom.ts +++ b/packages/vitest/src/integrations/env/happy-dom.ts @@ -2,7 +2,7 @@ import { importModule } from 'local-pkg' import type { Environment } from '../../types' import { populateGlobal } from './utils' -export default ({ +export default ({ name: 'happy-dom', transformMode: 'web', async setupVM() { @@ -40,4 +40,4 @@ export default ({ }, } }, -}) satisfies Environment +}) diff --git a/packages/vitest/src/integrations/env/jsdom.ts b/packages/vitest/src/integrations/env/jsdom.ts index 26a983b84551..6310f00a9d80 100644 --- a/packages/vitest/src/integrations/env/jsdom.ts +++ b/packages/vitest/src/integrations/env/jsdom.ts @@ -26,7 +26,7 @@ function catchWindowErrors(window: Window) { } } -export default ({ +export default ({ name: 'jsdom', transformMode: 'web', async setupVM({ jsdom = {} }) { @@ -125,4 +125,4 @@ export default ({ }, } }, -}) satisfies Environment +}) diff --git a/packages/vitest/src/integrations/env/node.ts b/packages/vitest/src/integrations/env/node.ts index 3434267d9f14..bb15a319707b 100644 --- a/packages/vitest/src/integrations/env/node.ts +++ b/packages/vitest/src/integrations/env/node.ts @@ -30,7 +30,7 @@ const nodeGlobals = new Map( }), ) -export default ({ +export default ({ name: 'node', transformMode: 'ssr', // this is largely copied from jest's node environment @@ -120,4 +120,4 @@ export default ({ }, } }, -}) satisfies Environment +}) diff --git a/packages/vitest/src/runtime/environment.ts b/packages/vitest/src/runtime/environment.ts new file mode 100644 index 000000000000..06b5e66cc289 --- /dev/null +++ b/packages/vitest/src/runtime/environment.ts @@ -0,0 +1,21 @@ +import { environments } from '../integrations/env' +import type { Environment } from '../types' + +export async function loadEnvironment(name: string, method: 'setup' | 'setupVM'): Promise { + if (name in environments) + return environments[name as 'jsdom'] + const pkg = await import(`vitest-environment-${name}`) + if (!pkg || !pkg.default || typeof pkg.default !== 'object') { + throw new Error( + `Environment "${name}" is not a valid environment. ` + + `Package "vitest-environment-${name}" should have default export with "${method}" method.`, + ) + } + if (typeof pkg.default[method] !== 'function') { + throw new TypeError( + `Environment "${name}" is not a valid environment. ` + + `Package "vitest-environment-${name}" doesn't support ${method === 'setupVM' ? 'vm' : 'non-vm'} environment because it doesn't provide "${method}" method.`, + ) + } + return pkg.default +} From 2f2580aefd649359db905154d1c1a2c0c8524968 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 11 Jul 2023 13:38:03 +0200 Subject: [PATCH 44/87] fix: improve type module check --- .github/workflows/ci.yml | 3 + package.json | 1 + packages/vite-node/src/server.ts | 142 +++++++++++++++++- packages/vitest/src/node/pools/rpc.ts | 4 + packages/vitest/src/runtime/execute.ts | 9 +- .../vitest/src/runtime/external-executor.ts | 25 +-- packages/vitest/src/types/rpc.ts | 5 +- pnpm-lock.yaml | 54 ++++++- 8 files changed, 223 insertions(+), 20 deletions(-) diff --git a/.github/workflows/ci.yml b/.github/workflows/ci.yml index cc4811c66980..57e8b3852476 100644 --- a/.github/workflows/ci.yml +++ b/.github/workflows/ci.yml @@ -84,6 +84,9 @@ jobs: - name: Test Single Thread run: pnpm run test:ci:single-thread + - name: Test Vm Threads + run: pnpm run test:ci:vm-threads + test-ui: runs-on: ubuntu-latest diff --git a/package.json b/package.json index 3b9ee959ae95..b4ff21bea692 100644 --- a/package.json +++ b/package.json @@ -23,6 +23,7 @@ "test:run": "vitest run -r test/core", "test:all": "CI=true pnpm -r --stream run test --allowOnly", "test:ci": "CI=true pnpm -r --stream --filter !test-fails --filter !test-browser --filter !test-esm --filter !test-browser run test --allowOnly", + "test:ci:vm-threads": "CI=true pnpm -r --stream --filter !test-fails --filter !test-browser --filter !test-esm --filter !test-browser run test --allowOnly --experimental-vm-threads", "test:ci:single-thread": "CI=true pnpm -r --stream --filter !test-fails --filter !test-coverage --filter !test-watch --filter !test-bail --filter !test-esm --filter !test-browser run test --allowOnly --no-threads", "typecheck": "tsc --noEmit", "typecheck:why": "tsc --noEmit --explainFiles > explainTypes.txt", diff --git a/packages/vite-node/src/server.ts b/packages/vite-node/src/server.ts index 17834bb2e367..2a9ab558d648 100644 --- a/packages/vite-node/src/server.ts +++ b/packages/vite-node/src/server.ts @@ -1,7 +1,7 @@ import { performance } from 'node:perf_hooks' -import { existsSync } from 'node:fs' -import { join, normalize, relative, resolve } from 'pathe' -import type { TransformResult, ViteDevServer } from 'vite' +import { existsSync, readFileSync, statSync } from 'node:fs' +import { dirname, join, normalize, relative, resolve } from 'pathe' +import { type PackageCache, type PackageData, type TransformResult, type ViteDevServer, createFilter } from 'vite' import createDebug from 'debug' import type { EncodedSourceMap } from '@jridgewell/trace-mapping' import type { DebuggerOptions, FetchResult, ViteNodeResolveId, ViteNodeServerOptions } from './types' @@ -27,6 +27,7 @@ export class ViteNodeServer { }>() externalizeCache = new Map>() + packageCache = new Map() debugger?: Debugger @@ -150,6 +151,40 @@ export class ViteNodeServer { return this.transformPromiseMap.get(id)! } + findNearestPackageData(basedir: string) { + const config = this.server.config + // @ts-expect-error not typed + const packageCache = config.packageCache || this.packageCache + const originalBasedir = basedir + while (basedir) { + if (packageCache) { + const cached = getFnpdCache(packageCache, basedir, originalBasedir) + if (cached) + return cached + } + + const pkgPath = join(basedir, 'package.json') + try { + if (statSync(pkgPath, { throwIfNoEntry: false })?.isFile()) { + const pkgData = loadPackageData(pkgPath) + + if (packageCache) + setFnpdCache(packageCache, pkgData, basedir, originalBasedir) + + return pkgData + } + } + catch {} + + const nextBasedir = dirname(basedir) + if (nextBasedir === basedir) + break + basedir = nextBasedir + } + + return null + } + getTransformMode(id: string) { const withoutQuery = id.split('?')[0] @@ -251,3 +286,104 @@ export class ViteNodeServer { return result } } + +export function loadPackageData(pkgPath: string): PackageData { + const data = JSON.parse(readFileSync(pkgPath, 'utf-8')) + const pkgDir = dirname(pkgPath) + const { sideEffects } = data + let hasSideEffects: (id: string) => boolean + if (typeof sideEffects === 'boolean') { + hasSideEffects = () => sideEffects + } + else if (Array.isArray(sideEffects)) { + const finalPackageSideEffects = sideEffects.map((sideEffect) => { + /* + * The array accepts simple glob patterns to the relevant files... Patterns like *.css, which do not include a /, will be treated like **\/*.css. + * https://webpack.js.org/guides/tree-shaking/ + * https://github.com/vitejs/vite/pull/11807 + */ + if (sideEffect.includes('/')) + return sideEffect + + return `**/${sideEffect}` + }) + + hasSideEffects = createFilter(finalPackageSideEffects, null, { + resolve: pkgDir, + }) + } + else { + hasSideEffects = () => true + } + + const pkg: PackageData = { + dir: pkgDir, + data, + hasSideEffects, + webResolvedImports: {}, + nodeResolvedImports: {}, + setResolvedCache(key: string, entry: string, targetWeb: boolean) { + if (targetWeb) + pkg.webResolvedImports[key] = entry + else + pkg.nodeResolvedImports[key] = entry + }, + getResolvedCache(key: string, targetWeb: boolean) { + if (targetWeb) + return pkg.webResolvedImports[key] + + else + return pkg.nodeResolvedImports[key] + }, + } + + return pkg +} + +function getFnpdCache( + packageCache: PackageCache, + basedir: string, + originalBasedir: string, +) { + const cacheKey = getFnpdCacheKey(basedir) + const pkgData = packageCache.get(cacheKey) + if (pkgData) { + traverseBetweenDirs(originalBasedir, basedir, (dir) => { + packageCache.set(getFnpdCacheKey(dir), pkgData) + }) + return pkgData + } +} + +function setFnpdCache( + packageCache: PackageCache, + pkgData: PackageData, + basedir: string, + originalBasedir: string, +) { + packageCache.set(getFnpdCacheKey(basedir), pkgData) + traverseBetweenDirs(originalBasedir, basedir, (dir) => { + packageCache.set(getFnpdCacheKey(dir), pkgData) + }) +} + +// package cache key for `findNearestPackageData` +function getFnpdCacheKey(basedir: string) { + return `fnpd_${basedir}` +} + +/** + * Traverse between `longerDir` (inclusive) and `shorterDir` (exclusive) and call `cb` for each dir. + * @param longerDir Longer dir path, e.g. `/User/foo/bar/baz` + * @param shorterDir Shorter dir path, e.g. `/User/foo` + */ +function traverseBetweenDirs( + longerDir: string, + shorterDir: string, + cb: (dir: string) => void, +) { + while (longerDir !== shorterDir) { + cb(longerDir) + longerDir = dirname(longerDir) + } +} diff --git a/packages/vitest/src/node/pools/rpc.ts b/packages/vitest/src/node/pools/rpc.ts index 020ea2cf4747..2b4e351be41a 100644 --- a/packages/vitest/src/node/pools/rpc.ts +++ b/packages/vitest/src/node/pools/rpc.ts @@ -61,5 +61,9 @@ export function createMethodsRPC(project: WorkspaceProject): RuntimeRPC { getCountOfFailedTests() { return ctx.state.getCountOfFailedTests() }, + async findNearestPackageData(file) { + const pkgData = project.vitenode.findNearestPackageData(file) + return pkgData?.data || {} + }, } } diff --git a/packages/vitest/src/runtime/execute.ts b/packages/vitest/src/runtime/execute.ts index ba1499b724a3..f93c8fdf0348 100644 --- a/packages/vitest/src/runtime/execute.ts +++ b/packages/vitest/src/runtime/execute.ts @@ -6,7 +6,7 @@ import type { ViteNodeRunnerOptions } from 'vite-node' import { normalize, relative, resolve } from 'pathe' import { processError } from '@vitest/utils/error' import type { MockMap } from '../types/mocker' -import type { ResolvedConfig, ResolvedTestEnvironment, WorkerGlobalState } from '../types' +import type { ResolvedConfig, ResolvedTestEnvironment, RuntimeRPC, WorkerGlobalState } from '../types' import { distDir } from '../paths' import { getWorkerState } from '../utils/global' import { VitestMocker } from './mocker' @@ -18,6 +18,7 @@ export interface ExecuteOptions extends ViteNodeRunnerOptions { mockMap: MockMap moduleDirectories?: string[] context?: vm.Context + findNearestPackageData?: RuntimeRPC['findNearestPackageData'] state: WorkerGlobalState } @@ -55,6 +56,7 @@ export interface ContextExecutorOptions { mockMap?: MockMap moduleCache?: ModuleCacheMap context?: vm.Context + findNearestPackageData?: RuntimeRPC['findNearestPackageData'] state: WorkerGlobalState } @@ -96,6 +98,9 @@ export async function startVitestExecutor(options: ContextExecutorOptions) { resolveId(id, importer) { return rpc().resolveId(id, importer, getTransformMode()) }, + findNearestPackageData(file) { + return rpc().findNearestPackageData(file) + }, moduleCache, mockMap, get interopDefault() { return state().config.deps.interopDefault }, @@ -123,7 +128,7 @@ export class VitestExecutor extends ViteNodeRunner { }) } else { - this.externalModules = new ExternalModulesExecutor(options.context) + this.externalModules = new ExternalModulesExecutor(options.context, options.findNearestPackageData || (() => Promise.resolve({}))) } } diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index 2805e4d5913b..2f56e06faad8 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -7,9 +7,9 @@ import { createRequire } from 'node:module' import { readFileSync } from 'node:fs' import { readFile } from 'node:fs/promises' import { resolve as resolveModule } from 'import-meta-resolve' -import { hasESMSyntax } from 'mlly' import { extname } from 'pathe' import { isNodeBuiltin } from 'vite-node/utils' +import type { RuntimeRPC } from '../types' // need to copy paste types for vm // because they require latest @types/node which we don't bundle @@ -91,15 +91,13 @@ const nativeResolve = import.meta.resolve // TODO: improve Node.js strict mode support in #2854 export class ExternalModulesExecutor { - private context: vm.Context - private requireCache: Record = Object.create(null) private moduleCache = new Map() private extensions: Record string> = Object.create(null) private esmLinkMap = new WeakMap>() - constructor(context: vm.Context) { + constructor(private context: vm.Context, private findNearestPackageData: RuntimeRPC['findNearestPackageData']) { this.context = context this.requireCache = Object.create(null) @@ -292,17 +290,26 @@ export class ExternalModulesExecutor { const isFileUrl = identifier.startsWith('file://') const fileUrl = isFileUrl ? identifier : pathToFileURL(identifier).toString() const pathUrl = isFileUrl ? fileURLToPath(identifier) : identifier - const inlineCode = this.getIdentifierCode(identifier) - const code = inlineCode || await readFile(pathUrl, 'utf-8') - // TODO: very dirty check for cjs, it should actually check filepath and package.json, improve in #2854 - if (!inlineCode && (extension === '.cjs' || !hasESMSyntax(code))) { + if (extension === '.cjs') { const module = this.createCommonJSNodeModule(pathUrl) const exports = this.evaluateCommonJSModule(module, pathUrl) return this.wrapSynteticModule(fileUrl, 'cjs', exports) } - return await this.createEsmModule(fileUrl, code) + const inlineCode = this.getIdentifierCode(identifier) + + if (inlineCode || extension === '.mjs') + return await this.createEsmModule(fileUrl, inlineCode || await readFile(pathUrl, 'utf8')) + + const pkgData = await this.findNearestPackageData(pathUrl) + + if (pkgData.type === 'module') + return await this.createEsmModule(fileUrl, await readFile(pathUrl, 'utf8')) + + const module = this.createCommonJSNodeModule(pathUrl) + const exports = this.evaluateCommonJSModule(module, pathUrl) + return this.wrapSynteticModule(fileUrl, 'cjs', exports) } async import(identifier: string) { diff --git a/packages/vitest/src/types/rpc.ts b/packages/vitest/src/types/rpc.ts index e3f0f9e5acef..0029cf77c834 100644 --- a/packages/vitest/src/types/rpc.ts +++ b/packages/vitest/src/types/rpc.ts @@ -21,8 +21,9 @@ export interface RuntimeRPC { onCollected: (files: File[]) => void onAfterSuiteRun: (meta: AfterSuiteRunMeta) => void onTaskUpdate: (pack: TaskResultPack[]) => void - onCancel(reason: CancelReason): void - getCountOfFailedTests(): number + onCancel: (reason: CancelReason) => void + getCountOfFailedTests: () => number + findNearestPackageData: (file: string) => Promise> snapshotSaved: (snapshot: SnapshotResult) => void resolveSnapshotPath: (testPath: string) => string diff --git a/pnpm-lock.yaml b/pnpm-lock.yaml index 377fa082f01c..d302a0eca75f 100644 --- a/pnpm-lock.yaml +++ b/pnpm-lock.yaml @@ -1218,7 +1218,7 @@ importers: version: 6.7.14 debug: specifier: ^4.3.4 - version: 4.3.4(supports-color@8.1.1) + version: 4.3.4 mlly: specifier: ^1.4.0 version: 1.4.0 @@ -1230,7 +1230,7 @@ importers: version: 1.0.0 vite: specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) + version: 4.3.9 devDependencies: '@jridgewell/trace-mapping': specifier: ^0.3.18 @@ -8818,6 +8818,7 @@ packages: /@types/node@18.16.19: resolution: {integrity: sha512-IXl7o+R9iti9eBW4Wg2hx1xQDig183jj7YLn8F7udNceyfkbn1ZxmzZXuak20gR40D7pIkIY1kYGx5VIGbaHKA==} + dev: true /@types/node@18.7.13: resolution: {integrity: sha512-46yIhxSe5xEaJZXWdIBP7GU4HDTG8/eo0qd9atdiL+lFpA03y8KS+lkTN834TWJj5767GbWv4n/P6efyTFt1Dw==} @@ -12974,6 +12975,18 @@ packages: supports-color: 8.1.1 dev: true + /debug@4.3.4: + resolution: {integrity: sha512-PRWFHuSU3eDtQJPvnNY7Jcket1j0t5OuOsFzPPzsekD52Zl8qUfFIPEiswXqIvHWGVHOgX+7G/vCNNhehwxfkQ==} + engines: {node: '>=6.0'} + peerDependencies: + supports-color: '*' + peerDependenciesMeta: + supports-color: + optional: true + dependencies: + ms: 2.1.2 + dev: false + /debug@4.3.4(supports-color@8.1.1): resolution: {integrity: sha512-PRWFHuSU3eDtQJPvnNY7Jcket1j0t5OuOsFzPPzsekD52Zl8qUfFIPEiswXqIvHWGVHOgX+7G/vCNNhehwxfkQ==} engines: {node: '>=6.0'} @@ -24264,7 +24277,7 @@ packages: debug: 4.3.4(supports-color@8.1.1) fast-glob: 3.3.0 local-pkg: 0.4.3 - magic-string: 0.30.0 + magic-string: 0.30.1 minimatch: 9.0.1 resolve: 1.22.2 unplugin: 1.3.1 @@ -24293,7 +24306,7 @@ packages: debug: 4.3.4(supports-color@8.1.1) fast-glob: 3.3.0 local-pkg: 0.4.3 - magic-string: 0.30.0 + magic-string: 0.30.1 minimatch: 9.0.1 resolve: 1.22.2 unplugin: 1.3.1 @@ -24606,6 +24619,38 @@ packages: - supports-color dev: true + /vite@4.3.9: + resolution: {integrity: sha512-qsTNZjO9NoJNW7KnOrgYwczm0WctJ8m/yqYAMAK9Lxt4SoySUfS5S8ia9K7JHpa3KEeMfyF8LoJ3c5NeBJy6pg==} + engines: {node: ^14.18.0 || >=16.0.0} + hasBin: true + peerDependencies: + '@types/node': '>= 14' + less: '*' + sass: '*' + stylus: '*' + sugarss: '*' + terser: ^5.4.0 + peerDependenciesMeta: + '@types/node': + optional: true + less: + optional: true + sass: + optional: true + stylus: + optional: true + sugarss: + optional: true + terser: + optional: true + dependencies: + esbuild: 0.17.18 + postcss: 8.4.24 + rollup: 3.23.0 + optionalDependencies: + fsevents: 2.3.2 + dev: false + /vite@4.3.9(@types/node@18.16.19): resolution: {integrity: sha512-qsTNZjO9NoJNW7KnOrgYwczm0WctJ8m/yqYAMAK9Lxt4SoySUfS5S8ia9K7JHpa3KEeMfyF8LoJ3c5NeBJy6pg==} engines: {node: ^14.18.0 || >=16.0.0} @@ -24637,6 +24682,7 @@ packages: rollup: 3.23.0 optionalDependencies: fsevents: 2.3.2 + dev: true /vite@4.3.9(@types/node@18.7.13): resolution: {integrity: sha512-qsTNZjO9NoJNW7KnOrgYwczm0WctJ8m/yqYAMAK9Lxt4SoySUfS5S8ia9K7JHpa3KEeMfyF8LoJ3c5NeBJy6pg==} From 385bb5a16233aefd6bfc7c7674b8491f2ced6c9d Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 11 Jul 2023 14:12:09 +0200 Subject: [PATCH 45/87] chore: fix path --- packages/vitest/src/integrations/env/index.ts | 9 ++++++--- packages/vitest/src/runtime/vm.ts | 2 +- .../vitest-environment-custom/index.mjs | 20 +++++++++++++++++++ 3 files changed, 27 insertions(+), 4 deletions(-) diff --git a/packages/vitest/src/integrations/env/index.ts b/packages/vitest/src/integrations/env/index.ts index 081e68059109..f692138068a9 100644 --- a/packages/vitest/src/integrations/env/index.ts +++ b/packages/vitest/src/integrations/env/index.ts @@ -1,5 +1,6 @@ import { pathToFileURL } from 'node:url' -import { resolve } from 'pathe' +import { normalize, resolve } from 'pathe' +import { resolveModule } from 'local-pkg' import type { BuiltinEnvironment, VitestEnvironment } from '../../types/config' import type { Environment } from '../../types' import node from './node' @@ -37,8 +38,10 @@ export function getEnvPackageName(env: VitestEnvironment) { export async function loadEnvironment(name: VitestEnvironment, root: string): Promise { if (isBuiltinEnvironment(name)) return environments[name] - const packageId = (name[0] === '.' || name[0] === '/') ? resolve(root, name) : `vitest-environment-${name}` - const pkg = await import(pathToFileURL(packageId).href) + const packageId = name[0] === '.' || name[0] === '/' + ? resolve(root, name) + : resolveModule(`vitest-environment-${name}`, { paths: [root] }) ?? resolve(root, name) + const pkg = await import(pathToFileURL(normalize(packageId)).href) if (!pkg || !pkg.default || typeof pkg.default !== 'object' || typeof pkg.default.setup !== 'function') { throw new Error( `Environment "${name}" is not a valid environment. ` diff --git a/packages/vitest/src/runtime/vm.ts b/packages/vitest/src/runtime/vm.ts index 2595ab30960a..90610c0163a3 100644 --- a/packages/vitest/src/runtime/vm.ts +++ b/packages/vitest/src/runtime/vm.ts @@ -65,7 +65,7 @@ export async function run(ctx: WorkerContext) { getSourceMap: source => moduleCache.getSourceMap(source), }) - const vm = await environment.setupVM!(ctx.environment.options || {}) + const vm = await environment.setupVM!(ctx.environment.options || ctx.config.environmentOptions || {}) state.durations.environment = performance.now() - state.durations.environment diff --git a/test/env-custom/vitest-environment-custom/index.mjs b/test/env-custom/vitest-environment-custom/index.mjs index 7fc3b0755779..da512a72ebda 100644 --- a/test/env-custom/vitest-environment-custom/index.mjs +++ b/test/env-custom/vitest-environment-custom/index.mjs @@ -1,5 +1,25 @@ +import vm from 'node:vm' + export default { name: 'custom', + transformMode: 'ssr', + setupVM({ custom }) { + const context = vm.createContext({ + testEnvironment: 'custom', + option: custom.option, + setTimeout, + clearTimeout, + }) + return { + getVmContext() { + return context + }, + teardown() { + delete context.testEnvironment + delete context.option + }, + } + }, setup(global, { custom }) { global.testEnvironment = 'custom' global.option = custom.option From 61692faede447e34c1ef887b9e0520ad7e14425d Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 11 Jul 2023 14:21:59 +0200 Subject: [PATCH 46/87] chore: docs and validation --- docs/config/index.md | 1 + docs/guide/environment.md | 20 ++++++++++++++++++- packages/vitest/src/integrations/env/index.ts | 15 ++++++++++---- packages/vitest/src/runtime/vm.ts | 9 ++++++++- packages/vitest/src/types/general.ts | 2 +- 5 files changed, 40 insertions(+), 7 deletions(-) diff --git a/docs/config/index.md b/docs/config/index.md index 5722359d1b29..83743e6bd415 100644 --- a/docs/config/index.md +++ b/docs/config/index.md @@ -421,6 +421,7 @@ import type { Environment } from 'vitest' export default { name: 'custom', + transformMode: 'ssr', setup() { // custom setup return { diff --git a/docs/guide/environment.md b/docs/guide/environment.md index dfd365fa0316..b5494c109108 100644 --- a/docs/guide/environment.md +++ b/docs/guide/environment.md @@ -27,13 +27,27 @@ Or you can also set [`environmentMatchGlobs`](https://vitest.dev/config/#environ ## Custom Environment -Starting from 0.23.0, you can create your own package to extend Vitest environment. To do so, create package with the name `vitest-environment-${name}`. That package should export an object with the shape of `Environment`: +Starting from 0.23.0, you can create your own package to extend Vitest environment. To do so, create package with the name `vitest-environment-${name}` or specify a path to a valid JS file (supported since 0.34.0). That package should export an object with the shape of `Environment`: ```ts import type { Environment } from 'vitest' export default { name: 'custom', + transformMode: 'ssr', + // optional - only if you support "experimental-vm" pool + async setupVM() { + const vm = await import('node:vm') + const context = vm.createContext() + return { + getVmContext() { + return context + }, + teardown() { + // called after all tests with this env have been run + } + } + }, setup() { // custom setup return { @@ -45,6 +59,10 @@ export default { } ``` +::: warning +Since 0.34.0 Vitest requires `transformMode` option on environment object. It should be equal to `ssr` or `web`. This value determines how plugins will transform source code. If it's set to `ssr`, plugin hooks will receive `ssr: true` when transforming or resolving files. Otherwise, `ssr` is set to `false`. +::: + You also have access to default Vitest environments through `vitest/environments` entry: ```ts diff --git a/packages/vitest/src/integrations/env/index.ts b/packages/vitest/src/integrations/env/index.ts index f692138068a9..ceb8d073c687 100644 --- a/packages/vitest/src/integrations/env/index.ts +++ b/packages/vitest/src/integrations/env/index.ts @@ -42,11 +42,18 @@ export async function loadEnvironment(name: VitestEnvironment, root: string): Pr ? resolve(root, name) : resolveModule(`vitest-environment-${name}`, { paths: [root] }) ?? resolve(root, name) const pkg = await import(pathToFileURL(normalize(packageId)).href) - if (!pkg || !pkg.default || typeof pkg.default !== 'object' || typeof pkg.default.setup !== 'function') { - throw new Error( + if (!pkg || !pkg.default || typeof pkg.default !== 'object') { + throw new TypeError( `Environment "${name}" is not a valid environment. ` - + `Path "${packageId}" should export default object with a "setup" method.`, + + `Path "${packageId}" should export default object with a "setup" or/and "setupVM" method.`, ) } - return pkg.default + const environment = pkg.default + if (!environment.transformMode) { + throw new TypeError( + `Environment "${name}" is not a valid environment. ` + + `Path "${packageId}" should export default object with a "transformMode" method equal to "ssr" or "web".`, + ) + } + return environment } diff --git a/packages/vitest/src/runtime/vm.ts b/packages/vitest/src/runtime/vm.ts index 90610c0163a3..d378ba68ad77 100644 --- a/packages/vitest/src/runtime/vm.ts +++ b/packages/vitest/src/runtime/vm.ts @@ -1,5 +1,6 @@ import { pathToFileURL } from 'node:url' import { performance } from 'node:perf_hooks' +import { isContext } from 'node:vm' import { ModuleCacheMap } from 'vite-node/client' import { workerId as poolId } from 'tinypool' import { createBirpc } from 'birpc' @@ -72,8 +73,14 @@ export async function run(ctx: WorkerContext) { process.env.VITEST_WORKER_ID = String(ctx.workerId) process.env.VITEST_POOL_ID = String(poolId) + if (!vm.getVmContext) + throw new TypeError(`Environment ${ctx.environment.name} doesn't provide "getVmContext" method. It should return a context created by "vm.createContext" method.`) + const context = vm.getVmContext() + if (!isContext(context)) + throw new TypeError(`Environment ${ctx.environment.name} doesn't provide a valid context. It should be created by "vm.createContext" method.`) + context.__vitest_worker__ = state // this is unfortunately needed for our own dependencies // we need to find a way to not rely on this by default @@ -105,7 +112,7 @@ export async function run(ctx: WorkerContext) { await run(ctx.files, ctx.config, executor) } finally { - await vm.teardown() + await vm.teardown?.() state.environmentTeardownRun = true } } diff --git a/packages/vitest/src/types/general.ts b/packages/vitest/src/types/general.ts index 6ca86146f7ef..776ac609adeb 100644 --- a/packages/vitest/src/types/general.ts +++ b/packages/vitest/src/types/general.ts @@ -28,7 +28,7 @@ export interface VmEnvironmentReturn { export interface Environment { name: string - transformMode?: 'web' | 'ssr' + transformMode: 'web' | 'ssr' setupVM?(options: Record): Awaitable setup(global: any, options: Record): Awaitable } From b228f67fa2b5f983e9c278c0ac9907bb693438c9 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 11 Jul 2023 15:06:26 +0200 Subject: [PATCH 47/87] chore: provide env name in browser context --- packages/browser/src/client/main.ts | 3 +++ test/public-api/tests/runner.spec.ts | 4 +++- 2 files changed, 6 insertions(+), 1 deletion(-) diff --git a/packages/browser/src/client/main.ts b/packages/browser/src/client/main.ts index 046dbe7f941d..47171f97c036 100644 --- a/packages/browser/src/client/main.ts +++ b/packages/browser/src/client/main.ts @@ -68,6 +68,9 @@ ws.addEventListener('open', async () => { globalThis.__vitest_worker__ = { config, browserHashMap, + environment: { + name: 'browser', + }, // @ts-expect-error untyped global for internal use moduleCache: globalThis.__vi_module_cache__, rpc: client.rpc, diff --git a/test/public-api/tests/runner.spec.ts b/test/public-api/tests/runner.spec.ts index f81fc719043e..bf177e02382b 100644 --- a/test/public-api/tests/runner.spec.ts +++ b/test/public-api/tests/runner.spec.ts @@ -18,7 +18,7 @@ it.each([ ] as UserConfig[])('passes down metadata when $name', async (config) => { const taskUpdate: TaskResultPack[] = [] const finishedFiles: File[] = [] - const { vitest, stdout } = await runVitest({ + const { vitest, stdout, stderr } = await runVitest({ root: resolve(__dirname, '..', 'fixtures'), include: ['**/*.spec.ts'], reporters: [ @@ -35,6 +35,8 @@ it.each([ ...config, }) + expect(stderr).toBe('') + expect(stdout).toContain('custom.spec.ts > custom') const suiteMeta = { done: true } From a2e30f731c3b3ab866836d8e07452f831f027ac3 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 11 Jul 2023 16:26:56 +0200 Subject: [PATCH 48/87] chore: improve compatibility with node.js --- .../vitest/src/runtime/external-executor.ts | 169 ++++++++++++------ 1 file changed, 116 insertions(+), 53 deletions(-) diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index 2f56e06faad8..b6df589519a9 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -3,7 +3,7 @@ import vm from 'node:vm' import { fileURLToPath, pathToFileURL } from 'node:url' import { dirname } from 'node:path' -import { createRequire } from 'node:module' +import { Module as _Module, createRequire } from 'node:module' import { readFileSync } from 'node:fs' import { readFile } from 'node:fs/promises' import { resolve as resolveModule } from 'import-meta-resolve' @@ -85,6 +85,10 @@ declare class VMSourceTextModule extends VMModule { const SyntheticModule: typeof VMSyntheticModule = (vm as any).SyntheticModule const SourceTextModule: typeof VMSourceTextModule = (vm as any).SourceTextModule +interface PrivateNodeModule extends NodeModule { + _compile(code: string, filename: string): void +} + const _require = createRequire(import.meta.url) const nativeResolve = import.meta.resolve @@ -92,26 +96,118 @@ const nativeResolve = import.meta.resolve // TODO: improve Node.js strict mode support in #2854 export class ExternalModulesExecutor { private requireCache: Record = Object.create(null) + private builtinCache: Record = Object.create(null) private moduleCache = new Map() - private extensions: Record string> = Object.create(null) + private extensions: Record unknown> = Object.create(null) private esmLinkMap = new WeakMap>() + private Module: typeof _Module + constructor(private context: vm.Context, private findNearestPackageData: RuntimeRPC['findNearestPackageData']) { this.context = context - this.requireCache = Object.create(null) + + // eslint-disable-next-line @typescript-eslint/no-this-alias + const executor = this + + this.Module = class Module { + exports = {} + isPreloading = false + require: NodeRequire + id: string + filename: string + loaded: boolean + parent: null | Module | undefined + children: Module[] = [] + path: string + paths: string[] + + constructor(id: string, parent?: Module) { + this.exports = {} + this.isPreloading = false + this.require = Module.createRequire(id) + // in our case the path should always be resolved already + this.path = dirname(id) + this.id = id + this.filename = id + this.loaded = false + this.parent = parent + this.children = [] + this.paths = [] + } + + _compile(code: string, filename: string) { + const cjsModule = _Module.wrap(code) + const script = new vm.Script(cjsModule, { + filename, + importModuleDynamically: executor.importModuleDynamically, + } as any) + // @ts-expect-error mark script with current identifier + script.identifier = filename + const fn = script.runInContext(context) + const __dirname = dirname(filename) + executor.requireCache[filename] = this + try { + fn(this.exports, this.require, this, filename, __dirname) + return this.exports + } + finally { + this.loaded = true + } + } + + // exposed for external use, Node.js does the opposite + static _load = (request: string, parent: Module | undefined, _isMain: boolean) => { + const require = Module.createRequire(parent?.filename ?? request) + return require(request) + } + + static builtinModules = _Module.builtinModules + static wrap = _Module.wrap + static isBuiltin = _Module.isBuiltin + static findSourceMap = _Module.findSourceMap + static SourceMap = _Module.SourceMap + static syncBuiltinESMExports = _Module.syncBuiltinESMExports + + static _cache = executor.moduleCache + static _extensions = executor.extensions + + static createRequire = (filename: string) => { + return executor.createRequire(filename) + } + + static runMain = () => { + throw new Error('[vitest] "runMain" is not implemented.') + } + + // @ts-expect-error not typed + static _resolveFilename = _Module._resolveFilename + // @ts-expect-error not typed + static _findPath = _Module._findPath + // @ts-expect-error not typed + static _initPaths = _Module._initPaths + // @ts-expect-error not typed + static _preloadModules = _Module._preloadModules + // @ts-expect-error not typed + static _resolveLookupPaths = _Module._resolveLookupPaths + // @ts-expect-error not typed + static globalPaths = _Module.globalPaths + + static Module = Module + } this.extensions['.js'] = this.requireJs this.extensions['.json'] = this.requireJson } private requireJs = (m: NodeModule, filename: string) => { - return readFileSync(filename, 'utf-8') + const content = readFileSync(filename, 'utf-8') + ;(m as PrivateNodeModule)._compile(content, filename) } private requireJson = (m: NodeModule, filename: string) => { const code = readFileSync(filename, 'utf-8') - return `module.exports = ${code}` + m.exports = JSON.parse(code) } public importModuleDynamically = async (specifier: string, referencer: VMModule) => { @@ -172,7 +268,7 @@ export class ExternalModulesExecutor { if (ext === '.node' || isNodeBuiltin(filename)) return this.requireCoreModule(filename) const module = this.createCommonJSNodeModule(filename) - return this.evaluateCommonJSModule(module, filename) + return this.loadCommonJSModule(module, filename) }) as NodeRequire require.resolve = _require.resolve Object.defineProperty(require, 'extensions', { @@ -186,53 +282,20 @@ export class ExternalModulesExecutor { } private createCommonJSNodeModule(filename: string) { - const require = this.createRequire(filename) - const __dirname = dirname(filename) - // dirty non-spec implementation - doesn't support children, parent, etc - const module: NodeModule = { - exports: {}, - isPreloading: false, - require, - id: filename, - filename, - loaded: false, - parent: null, - children: [], - path: __dirname, - paths: [], - } - return module + return new this.Module(filename) } // very naive implementation for Node.js require - private evaluateCommonJSModule(module: NodeModule, filename: string): Record { + private loadCommonJSModule(module: NodeModule, filename: string): Record { const cached = this.requireCache[filename] if (cached) return cached.exports const extension = extname(filename) const loader = this.extensions[extension] || this.extensions['.js'] - const result = loader(module, filename) - - const code = typeof result === 'string' ? result : '' - - const cjsModule = `(function (exports, require, module, __filename, __dirname) { ${code}\n})` - const script = new vm.Script(cjsModule, { - filename, - importModuleDynamically: this.importModuleDynamically, - } as any) - // @ts-expect-error mark script with current identifier - script.identifier = filename - const fn = script.runInContext(this.context) - const __dirname = dirname(filename) - this.requireCache[filename] = module - try { - fn(module.exports, module.require, module, filename, __dirname) - return module.exports - } - finally { - module.loaded = true - } + loader(module, filename) + + return module.exports } private async createEsmModule(fileUrl: string, code: string) { @@ -261,16 +324,16 @@ export class ExternalModulesExecutor { private requireCoreModule(identifier: string) { const normalized = identifier.replace(/^node:/, '') - if (this.requireCache[normalized]) - return this.requireCache[normalized].exports + if (this.builtinCache[normalized]) + return this.builtinCache[normalized].exports const moduleExports = _require(identifier) if (identifier === 'node:module' || identifier === 'module') { - const exports = { ...moduleExports, createRequire: this.createRequire } - const cached = _require.cache[normalized]! - this.requireCache[normalized] = { ...cached, exports } - return exports + const module = new this.Module('/module.js') // path should not matter + module.exports = this.Module + this.builtinCache[normalized] = module + return module.exports } - this.requireCache[normalized] = _require.cache[normalized]! + this.builtinCache[normalized] = _require.cache[normalized]! return moduleExports } @@ -293,7 +356,7 @@ export class ExternalModulesExecutor { if (extension === '.cjs') { const module = this.createCommonJSNodeModule(pathUrl) - const exports = this.evaluateCommonJSModule(module, pathUrl) + const exports = this.loadCommonJSModule(module, pathUrl) return this.wrapSynteticModule(fileUrl, 'cjs', exports) } @@ -308,7 +371,7 @@ export class ExternalModulesExecutor { return await this.createEsmModule(fileUrl, await readFile(pathUrl, 'utf8')) const module = this.createCommonJSNodeModule(pathUrl) - const exports = this.evaluateCommonJSModule(module, pathUrl) + const exports = this.loadCommonJSModule(module, pathUrl) return this.wrapSynteticModule(fileUrl, 'cjs', exports) } From 87d46ec40a19b618e5b5f923bcb69e9fe96325b3 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 11 Jul 2023 16:42:43 +0200 Subject: [PATCH 49/87] chore: ignore isBuiltin --- packages/vitest/src/runtime/external-executor.ts | 4 +++- 1 file changed, 3 insertions(+), 1 deletion(-) diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index b6df589519a9..1edacba810a3 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -164,7 +164,6 @@ export class ExternalModulesExecutor { static builtinModules = _Module.builtinModules static wrap = _Module.wrap - static isBuiltin = _Module.isBuiltin static findSourceMap = _Module.findSourceMap static SourceMap = _Module.SourceMap static syncBuiltinESMExports = _Module.syncBuiltinESMExports @@ -192,6 +191,9 @@ export class ExternalModulesExecutor { static _resolveLookupPaths = _Module._resolveLookupPaths // @ts-expect-error not typed static globalPaths = _Module.globalPaths + // eslint-disable-next-line @typescript-eslint/prefer-ts-expect-error + // @ts-ignore not typed in lower versions + static isBuiltin = _Module.isBuiltin static Module = Module } From 71b90fbd38f227ce742345fbb4143a11d333b92a Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 11 Jul 2023 17:27:00 +0200 Subject: [PATCH 50/87] fix: correctly inline styles in VM --- examples/react-storybook/src/setup.ts | 4 ++++ packages/vite-node/src/client.ts | 30 ++++---------------------- packages/vitest/src/runtime/execute.ts | 28 +++++++++++++++++++++++- 3 files changed, 35 insertions(+), 27 deletions(-) diff --git a/examples/react-storybook/src/setup.ts b/examples/react-storybook/src/setup.ts index c239610b8a37..c689876c16aa 100644 --- a/examples/react-storybook/src/setup.ts +++ b/examples/react-storybook/src/setup.ts @@ -1,4 +1,5 @@ import '@testing-library/jest-dom' +import { Buffer } from 'node:buffer' import { setGlobalConfig } from '@storybook/testing-react' import { getWorker } from 'msw-storybook-addon' import * as globalStorybookConfig from '../.storybook/preview' @@ -8,3 +9,6 @@ setGlobalConfig(globalStorybookConfig) // Ensure MSW connections are closed // @ts-expect-error https://github.com/mswjs/msw-storybook-addon/issues/65 afterAll(() => getWorker().close()) + +// Buffer is not available in browser environment, but some testing libraries require it +globalThis.Buffer = Buffer diff --git a/packages/vite-node/src/client.ts b/packages/vite-node/src/client.ts index 201d4d48dbdb..e0665e73629b 100644 --- a/packages/vite-node/src/client.ts +++ b/packages/vite-node/src/client.ts @@ -17,7 +17,7 @@ const debugNative = createDebug('vite-node:client:native') const clientStub = { injectQuery: (id: string) => id, - createHotContext() { + createHotContext: () => { return { accept: () => {}, prune: () => {}, @@ -28,33 +28,11 @@ const clientStub = { send: () => {}, } }, - updateStyle(id: string, css: string) { - if (typeof document === 'undefined') - return - - const element = document.querySelector(`[data-vite-dev-id="${id}"]`) - if (element) { - element.textContent = css - return - } - - const head = document.querySelector('head') - const style = document.createElement('style') - style.setAttribute('type', 'text/css') - style.setAttribute('data-vite-dev-id', id) - style.textContent = css - head?.appendChild(style) - }, - removeStyle(id: string) { - if (typeof document === 'undefined') - return - const sheet = document.querySelector(`[data-vite-dev-id="${id}"]`) - if (sheet) - document.head.removeChild(sheet) - }, + updateStyle: () => {}, + removeStyle: () => {}, } -export const DEFAULT_REQUEST_STUBS: Record = { +export const DEFAULT_REQUEST_STUBS: Record> = { '/@vite/client': clientStub, '@vite/client': clientStub, } diff --git a/packages/vitest/src/runtime/execute.ts b/packages/vitest/src/runtime/execute.ts index f93c8fdf0348..f32e6b40810d 100644 --- a/packages/vitest/src/runtime/execute.ts +++ b/packages/vitest/src/runtime/execute.ts @@ -1,6 +1,6 @@ import { pathToFileURL } from 'node:url' import vm from 'node:vm' -import { ModuleCacheMap, ViteNodeRunner } from 'vite-node/client' +import { DEFAULT_REQUEST_STUBS, ModuleCacheMap, ViteNodeRunner } from 'vite-node/client' import { isInternalRequest, isNodeBuiltin, isPrimitive } from 'vite-node/utils' import type { ViteNodeRunnerOptions } from 'vite-node' import { normalize, relative, resolve } from 'pathe' @@ -111,6 +111,22 @@ export async function startVitestExecutor(options: ContextExecutorOptions) { }) } +function updateStyle(id: string, css: string) { + if (typeof document === 'undefined') + return + + const element = document.getElementById(id) + if (element) + element.remove() + + const head = document.querySelector('head') + const style = document.createElement('style') + style.setAttribute('type', 'text/css') + style.id = id + style.innerHTML = css + head?.appendChild(style) +} + export class VitestExecutor extends ViteNodeRunner { public mocker: VitestMocker public externalModules?: ExternalModulesExecutor @@ -126,9 +142,19 @@ export class VitestExecutor extends ViteNodeRunner { writable: true, configurable: true, }) + const clientStub = { ...DEFAULT_REQUEST_STUBS['@vite/client'], updateStyle } + this.options.requestStubs = { + '/@vite/client': clientStub, + '@vite/client': clientStub, + } } else { this.externalModules = new ExternalModulesExecutor(options.context, options.findNearestPackageData || (() => Promise.resolve({}))) + const clientStub = vm.runInContext(`(defaultClient) => ({ ...defaultClient, updateStyle: ${updateStyle.toString()} })`, options.context)(DEFAULT_REQUEST_STUBS['@vite/client']) + this.options.requestStubs = { + '/@vite/client': clientStub, + '@vite/client': clientStub, + } } } From fcbfc26897feddbe0a2473f935d9e28ba91901d2 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 11 Jul 2023 17:55:57 +0200 Subject: [PATCH 51/87] chore: add Buffer to global --- examples/react-storybook/src/setup.ts | 4 ---- packages/vitest/src/integrations/env/happy-dom.ts | 3 +++ packages/vitest/src/integrations/env/jsdom.ts | 3 +++ 3 files changed, 6 insertions(+), 4 deletions(-) diff --git a/examples/react-storybook/src/setup.ts b/examples/react-storybook/src/setup.ts index c689876c16aa..c239610b8a37 100644 --- a/examples/react-storybook/src/setup.ts +++ b/examples/react-storybook/src/setup.ts @@ -1,5 +1,4 @@ import '@testing-library/jest-dom' -import { Buffer } from 'node:buffer' import { setGlobalConfig } from '@storybook/testing-react' import { getWorker } from 'msw-storybook-addon' import * as globalStorybookConfig from '../.storybook/preview' @@ -9,6 +8,3 @@ setGlobalConfig(globalStorybookConfig) // Ensure MSW connections are closed // @ts-expect-error https://github.com/mswjs/msw-storybook-addon/issues/65 afterAll(() => getWorker().close()) - -// Buffer is not available in browser environment, but some testing libraries require it -globalThis.Buffer = Buffer diff --git a/packages/vitest/src/integrations/env/happy-dom.ts b/packages/vitest/src/integrations/env/happy-dom.ts index 5b092ac72028..370b2ebba58f 100644 --- a/packages/vitest/src/integrations/env/happy-dom.ts +++ b/packages/vitest/src/integrations/env/happy-dom.ts @@ -15,6 +15,9 @@ export default ({ configurable: true, }) + // TODO: browser doesn't expose Buffer, but a lot of dependencies use it + win.Buffer = Buffer + return { getVmContext() { return win diff --git a/packages/vitest/src/integrations/env/jsdom.ts b/packages/vitest/src/integrations/env/jsdom.ts index 6310f00a9d80..8e95f6f32012 100644 --- a/packages/vitest/src/integrations/env/jsdom.ts +++ b/packages/vitest/src/integrations/env/jsdom.ts @@ -66,6 +66,9 @@ export default ({ ) const clearWindowErrors = catchWindowErrors(dom.window as any) + // TODO: browser doesn't expose Buffer, but a lot of dependencies use it + dom.window.Buffer = Buffer + return { getVmContext() { return dom.getInternalVMContext() From d2ff89115d3f7262f0d6f76a6c9ed47b610e5fc6 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 11 Jul 2023 18:29:56 +0200 Subject: [PATCH 52/87] chore: always use native import.meta.resolve --- .../test/__snapshots__/Hello.test.jsx.snap | 2 +- packages/vitest/package.json | 1 - packages/vitest/src/node/pools/vm-threads.ts | 1 + .../vitest/src/runtime/external-executor.ts | 11 +- pnpm-lock.yaml | 137 ++++++++++++++++-- 5 files changed, 134 insertions(+), 18 deletions(-) diff --git a/examples/solid/test/__snapshots__/Hello.test.jsx.snap b/examples/solid/test/__snapshots__/Hello.test.jsx.snap index 018959cb76da..2f7d062f3667 100644 --- a/examples/solid/test/__snapshots__/Hello.test.jsx.snap +++ b/examples/solid/test/__snapshots__/Hello.test.jsx.snap @@ -1,4 +1,4 @@ -// Vitest Snapshot v1 +// Vitest Snapshot v1, https://vitest.dev/guide/snapshot.html exports[` > renders 1`] = `"
4 x 2 = 8
"`; diff --git a/packages/vitest/package.json b/packages/vitest/package.json index 89272d8530d4..7d21ab7d2fb6 100644 --- a/packages/vitest/package.json +++ b/packages/vitest/package.json @@ -147,7 +147,6 @@ "cac": "^6.7.14", "chai": "^4.3.7", "debug": "^4.3.4", - "import-meta-resolve": "^2.2.2", "local-pkg": "^0.4.3", "magic-string": "^0.30.1", "pathe": "^1.1.1", diff --git a/packages/vitest/src/node/pools/vm-threads.ts b/packages/vitest/src/node/pools/vm-threads.ts index bb5d0be70092..5cc867834728 100644 --- a/packages/vitest/src/node/pools/vm-threads.ts +++ b/packages/vitest/src/node/pools/vm-threads.ts @@ -58,6 +58,7 @@ export function createVmThreadsPool(ctx: Vitest, { execArgv, env }: PoolProcessO env, execArgv: [ + '--experimental-import-meta-resolve', '--experimental-vm-modules', '--require', suppressLoaderWarningsPath, diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index 1edacba810a3..1c1832c68bf0 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -6,7 +6,6 @@ import { dirname } from 'node:path' import { Module as _Module, createRequire } from 'node:module' import { readFileSync } from 'node:fs' import { readFile } from 'node:fs/promises' -import { resolve as resolveModule } from 'import-meta-resolve' import { extname } from 'pathe' import { isNodeBuiltin } from 'vite-node/utils' import type { RuntimeRPC } from '../types' @@ -91,7 +90,7 @@ interface PrivateNodeModule extends NodeModule { const _require = createRequire(import.meta.url) -const nativeResolve = import.meta.resolve +const nativeResolve = import.meta.resolve! // TODO: improve Node.js strict mode support in #2854 export class ExternalModulesExecutor { @@ -223,7 +222,7 @@ export class ExternalModulesExecutor { } private async resolveAsync(specifier: string, parent: string) { - return resolveModule(specifier, parent) + return nativeResolve(specifier, parent) } private async wrapSynteticModule(identifier: string, format: 'esm' | 'builtin' | 'cjs', exports: Record) { @@ -312,10 +311,8 @@ export class ExternalModulesExecutor { importModuleDynamically: this.importModuleDynamically, initializeImportMeta: (meta, mod) => { meta.url = mod.identifier - if (nativeResolve) { - meta.resolve = (specifier: string, importer?: string) => { - return nativeResolve(specifier, importer ?? mod.identifier) - } + meta.resolve = (specifier: string, importer?: string) => { + return nativeResolve(specifier, importer ?? mod.identifier) } }, }, diff --git a/pnpm-lock.yaml b/pnpm-lock.yaml index d302a0eca75f..42d618dbe283 100644 --- a/pnpm-lock.yaml +++ b/pnpm-lock.yaml @@ -1291,10 +1291,7 @@ importers: version: 4.3.7 debug: specifier: ^4.3.4 - version: 4.3.4(supports-color@8.1.1) - import-meta-resolve: - specifier: ^2.2.2 - version: 2.2.2 + version: 4.3.4 local-pkg: specifier: ^0.4.3 version: 0.4.3 @@ -1433,7 +1430,7 @@ importers: version: 7.1.0 webdriverio: specifier: ^8.11.2 - version: 8.12.1(typescript@5.1.6) + version: 8.12.1 ws: specifier: ^8.13.0 version: 8.13.0 @@ -6661,6 +6658,29 @@ packages: resolution: {integrity: sha512-50/17A98tWUfQ176raKiOGXuYpLyyVMkxxG6oylzL3BPOlA6ADGdK7EYunSa4I064xerltq9TGXs8HmOk5E+vw==} dev: false + /@puppeteer/browsers@1.3.0: + resolution: {integrity: sha512-an3QdbNPkuU6qpxpbssxAbjRLJcF+eP4L8UqIY3+6n0sbaVxw5pz7PiCLy9g32XEZuoamUlV5ZQPnA6FxvkIHA==} + engines: {node: '>=16.0.0'} + hasBin: true + peerDependencies: + typescript: '>= 4.7.4' + peerDependenciesMeta: + typescript: + optional: true + dependencies: + debug: 4.3.4 + extract-zip: 2.0.1 + http-proxy-agent: 5.0.0 + https-proxy-agent: 5.0.1 + progress: 2.0.3 + proxy-from-env: 1.1.0 + tar-fs: 2.1.1 + unbzip2-stream: 1.4.3 + yargs: 17.7.1 + transitivePeerDependencies: + - supports-color + dev: true + /@puppeteer/browsers@1.3.0(typescript@5.1.6): resolution: {integrity: sha512-an3QdbNPkuU6qpxpbssxAbjRLJcF+eP4L8UqIY3+6n0sbaVxw5pz7PiCLy9g32XEZuoamUlV5ZQPnA6FxvkIHA==} engines: {node: '>=16.0.0'} @@ -10435,7 +10455,7 @@ packages: resolution: {integrity: sha512-RZNwNclF7+MS/8bDg70amg32dyeZGZxiDuQmZxKLAlQjr3jGyLx+4Kkk58UO7D2QdgFIQCovuSuZESne6RG6XQ==} engines: {node: '>= 6.0.0'} dependencies: - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 transitivePeerDependencies: - supports-color dev: true @@ -12985,7 +13005,6 @@ packages: optional: true dependencies: ms: 2.1.2 - dev: false /debug@4.3.4(supports-color@8.1.1): resolution: {integrity: sha512-PRWFHuSU3eDtQJPvnNY7Jcket1j0t5OuOsFzPPzsekD52Zl8qUfFIPEiswXqIvHWGVHOgX+7G/vCNNhehwxfkQ==} @@ -13271,6 +13290,32 @@ packages: resolution: {integrity: sha512-0cuGS8+jhR67Fy7qG3i3Pc7Aw494sb9yG9QgpG97SFVWwolgYjlhJg7n+UaHxOQT30d1TYu/EYe9k01ivLErIg==} dev: true + /devtools@8.12.1: + resolution: {integrity: sha512-R72raQLN1lDSqbr2DVj9SRh07JRyojzmrcLa33VBa2nw3cf5ZyHOHe0DgxlJ/5c2Dfs1+wGNJy16gWKGBq+xgg==} + engines: {node: ^16.13 || >=18} + dependencies: + '@types/node': 20.4.1 + '@wdio/config': 8.12.1 + '@wdio/logger': 8.11.0 + '@wdio/protocols': 8.11.0 + '@wdio/types': 8.10.4 + '@wdio/utils': 8.12.1 + chrome-launcher: 0.15.1 + edge-paths: 3.0.5 + import-meta-resolve: 3.0.0 + puppeteer-core: 20.3.0 + query-selector-shadow-dom: 1.0.1 + ua-parser-js: 1.0.34 + uuid: 9.0.0 + which: 3.0.0 + transitivePeerDependencies: + - bufferutil + - encoding + - supports-color + - typescript + - utf-8-validate + dev: true + /devtools@8.12.1(typescript@5.1.6): resolution: {integrity: sha512-R72raQLN1lDSqbr2DVj9SRh07JRyojzmrcLa33VBa2nw3cf5ZyHOHe0DgxlJ/5c2Dfs1+wGNJy16gWKGBq+xgg==} engines: {node: ^16.13 || >=18} @@ -15039,6 +15084,20 @@ packages: parse-code-context: 1.0.0 dev: true + /extract-zip@2.0.1: + resolution: {integrity: sha512-GDhU9ntwuKyGXdZBUgTIe+vXnWj0fppUEtMDL0+idd5Sta8TGpHssn/eusA9mrPr9qNDym6SxAYZjNvCn/9RBg==} + engines: {node: '>= 10.17.0'} + hasBin: true + dependencies: + debug: 4.3.4 + get-stream: 5.2.0 + yauzl: 2.10.0 + optionalDependencies: + '@types/yauzl': 2.10.0 + transitivePeerDependencies: + - supports-color + dev: true + /extract-zip@2.0.1(supports-color@8.1.1): resolution: {integrity: sha512-GDhU9ntwuKyGXdZBUgTIe+vXnWj0fppUEtMDL0+idd5Sta8TGpHssn/eusA9mrPr9qNDym6SxAYZjNvCn/9RBg==} engines: {node: '>= 10.17.0'} @@ -16365,7 +16424,7 @@ packages: dependencies: '@tootallnate/once': 2.0.0 agent-base: 6.0.2 - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 transitivePeerDependencies: - supports-color dev: true @@ -16410,7 +16469,7 @@ packages: engines: {node: '>= 6'} dependencies: agent-base: 6.0.2 - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 transitivePeerDependencies: - supports-color dev: true @@ -16509,6 +16568,7 @@ packages: /import-meta-resolve@2.2.2: resolution: {integrity: sha512-f8KcQ1D80V7RnqVm+/lirO9zkOxjGxhaTC1IPrBGd3MEfNgmNG67tSUO9gTi2F3Blr2Az6g1vocaxzkVnWl9MA==} + dev: true /import-meta-resolve@3.0.0: resolution: {integrity: sha512-4IwhLhNNA8yy445rPjD/lWh++7hMDOml2eHtd58eG7h+qK3EryMuuRbsHGPikCoAgIkkDnckKfWSk2iDla/ejg==} @@ -20911,6 +20971,28 @@ packages: engines: {node: '>=6'} dev: true + /puppeteer-core@20.3.0: + resolution: {integrity: sha512-264pBrIui5bO6NJeOcbJrLa0OCwmA4+WK00JMrLIKTfRiqe2gx8KWTzLsjyw/bizErp3TKS7vt/I0i5fTC+mAw==} + engines: {node: '>=16.0.0'} + peerDependencies: + typescript: '>= 4.7.4' + peerDependenciesMeta: + typescript: + optional: true + dependencies: + '@puppeteer/browsers': 1.3.0 + chromium-bidi: 0.4.9(devtools-protocol@0.0.1120988) + cross-fetch: 3.1.6 + debug: 4.3.4 + devtools-protocol: 0.0.1120988 + ws: 8.13.0 + transitivePeerDependencies: + - bufferutil + - encoding + - supports-color + - utf-8-validate + dev: true + /puppeteer-core@20.3.0(typescript@5.1.6): resolution: {integrity: sha512-264pBrIui5bO6NJeOcbJrLa0OCwmA4+WK00JMrLIKTfRiqe2gx8KWTzLsjyw/bizErp3TKS7vt/I0i5fTC+mAw==} engines: {node: '>=16.0.0'} @@ -25066,6 +25148,43 @@ packages: - utf-8-validate dev: true + /webdriverio@8.12.1: + resolution: {integrity: sha512-lW0Qo3fy64cVbYWWAZbXxLIOK0pbTARgpY89J+0Sr6zh2K2NKtd/0D11k3WfMeYxd0b0he7E7XC1b6M6w4h75A==} + engines: {node: ^16.13 || >=18} + dependencies: + '@types/node': 20.4.1 + '@wdio/config': 8.12.1 + '@wdio/logger': 8.11.0 + '@wdio/protocols': 8.11.0 + '@wdio/repl': 8.10.1 + '@wdio/types': 8.10.4 + '@wdio/utils': 8.12.1 + archiver: 5.3.1 + aria-query: 5.3.0 + css-shorthand-properties: 1.1.1 + css-value: 0.0.1 + devtools: 8.12.1 + devtools-protocol: 0.0.1161598 + grapheme-splitter: 1.0.4 + import-meta-resolve: 3.0.0 + is-plain-obj: 4.1.0 + lodash.clonedeep: 4.5.0 + lodash.zip: 4.2.0 + minimatch: 9.0.1 + puppeteer-core: 20.3.0 + query-selector-shadow-dom: 1.0.1 + resq: 1.11.0 + rgb2hex: 0.2.5 + serialize-error: 8.1.0 + webdriver: 8.12.1 + transitivePeerDependencies: + - bufferutil + - encoding + - supports-color + - typescript + - utf-8-validate + dev: true + /webdriverio@8.12.1(typescript@5.1.6): resolution: {integrity: sha512-lW0Qo3fy64cVbYWWAZbXxLIOK0pbTARgpY89J+0Sr6zh2K2NKtd/0D11k3WfMeYxd0b0he7E7XC1b6M6w4h75A==} engines: {node: ^16.13 || >=18} From 6b1fdc642d48252ea3d929b5f156b9bad59abac4 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 11 Jul 2023 18:40:36 +0200 Subject: [PATCH 53/87] chore: use the longest extension --- .../vitest/src/runtime/external-executor.ts | 21 +++++++++++++++++-- 1 file changed, 19 insertions(+), 2 deletions(-) diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index 1c1832c68bf0..af3bda492a0d 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -6,7 +6,7 @@ import { dirname } from 'node:path' import { Module as _Module, createRequire } from 'node:module' import { readFileSync } from 'node:fs' import { readFile } from 'node:fs/promises' -import { extname } from 'pathe' +import { basename, extname } from 'pathe' import { isNodeBuiltin } from 'vite-node/utils' import type { RuntimeRPC } from '../types' @@ -261,6 +261,23 @@ export class ExternalModulesExecutor { return m } + private findLongestRegisteredExtension(filename: string) { + const name = basename(filename) + let currentExtension + let index + let startIndex = 0 + // eslint-disable-next-line no-cond-assign + while ((index = name.indexOf('.', startIndex)) !== -1) { + startIndex = index + 1 + if (index === 0) + continue // Skip dotfiles like .gitignore + currentExtension = (name.slice(index)) + if (this.extensions[currentExtension]) + return currentExtension + } + return '.js' + } + public createRequire = (filename: string) => { const _require = createRequire(filename) const require = ((id: string) => { @@ -292,7 +309,7 @@ export class ExternalModulesExecutor { if (cached) return cached.exports - const extension = extname(filename) + const extension = this.findLongestRegisteredExtension(filename) const loader = this.extensions[extension] || this.extensions['.js'] loader(module, filename) From 33004592ee0f2045999f610e26716ecb88da9dee Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 11 Jul 2023 18:52:09 +0200 Subject: [PATCH 54/87] fix: use the same primitives --- packages/vite-node/src/client.ts | 7 ++++++- packages/vitest/src/runtime/execute.ts | 16 ++++++++++++++++ packages/vitest/src/runtime/external-executor.ts | 15 +++++++++------ 3 files changed, 31 insertions(+), 7 deletions(-) diff --git a/packages/vite-node/src/client.ts b/packages/vite-node/src/client.ts index e0665e73629b..2c97f24f648b 100644 --- a/packages/vite-node/src/client.ts +++ b/packages/vite-node/src/client.ts @@ -282,7 +282,6 @@ export class ViteNodeRunner { const requestStubs = this.options.requestStubs || DEFAULT_REQUEST_STUBS if (id in requestStubs) return requestStubs[id] - let { code: transformed, externalize } = await this.options.fetchModule(id) if (externalize) { @@ -295,6 +294,8 @@ export class ViteNodeRunner { if (transformed == null) throw new Error(`[vite-node] Failed to load "${id}" imported from ${callstack[callstack.length - 2]}`) + const { Object, Reflect, Symbol } = this.getContextPrimitives() + const modulePath = cleanUrl(moduleId) // disambiguate the `:/` on windows: see nodejs/node#31710 const href = pathToFileURL(modulePath).href @@ -399,6 +400,10 @@ export class ViteNodeRunner { return exports } + protected getContextPrimitives() { + return { Object, Reflect, Symbol } + } + protected async runModule(context: Record, transformed: string) { // add 'use strict' since ESM enables it by default const codeDefinition = `'use strict';async (${Object.keys(context).join(',')})=>{{` diff --git a/packages/vitest/src/runtime/execute.ts b/packages/vitest/src/runtime/execute.ts index f32e6b40810d..870d93be63e4 100644 --- a/packages/vitest/src/runtime/execute.ts +++ b/packages/vitest/src/runtime/execute.ts @@ -131,6 +131,12 @@ export class VitestExecutor extends ViteNodeRunner { public mocker: VitestMocker public externalModules?: ExternalModulesExecutor + private primitives: { + Object: typeof Object + Reflect: typeof Reflect + Symbol: typeof Symbol + } + constructor(public options: ExecuteOptions) { super(options) @@ -147,6 +153,11 @@ export class VitestExecutor extends ViteNodeRunner { '/@vite/client': clientStub, '@vite/client': clientStub, } + this.primitives = { + Object, + Reflect, + Symbol, + } } else { this.externalModules = new ExternalModulesExecutor(options.context, options.findNearestPackageData || (() => Promise.resolve({}))) @@ -155,9 +166,14 @@ export class VitestExecutor extends ViteNodeRunner { '/@vite/client': clientStub, '@vite/client': clientStub, } + this.primitives = vm.runInContext('({ Object, Reflect, Symbol })', options.context) } } + protected getContextPrimitives() { + return this.primitives + } + get state() { return this.options.state } diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index af3bda492a0d..ed264e63a822 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -102,6 +102,9 @@ export class ExternalModulesExecutor { private esmLinkMap = new WeakMap>() private Module: typeof _Module + private primitives: { + Object: typeof Object + } constructor(private context: vm.Context, private findNearestPackageData: RuntimeRPC['findNearestPackageData']) { this.context = context @@ -110,7 +113,7 @@ export class ExternalModulesExecutor { const executor = this this.Module = class Module { - exports = {} + exports: any isPreloading = false require: NodeRequire id: string @@ -119,11 +122,10 @@ export class ExternalModulesExecutor { parent: null | Module | undefined children: Module[] = [] path: string - paths: string[] + paths: string[] = [] constructor(id: string, parent?: Module) { - this.exports = {} - this.isPreloading = false + this.exports = executor.primitives.Object.create(Object.prototype) this.require = Module.createRequire(id) // in our case the path should always be resolved already this.path = dirname(id) @@ -131,8 +133,6 @@ export class ExternalModulesExecutor { this.filename = id this.loaded = false this.parent = parent - this.children = [] - this.paths = [] } _compile(code: string, filename: string) { @@ -199,6 +199,8 @@ export class ExternalModulesExecutor { this.extensions['.js'] = this.requireJs this.extensions['.json'] = this.requireJson + + this.primitives = vm.runInContext('({ Object })', context) } private requireJs = (m: NodeModule, filename: string) => { @@ -226,6 +228,7 @@ export class ExternalModulesExecutor { } private async wrapSynteticModule(identifier: string, format: 'esm' | 'builtin' | 'cjs', exports: Record) { + // TODO: technically module should be parsed to find static exports, implement for #2854 const moduleKeys = Object.keys(exports) if (format !== 'esm' && !moduleKeys.includes('default')) moduleKeys.push('default') From 6cf97ed2b15b93606bd9a4eaa615e8b88a787331 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 11 Jul 2023 19:08:50 +0200 Subject: [PATCH 55/87] fix: support import.meta.vitest in vm pool --- packages/vitest/src/runtime/entry-vm.ts | 6 ++++++ packages/vitest/src/runtime/execute.ts | 3 ++- 2 files changed, 8 insertions(+), 1 deletion(-) diff --git a/packages/vitest/src/runtime/entry-vm.ts b/packages/vitest/src/runtime/entry-vm.ts index 72b9b7f2df41..78edc1a32e64 100644 --- a/packages/vitest/src/runtime/entry-vm.ts +++ b/packages/vitest/src/runtime/entry-vm.ts @@ -8,6 +8,7 @@ import { startCoverageInsideWorker, stopCoverageInsideWorker } from '../integrat import type { ResolvedConfig } from '../types' import { getWorkerState } from '../utils/global' import { VitestSnapshotEnvironment } from '../integrations/snapshot/environments/node' +import * as VitestIndex from '../index' import type { VitestExecutor } from './execute' import { resolveTestRunner } from './runners' import { setupCommonEnv } from './setup.common' @@ -17,6 +18,11 @@ export async function run(files: string[], config: ResolvedConfig, executor: Vit await setupCommonEnv(config) + Object.defineProperty(globalThis, '__vitest_index__', { + value: VitestIndex, + enumerable: false, + }) + config.snapshotOptions.snapshotEnvironment = new VitestSnapshotEnvironment(workerState.rpc) setupColors(createColors(isatty(1))) diff --git a/packages/vitest/src/runtime/execute.ts b/packages/vitest/src/runtime/execute.ts index 870d93be63e4..f2dc3db83736 100644 --- a/packages/vitest/src/runtime/execute.ts +++ b/packages/vitest/src/runtime/execute.ts @@ -256,8 +256,9 @@ export class VitestExecutor extends ViteNodeRunner { // support `import.meta.vitest` for test entry if (workerState.filepath && normalize(workerState.filepath) === normalize(context.__filename)) { + const globalNamespace = this.options.context || globalThis // @ts-expect-error injected untyped global - Object.defineProperty(context.__vite_ssr_import_meta__, 'vitest', { get: () => globalThis.__vitest_index__ }) + Object.defineProperty(context.__vite_ssr_import_meta__, 'vitest', { get: () => globalNamespace.__vitest_index__ }) } if (this.options.context && this.externalModules) From 296a29f0617e5d6dfc32f3edc2cea4ff4e64b190 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 11 Jul 2023 19:57:06 +0200 Subject: [PATCH 56/87] chore: fix structure clone and buffer inconsistencies --- packages/vitest/execute.d.ts | 1 + packages/vitest/package.json | 4 + packages/vitest/rollup.config.js | 1 + .../vitest/src/integrations/chai/index.ts | 3 +- .../vitest/src/integrations/env/happy-dom.ts | 7 +- packages/vitest/src/integrations/env/jsdom.ts | 6 + packages/vitest/src/integrations/env/node.ts | 2 +- packages/vitest/src/integrations/run-once.ts | 2 +- packages/vitest/src/node/index.ts | 3 - packages/vitest/src/public/execute.ts | 1 + .../vitest/src/runtime/external-executor.ts | 12 +- packages/vitest/src/types/index.ts | 20 +- packages/web-worker/package.json | 2 +- packages/web-worker/rollup.config.js | 2 +- packages/web-worker/src/runner.ts | 2 +- pnpm-lock.yaml | 277 ++++++------------ 16 files changed, 139 insertions(+), 206 deletions(-) create mode 100644 packages/vitest/execute.d.ts create mode 100644 packages/vitest/src/public/execute.ts diff --git a/packages/vitest/execute.d.ts b/packages/vitest/execute.d.ts new file mode 100644 index 000000000000..9901479f9a8e --- /dev/null +++ b/packages/vitest/execute.d.ts @@ -0,0 +1 @@ +export * from './dist/execute.js' diff --git a/packages/vitest/package.json b/packages/vitest/package.json index 7d21ab7d2fb6..9cc26025a1a8 100644 --- a/packages/vitest/package.json +++ b/packages/vitest/package.json @@ -45,6 +45,10 @@ "types": "./dist/node.d.ts", "import": "./dist/node.js" }, + "./execute": { + "types": "./dist/execute.d.ts", + "import": "./dist/execute.js" + }, "./browser": { "types": "./dist/browser.d.ts", "import": "./dist/browser.js" diff --git a/packages/vitest/rollup.config.js b/packages/vitest/rollup.config.js index 62526d018717..b0af2e32aa04 100644 --- a/packages/vitest/rollup.config.js +++ b/packages/vitest/rollup.config.js @@ -32,6 +32,7 @@ const entries = [ 'src/integrations/spy.ts', 'src/coverage.ts', 'src/public/utils.ts', + 'src/public/execute.ts', ] const dtsEntries = { diff --git a/packages/vitest/src/integrations/chai/index.ts b/packages/vitest/src/integrations/chai/index.ts index 4433d6985277..b25dc2f605a4 100644 --- a/packages/vitest/src/integrations/chai/index.ts +++ b/packages/vitest/src/integrations/chai/index.ts @@ -7,7 +7,8 @@ import { getCurrentTest } from '@vitest/runner' import { GLOBAL_EXPECT, getState, setState } from '@vitest/expect' import type { Assertion, ExpectStatic } from '@vitest/expect' import type { MatcherState } from '../../types/chai' -import { getCurrentEnvironment, getFullName } from '../../utils' +import { getFullName } from '../../utils/tasks' +import { getCurrentEnvironment } from '../../utils/global' export function createExpect(test?: Test) { const expect = ((value: any, message?: string): Assertion => { diff --git a/packages/vitest/src/integrations/env/happy-dom.ts b/packages/vitest/src/integrations/env/happy-dom.ts index 370b2ebba58f..e57cdb678957 100644 --- a/packages/vitest/src/integrations/env/happy-dom.ts +++ b/packages/vitest/src/integrations/env/happy-dom.ts @@ -7,7 +7,7 @@ export default ({ transformMode: 'web', async setupVM() { const { Window } = await importModule('happy-dom') as typeof import('happy-dom') - const win = new Window() + const win = new Window() as any win.global = win.window Object.defineProperty(win.document, 'defaultView', { @@ -17,6 +17,11 @@ export default ({ // TODO: browser doesn't expose Buffer, but a lot of dependencies use it win.Buffer = Buffer + win.Uint8Array = Uint8Array + + // inject structuredClone if it exists + if (typeof structuredClone !== 'undefined' && !win.structuredClone) + win.structuredClone = structuredClone return { getVmContext() { diff --git a/packages/vitest/src/integrations/env/jsdom.ts b/packages/vitest/src/integrations/env/jsdom.ts index 8e95f6f32012..30910b082f28 100644 --- a/packages/vitest/src/integrations/env/jsdom.ts +++ b/packages/vitest/src/integrations/env/jsdom.ts @@ -68,6 +68,12 @@ export default ({ // TODO: browser doesn't expose Buffer, but a lot of dependencies use it dom.window.Buffer = Buffer + // Buffer extends Uint8Array + dom.window.Uint8Array = Uint8Array + + // inject structuredClone if it exists + if (typeof structuredClone !== 'undefined' && !dom.window.structuredClone) + dom.window.structuredClone = structuredClone return { getVmContext() { diff --git a/packages/vitest/src/integrations/env/node.ts b/packages/vitest/src/integrations/env/node.ts index bb15a319707b..4ba49e471748 100644 --- a/packages/vitest/src/integrations/env/node.ts +++ b/packages/vitest/src/integrations/env/node.ts @@ -22,7 +22,7 @@ const nodeGlobals = new Map( if (!descriptor) { throw new Error( - `No property descriptor for ${nodeGlobalsKey}, this is a bug in Jest.`, + `No property descriptor for ${nodeGlobalsKey}, this is a bug in Vitest.`, ) } diff --git a/packages/vitest/src/integrations/run-once.ts b/packages/vitest/src/integrations/run-once.ts index 52e391a47d04..be150ed08904 100644 --- a/packages/vitest/src/integrations/run-once.ts +++ b/packages/vitest/src/integrations/run-once.ts @@ -1,4 +1,4 @@ -import { getWorkerState } from '../utils' +import { getWorkerState } from '../utils/global' const filesCount = new Map() const cache = new Map() diff --git a/packages/vitest/src/node/index.ts b/packages/vitest/src/node/index.ts index 80b128a4d1a3..bddc19919dba 100644 --- a/packages/vitest/src/node/index.ts +++ b/packages/vitest/src/node/index.ts @@ -6,8 +6,5 @@ export { startVitest } from './cli-api' export { registerConsoleShortcuts } from './stdin' export type { WorkspaceSpec } from './pool' -export { VitestExecutor } from '../runtime/execute' -export type { ExecuteOptions } from '../runtime/execute' - export type { TestSequencer, TestSequencerConstructor } from './sequencers/types' export { BaseSequencer } from './sequencers/BaseSequencer' diff --git a/packages/vitest/src/public/execute.ts b/packages/vitest/src/public/execute.ts new file mode 100644 index 000000000000..4f1ee837f2d8 --- /dev/null +++ b/packages/vitest/src/public/execute.ts @@ -0,0 +1 @@ +export { VitestExecutor } from '../runtime/execute' \ No newline at end of file diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index ed264e63a822..fefdd06ea88b 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -284,12 +284,12 @@ export class ExternalModulesExecutor { public createRequire = (filename: string) => { const _require = createRequire(filename) const require = ((id: string) => { - const filename = _require.resolve(id) - const ext = extname(filename) - if (ext === '.node' || isNodeBuiltin(filename)) - return this.requireCoreModule(filename) - const module = this.createCommonJSNodeModule(filename) - return this.loadCommonJSModule(module, filename) + const resolved = _require.resolve(id) + const ext = extname(resolved) + if (ext === '.node' || isNodeBuiltin(resolved)) + return this.requireCoreModule(resolved) + const module = this.createCommonJSNodeModule(resolved) + return this.loadCommonJSModule(module, resolved) }) as NodeRequire require.resolve = _require.resolve Object.defineProperty(require, 'extensions', { diff --git a/packages/vitest/src/types/index.ts b/packages/vitest/src/types/index.ts index 0111737947a3..e0d92a8ed0a3 100644 --- a/packages/vitest/src/types/index.ts +++ b/packages/vitest/src/types/index.ts @@ -3,16 +3,16 @@ import './global' export { expectTypeOf, type ExpectTypeOf } from '../typecheck/expectTypeOf' export { assertType, type AssertType } from '../typecheck/assertType' -export * from '../typecheck/types' -export * from './config' -export * from './tasks' -export * from './rpc' -export * from './reporter' -export * from './snapshot' -export * from './worker' -export * from './general' -export * from './coverage' -export * from './benchmark' +export type * from '../typecheck/types' +export type * from './config' +export type * from './tasks' +export type * from './rpc' +export type * from './reporter' +export type * from './snapshot' +export type * from './worker' +export type * from './general' +export type * from './coverage' +export type * from './benchmark' export type { EnhancedSpy, MockedFunction, diff --git a/packages/web-worker/package.json b/packages/web-worker/package.json index 7d4cc38b83ae..b67b6459eb2f 100644 --- a/packages/web-worker/package.json +++ b/packages/web-worker/package.json @@ -41,7 +41,7 @@ "typecheck": "tsc --noEmit" }, "peerDependencies": { - "vitest": "*" + "vitest": ">=0.33.0" }, "dependencies": { "debug": "^4.3.4" diff --git a/packages/web-worker/rollup.config.js b/packages/web-worker/rollup.config.js index 06ad151f0e66..93b1482e3bad 100644 --- a/packages/web-worker/rollup.config.js +++ b/packages/web-worker/rollup.config.js @@ -16,7 +16,7 @@ const external = [ ...Object.keys(pkg.dependencies || {}), ...Object.keys(pkg.peerDependencies || {}), 'vitest', - 'vitest/node', + 'vitest/execute', 'vite-node/utils', ] diff --git a/packages/web-worker/src/runner.ts b/packages/web-worker/src/runner.ts index 3f5b7266325a..407d9f60fbd2 100644 --- a/packages/web-worker/src/runner.ts +++ b/packages/web-worker/src/runner.ts @@ -1,4 +1,4 @@ -import { VitestExecutor } from 'vitest/node' +import { VitestExecutor } from 'vitest/execute' export class InlineWorkerRunner extends VitestExecutor { constructor(options: any, private context: any) { diff --git a/pnpm-lock.yaml b/pnpm-lock.yaml index 42d618dbe283..f0a3bb4ca65f 100644 --- a/pnpm-lock.yaml +++ b/pnpm-lock.yaml @@ -734,10 +734,10 @@ importers: devDependencies: '@sveltejs/vite-plugin-svelte': specifier: latest - version: 2.4.2(svelte@3.59.1)(vite@4.3.9) + version: 2.4.2(svelte@4.0.5)(vite@4.3.9) '@testing-library/svelte': specifier: latest - version: 3.2.2(svelte@3.59.1) + version: 3.2.2(svelte@4.0.5) '@vitest/ui': specifier: latest version: link:../../packages/ui @@ -746,7 +746,7 @@ importers: version: 22.1.0 svelte: specifier: latest - version: 3.59.1 + version: 4.0.5 vite: specifier: ^4.3.9 version: 4.3.9(@types/node@18.16.19) @@ -1218,7 +1218,7 @@ importers: version: 6.7.14 debug: specifier: ^4.3.4 - version: 4.3.4 + version: 4.3.4(supports-color@8.1.1) mlly: specifier: ^1.4.0 version: 1.4.0 @@ -1230,7 +1230,7 @@ importers: version: 1.0.0 vite: specifier: ^4.3.9 - version: 4.3.9 + version: 4.3.9(@types/node@18.16.19) devDependencies: '@jridgewell/trace-mapping': specifier: ^0.3.18 @@ -1291,7 +1291,7 @@ importers: version: 4.3.7 debug: specifier: ^4.3.4 - version: 4.3.4 + version: 4.3.4(supports-color@8.1.1) local-pkg: specifier: ^0.4.3 version: 0.4.3 @@ -1430,7 +1430,7 @@ importers: version: 7.1.0 webdriverio: specifier: ^8.11.2 - version: 8.12.1 + version: 8.12.1(typescript@5.1.6) ws: specifier: ^8.13.0 version: 8.13.0 @@ -1441,7 +1441,7 @@ importers: specifier: ^4.3.4 version: 4.3.4(supports-color@8.1.1) vitest: - specifier: '*' + specifier: '>=0.33.0' version: link:../vitest devDependencies: '@types/debug': @@ -6658,29 +6658,6 @@ packages: resolution: {integrity: sha512-50/17A98tWUfQ176raKiOGXuYpLyyVMkxxG6oylzL3BPOlA6ADGdK7EYunSa4I064xerltq9TGXs8HmOk5E+vw==} dev: false - /@puppeteer/browsers@1.3.0: - resolution: {integrity: sha512-an3QdbNPkuU6qpxpbssxAbjRLJcF+eP4L8UqIY3+6n0sbaVxw5pz7PiCLy9g32XEZuoamUlV5ZQPnA6FxvkIHA==} - engines: {node: '>=16.0.0'} - hasBin: true - peerDependencies: - typescript: '>= 4.7.4' - peerDependenciesMeta: - typescript: - optional: true - dependencies: - debug: 4.3.4 - extract-zip: 2.0.1 - http-proxy-agent: 5.0.0 - https-proxy-agent: 5.0.1 - progress: 2.0.3 - proxy-from-env: 1.1.0 - tar-fs: 2.1.1 - unbzip2-stream: 1.4.3 - yargs: 17.7.1 - transitivePeerDependencies: - - supports-color - dev: true - /@puppeteer/browsers@1.3.0(typescript@5.1.6): resolution: {integrity: sha512-an3QdbNPkuU6qpxpbssxAbjRLJcF+eP4L8UqIY3+6n0sbaVxw5pz7PiCLy9g32XEZuoamUlV5ZQPnA6FxvkIHA==} engines: {node: '>=16.0.0'} @@ -8336,6 +8313,22 @@ packages: - supports-color dev: true + /@sveltejs/vite-plugin-svelte-inspector@1.0.3(@sveltejs/vite-plugin-svelte@2.4.2)(svelte@4.0.5)(vite@4.3.9): + resolution: {integrity: sha512-Khdl5jmmPN6SUsVuqSXatKpQTMIifoQPDanaxC84m9JxIibWvSABJyHpyys0Z+1yYrxY5TTEQm+6elh0XCMaOA==} + engines: {node: ^14.18.0 || >= 16} + peerDependencies: + '@sveltejs/vite-plugin-svelte': ^2.2.0 + svelte: ^3.54.0 || ^4.0.0 + vite: ^4.0.0 + dependencies: + '@sveltejs/vite-plugin-svelte': 2.4.2(svelte@4.0.5)(vite@4.3.9) + debug: 4.3.4(supports-color@8.1.1) + svelte: 4.0.5 + vite: 4.3.9(@types/node@18.16.19) + transitivePeerDependencies: + - supports-color + dev: true + /@sveltejs/vite-plugin-svelte@2.4.2(svelte@3.59.1)(vite@4.3.9): resolution: {integrity: sha512-ePfcC48ftMKhkT0OFGdOyycYKnnkT6i/buzey+vHRTR/JpQvuPzzhf1PtKqCDQfJRgoPSN2vscXs6gLigx/zGw==} engines: {node: ^14.18.0 || >= 16} @@ -8356,6 +8349,26 @@ packages: - supports-color dev: true + /@sveltejs/vite-plugin-svelte@2.4.2(svelte@4.0.5)(vite@4.3.9): + resolution: {integrity: sha512-ePfcC48ftMKhkT0OFGdOyycYKnnkT6i/buzey+vHRTR/JpQvuPzzhf1PtKqCDQfJRgoPSN2vscXs6gLigx/zGw==} + engines: {node: ^14.18.0 || >= 16} + peerDependencies: + svelte: ^3.54.0 || ^4.0.0 + vite: ^4.0.0 + dependencies: + '@sveltejs/vite-plugin-svelte-inspector': 1.0.3(@sveltejs/vite-plugin-svelte@2.4.2)(svelte@4.0.5)(vite@4.3.9) + debug: 4.3.4(supports-color@8.1.1) + deepmerge: 4.3.1 + kleur: 4.1.5 + magic-string: 0.30.1 + svelte: 4.0.5 + svelte-hmr: 0.15.2(svelte@4.0.5) + vite: 4.3.9(@types/node@18.16.19) + vitefu: 0.2.4(vite@4.3.9) + transitivePeerDependencies: + - supports-color + dev: true + /@szmarczak/http-timer@5.0.1: resolution: {integrity: sha512-+PmQX0PiAYPMeVYe237LJAYvOMYW1j2rH5YROyS3b4CTVJum34HfRvKvAzozHAQG0TnHNdUfY9nCeUyRAs//cw==} engines: {node: '>=14.16'} @@ -8487,14 +8500,14 @@ packages: react-dom: 18.2.0(react@18.2.0) dev: true - /@testing-library/svelte@3.2.2(svelte@3.59.1): + /@testing-library/svelte@3.2.2(svelte@4.0.5): resolution: {integrity: sha512-IKwZgqbekC3LpoRhSwhd0JswRGxKdAGkf39UiDXTywK61YyLXbCYoR831e/UUC6EeNW4hiHPY+2WuovxOgI5sw==} engines: {node: '>= 10'} peerDependencies: svelte: 3.x dependencies: '@testing-library/dom': 8.19.0 - svelte: 3.59.1 + svelte: 4.0.5 dev: true /@testing-library/user-event@13.5.0(@testing-library/dom@8.17.1): @@ -8838,7 +8851,6 @@ packages: /@types/node@18.16.19: resolution: {integrity: sha512-IXl7o+R9iti9eBW4Wg2hx1xQDig183jj7YLn8F7udNceyfkbn1ZxmzZXuak20gR40D7pIkIY1kYGx5VIGbaHKA==} - dev: true /@types/node@18.7.13: resolution: {integrity: sha512-46yIhxSe5xEaJZXWdIBP7GU4HDTG8/eo0qd9atdiL+lFpA03y8KS+lkTN834TWJj5767GbWv4n/P6efyTFt1Dw==} @@ -10455,7 +10467,7 @@ packages: resolution: {integrity: sha512-RZNwNclF7+MS/8bDg70amg32dyeZGZxiDuQmZxKLAlQjr3jGyLx+4Kkk58UO7D2QdgFIQCovuSuZESne6RG6XQ==} engines: {node: '>= 6.0.0'} dependencies: - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) transitivePeerDependencies: - supports-color dev: true @@ -11021,6 +11033,12 @@ packages: transitivePeerDependencies: - debug + /axobject-query@3.2.1: + resolution: {integrity: sha512-jsyHu61e6N4Vbz/v18DHwWYKK0bSWLqn47eeDSKPB7m8tqMHF9YJ+mhIk2lVteyZrY8tnSj/jHOv4YiTCuCJgg==} + dependencies: + dequal: 2.0.3 + dev: true + /babel-jest@27.5.1(@babel/core@7.22.5): resolution: {integrity: sha512-cdQ5dXjGRd0IBRATiQ4mZGlGlRE8kJpjPOixdNRdT+m3UcNqmYWN6rK6nvtXYfY3D76cb8s/O1Ss8ea24PIwcg==} engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} @@ -12176,6 +12194,16 @@ packages: engines: {iojs: '>= 1.0.0', node: '>= 0.12.0'} dev: true + /code-red@1.0.3: + resolution: {integrity: sha512-kVwJELqiILQyG5aeuyKFbdsI1fmQy1Cmf7dQ8eGmVuJoaRVdwey7WaMknr2ZFeVSYSKT0rExsa8EGw0aoI/1QQ==} + dependencies: + '@jridgewell/sourcemap-codec': 1.4.15 + '@types/estree': 1.0.1 + acorn: 8.9.0 + estree-walker: 3.0.3 + periscopic: 3.1.0 + dev: true + /codemirror-theme-vars@0.1.2: resolution: {integrity: sha512-WTau8X2q58b0SOAY9DO+iQVw8JKVEgyQIqArp2D732tcc+pobbMta3bnVMdQdmgwuvNrOFFr6HoxPRoQOgooFA==} dev: true @@ -12995,17 +13023,6 @@ packages: supports-color: 8.1.1 dev: true - /debug@4.3.4: - resolution: {integrity: sha512-PRWFHuSU3eDtQJPvnNY7Jcket1j0t5OuOsFzPPzsekD52Zl8qUfFIPEiswXqIvHWGVHOgX+7G/vCNNhehwxfkQ==} - engines: {node: '>=6.0'} - peerDependencies: - supports-color: '*' - peerDependenciesMeta: - supports-color: - optional: true - dependencies: - ms: 2.1.2 - /debug@4.3.4(supports-color@8.1.1): resolution: {integrity: sha512-PRWFHuSU3eDtQJPvnNY7Jcket1j0t5OuOsFzPPzsekD52Zl8qUfFIPEiswXqIvHWGVHOgX+7G/vCNNhehwxfkQ==} engines: {node: '>=6.0'} @@ -13290,32 +13307,6 @@ packages: resolution: {integrity: sha512-0cuGS8+jhR67Fy7qG3i3Pc7Aw494sb9yG9QgpG97SFVWwolgYjlhJg7n+UaHxOQT30d1TYu/EYe9k01ivLErIg==} dev: true - /devtools@8.12.1: - resolution: {integrity: sha512-R72raQLN1lDSqbr2DVj9SRh07JRyojzmrcLa33VBa2nw3cf5ZyHOHe0DgxlJ/5c2Dfs1+wGNJy16gWKGBq+xgg==} - engines: {node: ^16.13 || >=18} - dependencies: - '@types/node': 20.4.1 - '@wdio/config': 8.12.1 - '@wdio/logger': 8.11.0 - '@wdio/protocols': 8.11.0 - '@wdio/types': 8.10.4 - '@wdio/utils': 8.12.1 - chrome-launcher: 0.15.1 - edge-paths: 3.0.5 - import-meta-resolve: 3.0.0 - puppeteer-core: 20.3.0 - query-selector-shadow-dom: 1.0.1 - ua-parser-js: 1.0.34 - uuid: 9.0.0 - which: 3.0.0 - transitivePeerDependencies: - - bufferutil - - encoding - - supports-color - - typescript - - utf-8-validate - dev: true - /devtools@8.12.1(typescript@5.1.6): resolution: {integrity: sha512-R72raQLN1lDSqbr2DVj9SRh07JRyojzmrcLa33VBa2nw3cf5ZyHOHe0DgxlJ/5c2Dfs1+wGNJy16gWKGBq+xgg==} engines: {node: ^16.13 || >=18} @@ -15084,20 +15075,6 @@ packages: parse-code-context: 1.0.0 dev: true - /extract-zip@2.0.1: - resolution: {integrity: sha512-GDhU9ntwuKyGXdZBUgTIe+vXnWj0fppUEtMDL0+idd5Sta8TGpHssn/eusA9mrPr9qNDym6SxAYZjNvCn/9RBg==} - engines: {node: '>= 10.17.0'} - hasBin: true - dependencies: - debug: 4.3.4 - get-stream: 5.2.0 - yauzl: 2.10.0 - optionalDependencies: - '@types/yauzl': 2.10.0 - transitivePeerDependencies: - - supports-color - dev: true - /extract-zip@2.0.1(supports-color@8.1.1): resolution: {integrity: sha512-GDhU9ntwuKyGXdZBUgTIe+vXnWj0fppUEtMDL0+idd5Sta8TGpHssn/eusA9mrPr9qNDym6SxAYZjNvCn/9RBg==} engines: {node: '>= 10.17.0'} @@ -16424,7 +16401,7 @@ packages: dependencies: '@tootallnate/once': 2.0.0 agent-base: 6.0.2 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) transitivePeerDependencies: - supports-color dev: true @@ -16469,7 +16446,7 @@ packages: engines: {node: '>= 6'} dependencies: agent-base: 6.0.2 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) transitivePeerDependencies: - supports-color dev: true @@ -18542,6 +18519,10 @@ packages: resolution: {integrity: sha512-SFppqq5p42fe2qcZQqqEOiVRXl+WCP1MdT6k7BDEW1j++sp5fIY+/fdRQitvKgB5BrBcmrs5m/L0v2FrU5MY1g==} engines: {node: '>=14'} + /locate-character@3.0.0: + resolution: {integrity: sha512-SW13ws7BjaeJ6p7Q6CO2nchbYEc3X3J6WrmTTDto7yMPqVSZTUyY5Tjbid+Ab8gLnATtygYtiDIJGQRRn2ZOiA==} + dev: true + /locate-path@3.0.0: resolution: {integrity: sha512-7AO748wWnIhNqAuaty2ZWHkQHRSNfPVIsPIfwEOWO22AmaoVrWavlOcMR5nzTLNYvp36X220/maaRsrec1G65A==} engines: {node: '>=6'} @@ -20971,28 +20952,6 @@ packages: engines: {node: '>=6'} dev: true - /puppeteer-core@20.3.0: - resolution: {integrity: sha512-264pBrIui5bO6NJeOcbJrLa0OCwmA4+WK00JMrLIKTfRiqe2gx8KWTzLsjyw/bizErp3TKS7vt/I0i5fTC+mAw==} - engines: {node: '>=16.0.0'} - peerDependencies: - typescript: '>= 4.7.4' - peerDependenciesMeta: - typescript: - optional: true - dependencies: - '@puppeteer/browsers': 1.3.0 - chromium-bidi: 0.4.9(devtools-protocol@0.0.1120988) - cross-fetch: 3.1.6 - debug: 4.3.4 - devtools-protocol: 0.0.1120988 - ws: 8.13.0 - transitivePeerDependencies: - - bufferutil - - encoding - - supports-color - - utf-8-validate - dev: true - /puppeteer-core@20.3.0(typescript@5.1.6): resolution: {integrity: sha512-264pBrIui5bO6NJeOcbJrLa0OCwmA4+WK00JMrLIKTfRiqe2gx8KWTzLsjyw/bizErp3TKS7vt/I0i5fTC+mAw==} engines: {node: '>=16.0.0'} @@ -23281,6 +23240,15 @@ packages: svelte: 3.59.1 dev: true + /svelte-hmr@0.15.2(svelte@4.0.5): + resolution: {integrity: sha512-q/bAruCvFLwvNbeE1x3n37TYFb3mTBJ6TrCq6p2CoFbSTNhDE9oAtEfpy+wmc9So8AG0Tja+X0/mJzX9tSfvIg==} + engines: {node: ^12.20 || ^14.13.1 || >= 16} + peerDependencies: + svelte: ^3.19.0 || ^4.0.0-next.0 + dependencies: + svelte: 4.0.5 + dev: true + /svelte-preprocess@5.0.4(svelte@3.59.1)(typescript@5.1.3): resolution: {integrity: sha512-ABia2QegosxOGsVlsSBJvoWeXy1wUKSfF7SWJdTjLAbx/Y3SrVevvvbFNQqrSJw89+lNSsM58SipmZJ5SRi5iw==} engines: {node: '>= 14.10.0'} @@ -23333,6 +23301,25 @@ packages: engines: {node: '>= 8'} dev: true + /svelte@4.0.5: + resolution: {integrity: sha512-PHKPWP1wiWHBtsE57nCb8xiWB3Ht7/3Kvi3jac0XIxUM2rep8alO7YoAtgWeGD7++tFy46krilOrPW0mG3Dx+A==} + engines: {node: '>=16'} + dependencies: + '@ampproject/remapping': 2.2.1 + '@jridgewell/sourcemap-codec': 1.4.15 + '@jridgewell/trace-mapping': 0.3.18 + acorn: 8.9.0 + aria-query: 5.3.0 + axobject-query: 3.2.1 + code-red: 1.0.3 + css-tree: 2.3.1 + estree-walker: 3.0.3 + is-reference: 3.0.1 + locate-character: 3.0.0 + magic-string: 0.30.1 + periscopic: 3.1.0 + dev: true + /sveltedoc-parser@4.2.1: resolution: {integrity: sha512-sWJRa4qOfRdSORSVw9GhfDEwsbsYsegnDzBevUCF6k/Eis/QqCu9lJ6I0+d/E2wOWCjOhlcJ3+jl/Iur+5mmCw==} engines: {node: '>=10.0.0'} @@ -24701,38 +24688,6 @@ packages: - supports-color dev: true - /vite@4.3.9: - resolution: {integrity: sha512-qsTNZjO9NoJNW7KnOrgYwczm0WctJ8m/yqYAMAK9Lxt4SoySUfS5S8ia9K7JHpa3KEeMfyF8LoJ3c5NeBJy6pg==} - engines: {node: ^14.18.0 || >=16.0.0} - hasBin: true - peerDependencies: - '@types/node': '>= 14' - less: '*' - sass: '*' - stylus: '*' - sugarss: '*' - terser: ^5.4.0 - peerDependenciesMeta: - '@types/node': - optional: true - less: - optional: true - sass: - optional: true - stylus: - optional: true - sugarss: - optional: true - terser: - optional: true - dependencies: - esbuild: 0.17.18 - postcss: 8.4.24 - rollup: 3.23.0 - optionalDependencies: - fsevents: 2.3.2 - dev: false - /vite@4.3.9(@types/node@18.16.19): resolution: {integrity: sha512-qsTNZjO9NoJNW7KnOrgYwczm0WctJ8m/yqYAMAK9Lxt4SoySUfS5S8ia9K7JHpa3KEeMfyF8LoJ3c5NeBJy6pg==} engines: {node: ^14.18.0 || >=16.0.0} @@ -24764,7 +24719,6 @@ packages: rollup: 3.23.0 optionalDependencies: fsevents: 2.3.2 - dev: true /vite@4.3.9(@types/node@18.7.13): resolution: {integrity: sha512-qsTNZjO9NoJNW7KnOrgYwczm0WctJ8m/yqYAMAK9Lxt4SoySUfS5S8ia9K7JHpa3KEeMfyF8LoJ3c5NeBJy6pg==} @@ -25148,43 +25102,6 @@ packages: - utf-8-validate dev: true - /webdriverio@8.12.1: - resolution: {integrity: sha512-lW0Qo3fy64cVbYWWAZbXxLIOK0pbTARgpY89J+0Sr6zh2K2NKtd/0D11k3WfMeYxd0b0he7E7XC1b6M6w4h75A==} - engines: {node: ^16.13 || >=18} - dependencies: - '@types/node': 20.4.1 - '@wdio/config': 8.12.1 - '@wdio/logger': 8.11.0 - '@wdio/protocols': 8.11.0 - '@wdio/repl': 8.10.1 - '@wdio/types': 8.10.4 - '@wdio/utils': 8.12.1 - archiver: 5.3.1 - aria-query: 5.3.0 - css-shorthand-properties: 1.1.1 - css-value: 0.0.1 - devtools: 8.12.1 - devtools-protocol: 0.0.1161598 - grapheme-splitter: 1.0.4 - import-meta-resolve: 3.0.0 - is-plain-obj: 4.1.0 - lodash.clonedeep: 4.5.0 - lodash.zip: 4.2.0 - minimatch: 9.0.1 - puppeteer-core: 20.3.0 - query-selector-shadow-dom: 1.0.1 - resq: 1.11.0 - rgb2hex: 0.2.5 - serialize-error: 8.1.0 - webdriver: 8.12.1 - transitivePeerDependencies: - - bufferutil - - encoding - - supports-color - - typescript - - utf-8-validate - dev: true - /webdriverio@8.12.1(typescript@5.1.6): resolution: {integrity: sha512-lW0Qo3fy64cVbYWWAZbXxLIOK0pbTARgpY89J+0Sr6zh2K2NKtd/0D11k3WfMeYxd0b0he7E7XC1b6M6w4h75A==} engines: {node: ^16.13 || >=18} From 1def1f9e634b4350d83917c1e98ba19be8d6989b Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 11 Jul 2023 20:05:51 +0200 Subject: [PATCH 57/87] chore: fix ts types --- tsconfig.json | 1 + 1 file changed, 1 insertion(+) diff --git a/tsconfig.json b/tsconfig.json index f4b1805c6367..6077cbb2d44d 100644 --- a/tsconfig.json +++ b/tsconfig.json @@ -30,6 +30,7 @@ "vitest": ["./packages/vitest/src/index.ts"], "vitest/globals": ["./packages/vitest/globals.d.ts"], "vitest/node": ["./packages/vitest/src/node/index.ts"], + "vitest/execute": ["./packages/vitest/src/public/execute.ts"], "vitest/config": ["./packages/vitest/src/config.ts"], "vitest/coverage": ["./packages/vitest/src/coverage.ts"], "vitest/browser": ["./packages/vitest/src/browser.ts"], From 78459c75189af460145782339427544ab06719bd Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 11 Jul 2023 20:18:54 +0200 Subject: [PATCH 58/87] chore: update svelte testing-library --- examples/svelte/package.json | 2 +- pnpm-lock.yaml | 12 ++++++------ 2 files changed, 7 insertions(+), 7 deletions(-) diff --git a/examples/svelte/package.json b/examples/svelte/package.json index a1b2bde25082..3fdbc671f6dd 100644 --- a/examples/svelte/package.json +++ b/examples/svelte/package.json @@ -9,7 +9,7 @@ }, "devDependencies": { "@sveltejs/vite-plugin-svelte": "latest", - "@testing-library/svelte": "latest", + "@testing-library/svelte": "^4.0.3", "@vitest/ui": "latest", "jsdom": "latest", "svelte": "latest", diff --git a/pnpm-lock.yaml b/pnpm-lock.yaml index f0a3bb4ca65f..d8a973424514 100644 --- a/pnpm-lock.yaml +++ b/pnpm-lock.yaml @@ -736,8 +736,8 @@ importers: specifier: latest version: 2.4.2(svelte@4.0.5)(vite@4.3.9) '@testing-library/svelte': - specifier: latest - version: 3.2.2(svelte@4.0.5) + specifier: ^4.0.3 + version: 4.0.3(svelte@4.0.5) '@vitest/ui': specifier: latest version: link:../../packages/ui @@ -8500,13 +8500,13 @@ packages: react-dom: 18.2.0(react@18.2.0) dev: true - /@testing-library/svelte@3.2.2(svelte@4.0.5): - resolution: {integrity: sha512-IKwZgqbekC3LpoRhSwhd0JswRGxKdAGkf39UiDXTywK61YyLXbCYoR831e/UUC6EeNW4hiHPY+2WuovxOgI5sw==} + /@testing-library/svelte@4.0.3(svelte@4.0.5): + resolution: {integrity: sha512-GldAnyGEOn5gMwME+hLVQrnfuKZFB+it5YOMnRBHX+nqeHMsSa18HeqkdvGqtqLpvn81xV7R7EYFb500ngUfXA==} engines: {node: '>= 10'} peerDependencies: - svelte: 3.x + svelte: ^3 || ^4 dependencies: - '@testing-library/dom': 8.19.0 + '@testing-library/dom': 9.3.1 svelte: 4.0.5 dev: true From 709a5ed76f3e7914ed947aafe5c77129ab61aa54 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 11 Jul 2023 20:26:35 +0200 Subject: [PATCH 59/87] chore: error is not the same --- packages/vitest/src/runtime/vm.ts | 1 + test/web-worker/test/init.test.ts | 4 +++- test/web-worker/test/sharedWorker.spec.ts | 4 +++- 3 files changed, 7 insertions(+), 2 deletions(-) diff --git a/packages/vitest/src/runtime/vm.ts b/packages/vitest/src/runtime/vm.ts index d378ba68ad77..e5ee30e32ff0 100644 --- a/packages/vitest/src/runtime/vm.ts +++ b/packages/vitest/src/runtime/vm.ts @@ -72,6 +72,7 @@ export async function run(ctx: WorkerContext) { process.env.VITEST_WORKER_ID = String(ctx.workerId) process.env.VITEST_POOL_ID = String(poolId) + process.env.VITEST_VM_POOL = '1' if (!vm.getVmContext) throw new TypeError(`Environment ${ctx.environment.name} doesn't provide "getVmContext" method. It should return a context created by "vm.createContext" method.`) diff --git a/test/web-worker/test/init.test.ts b/test/web-worker/test/init.test.ts index 27f7434e5167..8b75947feb26 100644 --- a/test/web-worker/test/init.test.ts +++ b/test/web-worker/test/init.test.ts @@ -65,7 +65,9 @@ it('worker with invalid url throws an error', async () => { } }) expect(event).toBeInstanceOf(ErrorEvent) - expect(event.error).toBeInstanceOf(Error) + // Error is in different context when running in VM. This is consistent with jest. + if (!import.meta.env.VITEST_VM_POOL) + expect(event.error).toBeInstanceOf(Error) expect(event.error.message).toContain('Failed to load') }) diff --git a/test/web-worker/test/sharedWorker.spec.ts b/test/web-worker/test/sharedWorker.spec.ts index 792289f478b0..c245d4b5976c 100644 --- a/test/web-worker/test/sharedWorker.spec.ts +++ b/test/web-worker/test/sharedWorker.spec.ts @@ -49,7 +49,9 @@ it('throws an error on invalid path', async () => { } }) expect(event).toBeInstanceOf(ErrorEvent) - expect(event.error).toBeInstanceOf(Error) + // Error is in different context when running in VM. This is consistent with jest. + if (!import.meta.env.VITEST_VM_POOL) + expect(event.error).toBeInstanceOf(Error) expect(event.error.message).toContain('Failed to load') }) From 17fffdb5963af311240b5079f3c929870d7b15b1 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Tue, 11 Jul 2023 20:41:27 +0200 Subject: [PATCH 60/87] chore: skip single thread in vm --- package.json | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/package.json b/package.json index b4ff21bea692..f967a870ba02 100644 --- a/package.json +++ b/package.json @@ -23,7 +23,7 @@ "test:run": "vitest run -r test/core", "test:all": "CI=true pnpm -r --stream run test --allowOnly", "test:ci": "CI=true pnpm -r --stream --filter !test-fails --filter !test-browser --filter !test-esm --filter !test-browser run test --allowOnly", - "test:ci:vm-threads": "CI=true pnpm -r --stream --filter !test-fails --filter !test-browser --filter !test-esm --filter !test-browser run test --allowOnly --experimental-vm-threads", + "test:ci:vm-threads": "CI=true pnpm -r --stream --filter !test-fails --filter !test-single-thread --filter !test-browser --filter !test-esm --filter !test-browser run test --allowOnly --experimental-vm-threads", "test:ci:single-thread": "CI=true pnpm -r --stream --filter !test-fails --filter !test-coverage --filter !test-watch --filter !test-bail --filter !test-esm --filter !test-browser run test --allowOnly --no-threads", "typecheck": "tsc --noEmit", "typecheck:why": "tsc --noEmit --explainFiles > explainTypes.txt", From 3bc2d0aafb2c837cdf3c894b20c4f9cca9588fe0 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Wed, 12 Jul 2023 09:47:38 +0200 Subject: [PATCH 61/87] chore: move findNearestPackageData --- packages/vite-node/src/server.ts | 141 +----------------- packages/vite-node/src/utils.ts | 48 +++++- packages/vitest/src/node/pools/rpc.ts | 4 - packages/vitest/src/runtime/execute.ts | 15 +- .../vitest/src/runtime/external-executor.ts | 52 ++++++- packages/vitest/src/runtime/mocker.ts | 47 +++--- packages/vitest/src/types/config.ts | 3 - packages/vitest/src/types/rpc.ts | 1 - 8 files changed, 127 insertions(+), 184 deletions(-) diff --git a/packages/vite-node/src/server.ts b/packages/vite-node/src/server.ts index 2a9ab558d648..6e01f8b29a06 100644 --- a/packages/vite-node/src/server.ts +++ b/packages/vite-node/src/server.ts @@ -1,7 +1,7 @@ import { performance } from 'node:perf_hooks' -import { existsSync, readFileSync, statSync } from 'node:fs' -import { dirname, join, normalize, relative, resolve } from 'pathe' -import { type PackageCache, type PackageData, type TransformResult, type ViteDevServer, createFilter } from 'vite' +import { existsSync } from 'node:fs' +import { join, normalize, relative, resolve } from 'pathe' +import { type PackageCache, type TransformResult, type ViteDevServer } from 'vite' import createDebug from 'debug' import type { EncodedSourceMap } from '@jridgewell/trace-mapping' import type { DebuggerOptions, FetchResult, ViteNodeResolveId, ViteNodeServerOptions } from './types' @@ -151,40 +151,6 @@ export class ViteNodeServer { return this.transformPromiseMap.get(id)! } - findNearestPackageData(basedir: string) { - const config = this.server.config - // @ts-expect-error not typed - const packageCache = config.packageCache || this.packageCache - const originalBasedir = basedir - while (basedir) { - if (packageCache) { - const cached = getFnpdCache(packageCache, basedir, originalBasedir) - if (cached) - return cached - } - - const pkgPath = join(basedir, 'package.json') - try { - if (statSync(pkgPath, { throwIfNoEntry: false })?.isFile()) { - const pkgData = loadPackageData(pkgPath) - - if (packageCache) - setFnpdCache(packageCache, pkgData, basedir, originalBasedir) - - return pkgData - } - } - catch {} - - const nextBasedir = dirname(basedir) - if (nextBasedir === basedir) - break - basedir = nextBasedir - } - - return null - } - getTransformMode(id: string) { const withoutQuery = id.split('?')[0] @@ -286,104 +252,3 @@ export class ViteNodeServer { return result } } - -export function loadPackageData(pkgPath: string): PackageData { - const data = JSON.parse(readFileSync(pkgPath, 'utf-8')) - const pkgDir = dirname(pkgPath) - const { sideEffects } = data - let hasSideEffects: (id: string) => boolean - if (typeof sideEffects === 'boolean') { - hasSideEffects = () => sideEffects - } - else if (Array.isArray(sideEffects)) { - const finalPackageSideEffects = sideEffects.map((sideEffect) => { - /* - * The array accepts simple glob patterns to the relevant files... Patterns like *.css, which do not include a /, will be treated like **\/*.css. - * https://webpack.js.org/guides/tree-shaking/ - * https://github.com/vitejs/vite/pull/11807 - */ - if (sideEffect.includes('/')) - return sideEffect - - return `**/${sideEffect}` - }) - - hasSideEffects = createFilter(finalPackageSideEffects, null, { - resolve: pkgDir, - }) - } - else { - hasSideEffects = () => true - } - - const pkg: PackageData = { - dir: pkgDir, - data, - hasSideEffects, - webResolvedImports: {}, - nodeResolvedImports: {}, - setResolvedCache(key: string, entry: string, targetWeb: boolean) { - if (targetWeb) - pkg.webResolvedImports[key] = entry - else - pkg.nodeResolvedImports[key] = entry - }, - getResolvedCache(key: string, targetWeb: boolean) { - if (targetWeb) - return pkg.webResolvedImports[key] - - else - return pkg.nodeResolvedImports[key] - }, - } - - return pkg -} - -function getFnpdCache( - packageCache: PackageCache, - basedir: string, - originalBasedir: string, -) { - const cacheKey = getFnpdCacheKey(basedir) - const pkgData = packageCache.get(cacheKey) - if (pkgData) { - traverseBetweenDirs(originalBasedir, basedir, (dir) => { - packageCache.set(getFnpdCacheKey(dir), pkgData) - }) - return pkgData - } -} - -function setFnpdCache( - packageCache: PackageCache, - pkgData: PackageData, - basedir: string, - originalBasedir: string, -) { - packageCache.set(getFnpdCacheKey(basedir), pkgData) - traverseBetweenDirs(originalBasedir, basedir, (dir) => { - packageCache.set(getFnpdCacheKey(dir), pkgData) - }) -} - -// package cache key for `findNearestPackageData` -function getFnpdCacheKey(basedir: string) { - return `fnpd_${basedir}` -} - -/** - * Traverse between `longerDir` (inclusive) and `shorterDir` (exclusive) and call `cb` for each dir. - * @param longerDir Longer dir path, e.g. `/User/foo/bar/baz` - * @param shorterDir Shorter dir path, e.g. `/User/foo` - */ -function traverseBetweenDirs( - longerDir: string, - shorterDir: string, - cb: (dir: string) => void, -) { - while (longerDir !== shorterDir) { - cb(longerDir) - longerDir = dirname(longerDir) - } -} diff --git a/packages/vite-node/src/utils.ts b/packages/vite-node/src/utils.ts index 1f2b76362cc3..fdd349db9291 100644 --- a/packages/vite-node/src/utils.ts +++ b/packages/vite-node/src/utils.ts @@ -1,7 +1,7 @@ import { fileURLToPath, pathToFileURL } from 'node:url' import { builtinModules } from 'node:module' import { existsSync } from 'node:fs' -import { resolve } from 'pathe' +import { dirname, resolve } from 'pathe' import type { Arrayable, Nullable } from './types' export const isWindows = process.platform === 'win32' @@ -153,3 +153,49 @@ export function toArray(array?: Nullable>): Array { return [array] } + +export function getCachedData( + cache: Map, + basedir: string, + originalBasedir: string, +) { + const pkgData = cache.get(getFnpdCacheKey(basedir)) + if (pkgData) { + traverseBetweenDirs(originalBasedir, basedir, (dir) => { + cache.set(getFnpdCacheKey(dir), pkgData) + }) + return pkgData + } +} + +export function setCacheData( + cache: Map, + data: T, + basedir: string, + originalBasedir: string, +) { + cache.set(getFnpdCacheKey(basedir), data) + traverseBetweenDirs(originalBasedir, basedir, (dir) => { + cache.set(getFnpdCacheKey(dir), data) + }) +} + +function getFnpdCacheKey(basedir: string) { + return `fnpd_${basedir}` +} + +/** + * Traverse between `longerDir` (inclusive) and `shorterDir` (exclusive) and call `cb` for each dir. + * @param longerDir Longer dir path, e.g. `/User/foo/bar/baz` + * @param shorterDir Shorter dir path, e.g. `/User/foo` + */ +function traverseBetweenDirs( + longerDir: string, + shorterDir: string, + cb: (dir: string) => void, +) { + while (longerDir !== shorterDir) { + cb(longerDir) + longerDir = dirname(longerDir) + } +} diff --git a/packages/vitest/src/node/pools/rpc.ts b/packages/vitest/src/node/pools/rpc.ts index 2b4e351be41a..020ea2cf4747 100644 --- a/packages/vitest/src/node/pools/rpc.ts +++ b/packages/vitest/src/node/pools/rpc.ts @@ -61,9 +61,5 @@ export function createMethodsRPC(project: WorkspaceProject): RuntimeRPC { getCountOfFailedTests() { return ctx.state.getCountOfFailedTests() }, - async findNearestPackageData(file) { - const pkgData = project.vitenode.findNearestPackageData(file) - return pkgData?.data || {} - }, } } diff --git a/packages/vitest/src/runtime/execute.ts b/packages/vitest/src/runtime/execute.ts index f2dc3db83736..b1268d3bda47 100644 --- a/packages/vitest/src/runtime/execute.ts +++ b/packages/vitest/src/runtime/execute.ts @@ -6,7 +6,7 @@ import type { ViteNodeRunnerOptions } from 'vite-node' import { normalize, relative, resolve } from 'pathe' import { processError } from '@vitest/utils/error' import type { MockMap } from '../types/mocker' -import type { ResolvedConfig, ResolvedTestEnvironment, RuntimeRPC, WorkerGlobalState } from '../types' +import type { ResolvedConfig, ResolvedTestEnvironment, WorkerGlobalState } from '../types' import { distDir } from '../paths' import { getWorkerState } from '../utils/global' import { VitestMocker } from './mocker' @@ -16,9 +16,9 @@ const entryUrl = pathToFileURL(resolve(distDir, 'entry.js')).href export interface ExecuteOptions extends ViteNodeRunnerOptions { mockMap: MockMap + packageCache: Map moduleDirectories?: string[] context?: vm.Context - findNearestPackageData?: RuntimeRPC['findNearestPackageData'] state: WorkerGlobalState } @@ -36,6 +36,7 @@ let _viteNode: { executor: VitestExecutor } +export const packageCache = new Map() export const moduleCache = new ModuleCacheMap() export const mockMap: MockMap = new Map() @@ -56,7 +57,6 @@ export interface ContextExecutorOptions { mockMap?: MockMap moduleCache?: ModuleCacheMap context?: vm.Context - findNearestPackageData?: RuntimeRPC['findNearestPackageData'] state: WorkerGlobalState } @@ -98,9 +98,7 @@ export async function startVitestExecutor(options: ContextExecutorOptions) { resolveId(id, importer) { return rpc().resolveId(id, importer, getTransformMode()) }, - findNearestPackageData(file) { - return rpc().findNearestPackageData(file) - }, + packageCache, moduleCache, mockMap, get interopDefault() { return state().config.deps.interopDefault }, @@ -160,7 +158,10 @@ export class VitestExecutor extends ViteNodeRunner { } } else { - this.externalModules = new ExternalModulesExecutor(options.context, options.findNearestPackageData || (() => Promise.resolve({}))) + this.externalModules = new ExternalModulesExecutor({ + context: options.context, + packageCache: options.packageCache, + }) const clientStub = vm.runInContext(`(defaultClient) => ({ ...defaultClient, updateStyle: ${updateStyle.toString()} })`, options.context)(DEFAULT_REQUEST_STUBS['@vite/client']) this.options.requestStubs = { '/@vite/client': clientStub, diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index fefdd06ea88b..e3213451bb9d 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -4,11 +4,10 @@ import vm from 'node:vm' import { fileURLToPath, pathToFileURL } from 'node:url' import { dirname } from 'node:path' import { Module as _Module, createRequire } from 'node:module' -import { readFileSync } from 'node:fs' +import { readFileSync, statSync } from 'node:fs' import { readFile } from 'node:fs/promises' -import { basename, extname } from 'pathe' -import { isNodeBuiltin } from 'vite-node/utils' -import type { RuntimeRPC } from '../types' +import { basename, extname, join } from 'pathe' +import { getCachedData, isNodeBuiltin, setCacheData } from 'vite-node/utils' // need to copy paste types for vm // because they require latest @types/node which we don't bundle @@ -92,6 +91,11 @@ const _require = createRequire(import.meta.url) const nativeResolve = import.meta.resolve! +interface ExternalModulesExecutorOptions { + context: vm.Context + packageCache: Map +} + // TODO: improve Node.js strict mode support in #2854 export class ExternalModulesExecutor { private requireCache: Record = Object.create(null) @@ -100,18 +104,20 @@ export class ExternalModulesExecutor { private extensions: Record unknown> = Object.create(null) private esmLinkMap = new WeakMap>() + private context: vm.Context private Module: typeof _Module private primitives: { Object: typeof Object } - constructor(private context: vm.Context, private findNearestPackageData: RuntimeRPC['findNearestPackageData']) { - this.context = context + constructor(private options: ExternalModulesExecutorOptions) { + this.context = options.context // eslint-disable-next-line @typescript-eslint/no-this-alias const executor = this + // primitive implementation, some fields are not filled yet, like "paths" - #2854 this.Module = class Module { exports: any isPreloading = false @@ -143,7 +149,7 @@ export class ExternalModulesExecutor { } as any) // @ts-expect-error mark script with current identifier script.identifier = filename - const fn = script.runInContext(context) + const fn = script.runInContext(executor.context) const __dirname = dirname(filename) executor.requireCache[filename] = this try { @@ -200,7 +206,7 @@ export class ExternalModulesExecutor { this.extensions['.js'] = this.requireJs this.extensions['.json'] = this.requireJson - this.primitives = vm.runInContext('({ Object })', context) + this.primitives = vm.runInContext('({ Object })', this.context) } private requireJs = (m: NodeModule, filename: string) => { @@ -227,6 +233,36 @@ export class ExternalModulesExecutor { return nativeResolve(specifier, parent) } + private async findNearestPackageData(basedir: string) { + const originalBasedir = basedir + const packageCache = this.options.packageCache + while (basedir) { + const cached = getCachedData(packageCache, basedir, originalBasedir) + if (cached) + return cached + + const pkgPath = join(basedir, 'package.json') + try { + if (statSync(pkgPath, { throwIfNoEntry: false })?.isFile()) { + const pkgData = JSON.parse(readFileSync(pkgPath, 'utf-8')) + + if (packageCache) + setCacheData(packageCache, pkgData, basedir, originalBasedir) + + return pkgData + } + } + catch {} + + const nextBasedir = dirname(basedir) + if (nextBasedir === basedir) + break + basedir = nextBasedir + } + + return null + } + private async wrapSynteticModule(identifier: string, format: 'esm' | 'builtin' | 'cjs', exports: Record) { // TODO: technically module should be parsed to find static exports, implement for #2854 const moduleKeys = Object.keys(exports) diff --git a/packages/vitest/src/runtime/mocker.ts b/packages/vitest/src/runtime/mocker.ts index 612747ccad38..837082ba5787 100644 --- a/packages/vitest/src/runtime/mocker.ts +++ b/packages/vitest/src/runtime/mocker.ts @@ -4,15 +4,12 @@ import { basename, dirname, extname, isAbsolute, join, resolve } from 'pathe' import { getColors, getType } from '@vitest/utils' import { isNodeBuiltin } from 'vite-node/utils' import { distDir } from '../paths' -import type { GlobalConstructors } from '../utils/base' import { getAllMockableProperties } from '../utils/base' import type { MockFactory, PendingSuiteMock } from '../types/mocker' import type { VitestExecutor } from './execute' const spyModulePath = resolve(distDir, 'spy.js') -const filterPublicKeys = ['__esModule', Symbol.asyncIterator, Symbol.hasInstance, Symbol.isConcatSpreadable, Symbol.iterator, Symbol.match, Symbol.matchAll, Symbol.replace, Symbol.search, Symbol.split, Symbol.species, Symbol.toPrimitive, Symbol.toStringTag, Symbol.unscopables] - class RefTracker { private idMap = new Map() private mockedValueMap = new Map() @@ -45,10 +42,31 @@ export class VitestMocker { static pendingIds: PendingSuiteMock[] = [] private spyModule?: typeof import('@vitest/spy') private resolveCache = new Map>() + private primitives: { + Object: typeof Object + Function: typeof Function + RegExp: typeof RegExp + Array: typeof Array + Map: typeof Map + Error: typeof Error + Symbol: typeof Symbol + } + + private filterPublicKeys: (symbol | string)[] constructor( public executor: VitestExecutor, - ) {} + ) { + const context = this.executor.options.context + if (context) + this.primitives = vm.runInContext('({ Object, Symbol, Error, Function, RegExp, Array, Map })', context) + else + this.primitives = { Object, Error, Function, RegExp, Symbol: globalThis.Symbol, Array, Map } + + const Symbol = this.primitives.Symbol + + this.filterPublicKeys = ['__esModule', Symbol.asyncIterator, Symbol.hasInstance, Symbol.isConcatSpreadable, Symbol.iterator, Symbol.match, Symbol.matchAll, Symbol.replace, Symbol.search, Symbol.split, Symbol.species, Symbol.toPrimitive, Symbol.toStringTag, Symbol.unscopables] + } private get root() { return this.executor.options.root @@ -84,25 +102,11 @@ export class VitestMocker { return this.executor.state.filepath || 'global' } - private getErrorConstructor(): typeof Error { - const context = this.executor.options.context - if (!context) - return Error - return vm.runInContext('Error', context) - } - private createError(message: string) { - const Error = this.getErrorConstructor() + const Error = this.primitives.Error return new Error(message) } - private getFinalConstructors(): GlobalConstructors { - const context = this.executor.options.context - if (!context) - return { Object, Function, RegExp, Array, Map } - return vm.runInContext('({ Object, Function, RegExp, Array, Map })', context) - } - public getMocks() { const suite = this.getSuiteFilepath() const suiteMocks = this.mockMap.get(suite) @@ -190,7 +194,7 @@ export class VitestMocker { return target.then.bind(target) } else if (!(prop in target)) { - if (filterPublicKeys.includes(prop)) + if (this.filterPublicKeys.includes(prop)) return undefined const c = getColors() throw this.createError( @@ -261,7 +265,6 @@ export class VitestMocker { public mockObject(object: Record, mockExports: Record = {}) { const finalizers = new Array<() => void>() const refs = new RefTracker() - const constructors = this.getFinalConstructors() const define = (container: Record, key: Key, value: any) => { try { @@ -276,7 +279,7 @@ export class VitestMocker { const mockPropertiesOf = (container: Record, newContainer: Record) => { const containerType = getType(container) const isModule = containerType === 'Module' || !!container.__esModule - for (const { key: property, descriptor } of getAllMockableProperties(container, isModule, constructors)) { + for (const { key: property, descriptor } of getAllMockableProperties(container, isModule, this.primitives)) { // Modules define their exports as getters. We want to process those. if (!isModule && descriptor.get) { try { diff --git a/packages/vitest/src/types/config.ts b/packages/vitest/src/types/config.ts index c4406085adce..5b0b80bd19d6 100644 --- a/packages/vitest/src/types/config.ts +++ b/packages/vitest/src/types/config.ts @@ -316,9 +316,6 @@ export interface InlineConfig { */ experimentalVmWorkerMemoryLimit?: string | number - // TODO: document that "--no-isolate" has no effect on experimentalVmThreads - // TODO: workerIdleMemoryLimit for experimentalVmThreads, so they don't leak - /** * Enable multi-threading * diff --git a/packages/vitest/src/types/rpc.ts b/packages/vitest/src/types/rpc.ts index 0029cf77c834..9d0721b8864b 100644 --- a/packages/vitest/src/types/rpc.ts +++ b/packages/vitest/src/types/rpc.ts @@ -23,7 +23,6 @@ export interface RuntimeRPC { onTaskUpdate: (pack: TaskResultPack[]) => void onCancel: (reason: CancelReason) => void getCountOfFailedTests: () => number - findNearestPackageData: (file: string) => Promise> snapshotSaved: (snapshot: SnapshotResult) => void resolveSnapshotPath: (testPath: string) => string From 9a3c3104c06778eac17916231b4460d0e036cfd1 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Wed, 12 Jul 2023 10:56:19 +0200 Subject: [PATCH 62/87] chore: cleanup and docs --- docs/config/index.md | 67 +- docs/guide/cli.md | 5 +- packages/runner/src/types/runner.ts | 2 +- packages/vite-node/package.json | 1 - packages/vitest/src/integrations/env/index.ts | 2 +- packages/vitest/src/public/execute.ts | 2 +- packages/vitest/src/runtime/environment.ts | 21 - pnpm-lock.yaml | 17029 +++++++--------- 8 files changed, 7034 insertions(+), 10095 deletions(-) delete mode 100644 packages/vitest/src/runtime/environment.ts diff --git a/docs/config/index.md b/docs/config/index.md index 83743e6bd415..859dd17acf66 100644 --- a/docs/config/index.md +++ b/docs/config/index.md @@ -469,7 +469,7 @@ export default defineConfig({ ### poolMatchGlobs -- **Type:** `[string, 'browser' | 'threads' | 'child_process'][]` +- **Type:** `[string, 'threads' | 'child_process' | 'experimentalVmThreads'][]` - **Default:** `[]` - **Version:** Since Vitest 0.29.4 @@ -543,6 +543,69 @@ Custom reporters for output. Reporters can be [a Reporter instance](https://gith Write test results to a file when the `--reporter=json`, `--reporter=html` or `--reporter=junit` option is also specified. By providing an object instead of a string you can define individual outputs when using multiple reporters. +### experimentalVmThreads + +- **Type:** `boolean` +- **CLI:** `--experimentalVmThreads`, `--experimental-vm-threads` +- **Version:** Since Vitets 0.34.0 + +Run tests using [VM context](https://nodejs.org/api/vm.html) (inside a sandboxed environment) in a worker pool. + +This makes tests run faster, but VM module is unstable when running [ESM code](https://github.com/nodejs/node/issues/37648). Your tests will [leak memory](https://github.com/nodejs/node/issues/33439) - to battle that, consider manually editing [`experimentalVmWorkerMemoryLimit`](#experimentalvmworkermemorylimit) value. + +::: warning +Running code in a sandbox has some advantages (faster tests), but also comes with a number of disadvantages. + +- Globals from native modules (`fs`, `path`, etc) are different from the globals in your test environment. It means that error thrown by any of the native modules will be different from the one you are using in your code: + +```ts +try { + fs.writeFile('/doesnt exist') +} +catch (err) { + consoel.log(err instanceof Error) // false +} +``` + +- Importing ES modules caches them indefinetly which introduces memory leak if you have a lot of contexts (or tests). There is no API in Node.js that clears that cache. +- Accessing globals [takes longer](https://github.com/nodejs/node/issues/31658) in a sandbox environment. + +Please, be aware of these issues when using this option. Vitest team cannot fix any of the issues on our side. +::: + +### experimentalVmWorkerMemoryLimit + +- **Type:** `string | number` +- **CLI:** `--experimentalVmWorkerMemoryLimit`, `--experimental-vm-worker-memory-limit` +- **Default:** `1 / CPU Cores` +- **Version:** Since Vitets 0.34.0 + +Specifies the memory limit for workers before they are recycled. This value heavily depends on your environment, so it's better to specify it manually instead of relying on default. + +This option only affects workers that run tests in [VM context](#experimentalvmthreads). + +::: tip +The implementation is based on Jest's [`workerIdleMemoryLimit`](https://jestjs.io/docs/configuration#workeridlememorylimit-numberstring). + +The limit can be specified in a number of different ways and whatever the result is `Math.floor` is used to turn it into an integer value: + +- `<= 1` - The value is assumed to be a percentage of system memory. So 0.5 sets the memory limit of the worker to half of the total system memory +- `\> 1` - Assumed to be a fixed byte value. Because of the previous rule if you wanted a value of 1 byte (I don't know why) you could use 1.1. +- With units + - `50%` - As above, a percentage of total system memory + - `100KB`, `65MB`, etc - With units to denote a fixed memory limit. + - `K` / `KB` - Kilobytes (x1000) + - `KiB` - Kibibytes (x1024) + - `M` / `MB` - Megabytes + - `MiB` - Mebibytes + - `G` / `GB` - Gigabytes + - `GiB` - Gibibytes +::: + +::: warning +Percentage based memory limit [does not work on Linux CircleCI](https://github.com/jestjs/jest/issues/11956#issuecomment-1212925677) workers due to incorrect system memory being reported. +::: + ### threads - **Type:** `boolean` @@ -709,6 +772,8 @@ Make sure that your files are not excluded by `watchExclude`. Isolate environment for each test file. Does not work if you disable [`--threads`](#threads). +This options has no effect on [`experimentalVmThreads`](#experimentalvmthreads). + ### coverage You can use [`v8`](https://v8.dev/blog/javascript-code-coverage), [`istanbul`](https://istanbul.js.org/) or [a custom coverage solution](/guide/coverage#custom-coverage-provider) for coverage collection. diff --git a/docs/guide/cli.md b/docs/guide/cli.md index 11a3ad0ea9ec..30dc90a4a678 100644 --- a/docs/guide/cli.md +++ b/docs/guide/cli.md @@ -69,7 +69,10 @@ Run only [benchmark](https://vitest.dev/guide/features.html#benchmarking-experim | `--ui` | Enable UI | | `--open` | Open the UI automatically if enabled (default: `true`) | | `--api [api]` | Serve API, available options: `--api.port `, `--api.host [host]` and `--api.strictPort` | -| `--threads` | Enable Threads (default: `true`) | +| `--threads` | Enable Threads (default: `true`) | +| `--single-thread` | Run tests inside a single thread, requires --threads (default: `false`) | +| `--experimental-vm-threads` | Run tests in a worker pool using VM isolation (default: `false`) | +| `--experimental-vm-worker-memory-limit` | Set maximum allowed memory for a worker. When reached, new worker will be created instead | | `--silent` | Silent console output from tests | | `--isolate` | Isolate environment for each test file (default: `true`) | | `--reporter ` | Select reporter: `default`, `verbose`, `dot`, `junit`, `json`, or a path to a custom reporter | diff --git a/packages/runner/src/types/runner.ts b/packages/runner/src/types/runner.ts index eda11ef84d14..25142152f9aa 100644 --- a/packages/runner/src/types/runner.ts +++ b/packages/runner/src/types/runner.ts @@ -29,7 +29,7 @@ export interface VitestRunnerConstructor { new(config: VitestRunnerConfig): VitestRunner } -export type CancelReason = 'keyboard-input' | 'test-failure' | 'memory-limit' | string & {} +export type CancelReason = 'keyboard-input' | 'test-failure' | string & Record export interface VitestRunner { /** diff --git a/packages/vite-node/package.json b/packages/vite-node/package.json index fbf355035c25..f0f31f22ef74 100644 --- a/packages/vite-node/package.json +++ b/packages/vite-node/package.json @@ -87,7 +87,6 @@ "devDependencies": { "@jridgewell/trace-mapping": "^0.3.18", "@types/debug": "^4.1.8", - "import-meta-resolve": "^2.2.2", "rollup": "^2.79.1" } } diff --git a/packages/vitest/src/integrations/env/index.ts b/packages/vitest/src/integrations/env/index.ts index ceb8d073c687..3015f9ddb252 100644 --- a/packages/vitest/src/integrations/env/index.ts +++ b/packages/vitest/src/integrations/env/index.ts @@ -49,7 +49,7 @@ export async function loadEnvironment(name: VitestEnvironment, root: string): Pr ) } const environment = pkg.default - if (!environment.transformMode) { + if (environment.transformMode !== 'web' && environment.transformMode !== 'ssr') { throw new TypeError( `Environment "${name}" is not a valid environment. ` + `Path "${packageId}" should export default object with a "transformMode" method equal to "ssr" or "web".`, diff --git a/packages/vitest/src/public/execute.ts b/packages/vitest/src/public/execute.ts index 4f1ee837f2d8..05fef48145a4 100644 --- a/packages/vitest/src/public/execute.ts +++ b/packages/vitest/src/public/execute.ts @@ -1 +1 @@ -export { VitestExecutor } from '../runtime/execute' \ No newline at end of file +export { VitestExecutor } from '../runtime/execute' diff --git a/packages/vitest/src/runtime/environment.ts b/packages/vitest/src/runtime/environment.ts deleted file mode 100644 index 06b5e66cc289..000000000000 --- a/packages/vitest/src/runtime/environment.ts +++ /dev/null @@ -1,21 +0,0 @@ -import { environments } from '../integrations/env' -import type { Environment } from '../types' - -export async function loadEnvironment(name: string, method: 'setup' | 'setupVM'): Promise { - if (name in environments) - return environments[name as 'jsdom'] - const pkg = await import(`vitest-environment-${name}`) - if (!pkg || !pkg.default || typeof pkg.default !== 'object') { - throw new Error( - `Environment "${name}" is not a valid environment. ` - + `Package "vitest-environment-${name}" should have default export with "${method}" method.`, - ) - } - if (typeof pkg.default[method] !== 'function') { - throw new TypeError( - `Environment "${name}" is not a valid environment. ` - + `Package "vitest-environment-${name}" doesn't support ${method === 'setupVM' ? 'vm' : 'non-vm'} environment because it doesn't provide "${method}" method.`, - ) - } - return pkg.default -} diff --git a/pnpm-lock.yaml b/pnpm-lock.yaml index d8a973424514..0e5409f4b4d8 100644 --- a/pnpm-lock.yaml +++ b/pnpm-lock.yaml @@ -1,8 +1,4 @@ -lockfileVersion: '6.0' - -settings: - autoInstallPeers: true - excludeLinksFromLockfile: false +lockfileVersion: 5.4 overrides: vite: ^4.3.9 @@ -11,1993 +7,1501 @@ overrides: importers: .: + specifiers: + '@antfu/eslint-config': ^0.39.6 + '@antfu/ni': ^0.21.4 + '@rollup/plugin-alias': ^5.0.0 + '@rollup/plugin-commonjs': ^25.0.2 + '@rollup/plugin-json': ^6.0.0 + '@rollup/plugin-node-resolve': ^15.1.0 + '@types/fs-extra': ^11.0.1 + '@types/lodash': ^4.14.195 + '@types/node': ^18.16.19 + '@types/ws': ^8.5.5 + '@vitest/browser': workspace:* + '@vitest/coverage-istanbul': workspace:* + '@vitest/coverage-v8': workspace:* + '@vitest/ui': workspace:* + bumpp: ^9.1.1 + esbuild: ^0.18.11 + eslint: ^8.44.0 + esno: ^0.16.3 + fast-glob: ^3.3.0 + if-node-version: ^1.1.1 + lint-staged: ^13.2.3 + magic-string: ^0.30.1 + node-fetch-native: ^1.2.0 + npm-run-all: ^4.1.5 + ohmyfetch: ^0.4.21 + pathe: ^1.1.1 + pnpm: 8.6.6 + rimraf: ^5.0.1 + rollup: ^3.26.0 + rollup-plugin-dts: ^5.3.0 + rollup-plugin-esbuild: ^5.0.0 + rollup-plugin-license: ^3.0.1 + simple-git-hooks: ^2.8.1 + ts-node: ^10.9.1 + tsup: ^6.7.0 + typescript: ^5.1.6 + vite: ^4.3.9 + vitest: workspace:* devDependencies: - '@antfu/eslint-config': - specifier: ^0.39.6 - version: 0.39.6(eslint@8.44.0)(typescript@5.1.6) - '@antfu/ni': - specifier: ^0.21.4 - version: 0.21.4 - '@rollup/plugin-alias': - specifier: ^5.0.0 - version: 5.0.0(rollup@3.26.0) - '@rollup/plugin-commonjs': - specifier: ^25.0.2 - version: 25.0.2(rollup@3.26.0) - '@rollup/plugin-json': - specifier: ^6.0.0 - version: 6.0.0(rollup@3.26.0) - '@rollup/plugin-node-resolve': - specifier: ^15.1.0 - version: 15.1.0(rollup@3.26.0) - '@types/fs-extra': - specifier: ^11.0.1 - version: 11.0.1 - '@types/lodash': - specifier: ^4.14.195 - version: 4.14.195 - '@types/node': - specifier: ^18.16.19 - version: 18.16.19 - '@types/ws': - specifier: ^8.5.5 - version: 8.5.5 - '@vitest/browser': - specifier: workspace:* - version: link:packages/browser - '@vitest/coverage-istanbul': - specifier: workspace:* - version: link:packages/coverage-istanbul - '@vitest/coverage-v8': - specifier: workspace:* - version: link:packages/coverage-v8 - '@vitest/ui': - specifier: workspace:* - version: link:packages/ui - bumpp: - specifier: ^9.1.1 - version: 9.1.1 - esbuild: - specifier: ^0.18.11 - version: 0.18.11 - eslint: - specifier: ^8.44.0 - version: 8.44.0 - esno: - specifier: ^0.16.3 - version: 0.16.3 - fast-glob: - specifier: ^3.3.0 - version: 3.3.0 - if-node-version: - specifier: ^1.1.1 - version: 1.1.1 - lint-staged: - specifier: ^13.2.3 - version: 13.2.3 - magic-string: - specifier: ^0.30.1 - version: 0.30.1 - node-fetch-native: - specifier: ^1.2.0 - version: 1.2.0 - npm-run-all: - specifier: ^4.1.5 - version: 4.1.5 - ohmyfetch: - specifier: ^0.4.21 - version: 0.4.21 - pathe: - specifier: ^1.1.1 - version: 1.1.1 - pnpm: - specifier: 8.6.6 - version: 8.6.6 - rimraf: - specifier: ^5.0.1 - version: 5.0.1 - rollup: - specifier: ^3.26.0 - version: 3.26.0 - rollup-plugin-dts: - specifier: ^5.3.0 - version: 5.3.0(rollup@3.26.0)(typescript@5.1.6) - rollup-plugin-esbuild: - specifier: ^5.0.0 - version: 5.0.0(esbuild@0.18.11)(rollup@3.26.0) - rollup-plugin-license: - specifier: ^3.0.1 - version: 3.0.1(rollup@3.26.0) - simple-git-hooks: - specifier: ^2.8.1 - version: 2.8.1 - ts-node: - specifier: ^10.9.1 - version: 10.9.1(@types/node@18.16.19)(typescript@5.1.6) - tsup: - specifier: ^6.7.0 - version: 6.7.0(ts-node@10.9.1)(typescript@5.1.6) - typescript: - specifier: ^5.1.6 - version: 5.1.6 - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:packages/vitest + '@antfu/eslint-config': 0.39.7_iqf7tbmerllfqanu4l3d6aqdn4 + '@antfu/ni': 0.21.4 + '@rollup/plugin-alias': 5.0.0_rollup@3.26.2 + '@rollup/plugin-commonjs': 25.0.2_rollup@3.26.2 + '@rollup/plugin-json': 6.0.0_rollup@3.26.2 + '@rollup/plugin-node-resolve': 15.1.0_rollup@3.26.2 + '@types/fs-extra': 11.0.1 + '@types/lodash': 4.14.195 + '@types/node': 18.16.19 + '@types/ws': 8.5.5 + '@vitest/browser': link:packages/browser + '@vitest/coverage-istanbul': link:packages/coverage-istanbul + '@vitest/coverage-v8': link:packages/coverage-v8 + '@vitest/ui': link:packages/ui + bumpp: 9.1.1 + esbuild: 0.18.11 + eslint: 8.44.0 + esno: 0.16.3 + fast-glob: 3.3.0 + if-node-version: 1.1.1 + lint-staged: 13.2.3 + magic-string: 0.30.1 + node-fetch-native: 1.2.0 + npm-run-all: 4.1.5 + ohmyfetch: 0.4.21 + pathe: 1.1.1 + pnpm: 8.6.6 + rimraf: 5.0.1 + rollup: 3.26.2 + rollup-plugin-dts: 5.3.0_btijhbnqj3bkl7p6fnurpsgzhq + rollup-plugin-esbuild: 5.0.0_b5okt2kat7kf37a3hh6exlw3ju + rollup-plugin-license: 3.0.1_rollup@3.26.2 + simple-git-hooks: 2.8.1 + ts-node: 10.9.1_pqdfkuhuhnwv2d7uogwywwxtqq + tsup: 6.7.0_kg5gpyde6u3komamnnl67a6oc4 + typescript: 5.1.6 + vite: 4.4.3_@types+node@18.16.19 + vitest: link:packages/vitest docs: + specifiers: + '@iconify-json/carbon': ^1.1.18 + '@unocss/reset': ^0.53.4 + '@vite-pwa/assets-generator': ^0.0.3 + '@vite-pwa/vitepress': ^0.2.0 + '@vitejs/plugin-vue': latest + '@vueuse/core': ^10.2.1 + esno: ^0.16.3 + fast-glob: ^3.3.0 + fs-extra: ^11.1.1 + https-localhost: ^4.7.1 + jiti: ^1.18.2 + unocss: ^0.53.4 + unplugin-vue-components: ^0.25.1 + vite: ^4.3.9 + vite-plugin-pwa: ^0.16.4 + vitepress: 1.0.0-beta.5 + vue: latest + workbox-window: ^7.0.0 dependencies: - '@vueuse/core': - specifier: ^10.2.1 - version: 10.2.1(vue@3.3.4) - jiti: - specifier: ^1.18.2 - version: 1.18.2 - vue: - specifier: latest - version: 3.3.4 + '@vueuse/core': 10.2.1_vue@3.3.4 + jiti: 1.19.1 + vue: 3.3.4 devDependencies: - '@iconify-json/carbon': - specifier: ^1.1.18 - version: 1.1.18 - '@unocss/reset': - specifier: ^0.53.4 - version: 0.53.4 - '@vite-pwa/assets-generator': - specifier: ^0.0.3 - version: 0.0.3 - '@vite-pwa/vitepress': - specifier: ^0.2.0 - version: 0.2.0(vite-plugin-pwa@0.16.4) - '@vitejs/plugin-vue': - specifier: latest - version: 4.2.3(vite@4.3.9)(vue@3.3.4) - esno: - specifier: ^0.16.3 - version: 0.16.3 - fast-glob: - specifier: ^3.3.0 - version: 3.3.0 - fs-extra: - specifier: ^11.1.1 - version: 11.1.1 - https-localhost: - specifier: ^4.7.1 - version: 4.7.1 - unocss: - specifier: ^0.53.4 - version: 0.53.4(postcss@8.4.24)(rollup@2.79.1)(vite@4.3.9) - unplugin-vue-components: - specifier: ^0.25.1 - version: 0.25.1(rollup@2.79.1)(vue@3.3.4) - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vite-plugin-pwa: - specifier: ^0.16.4 - version: 0.16.4(vite@4.3.9)(workbox-build@7.0.0)(workbox-window@7.0.0) - vitepress: - specifier: 1.0.0-beta.5 - version: 1.0.0-beta.5(@types/node@18.16.19)(search-insights@2.6.0) - workbox-window: - specifier: ^7.0.0 - version: 7.0.0 + '@iconify-json/carbon': 1.1.18 + '@unocss/reset': 0.53.5 + '@vite-pwa/assets-generator': 0.0.3 + '@vite-pwa/vitepress': 0.2.0_vite-plugin-pwa@0.16.4 + '@vitejs/plugin-vue': 4.2.3_vite@4.4.3+vue@3.3.4 + esno: 0.16.3 + fast-glob: 3.3.0 + fs-extra: 11.1.1 + https-localhost: 4.7.1 + unocss: 0.53.5_vite@4.4.3 + unplugin-vue-components: 0.25.1_vue@3.3.4 + vite: 4.4.3 + vite-plugin-pwa: 0.16.4_cqwyifvz3q2qdw6r4piqd2mqaa + vitepress: 1.0.0-beta.5 + workbox-window: 7.0.0 examples/basic: + specifiers: + '@vitest/ui': latest + vite: ^4.3.9 + vitest: workspace:* devDependencies: - '@vitest/ui': - specifier: latest - version: link:../../packages/ui - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@vitest/ui': link:../../packages/ui + vite: 4.4.3 + vitest: link:../../packages/vitest examples/fastify: + specifiers: + '@vitest/ui': latest + axios: ^0.26.1 + fastify: 4.5.3 + supertest: 6.2.4 + tsx: ^3.9.0 + vite: ^4.3.9 + vitest: workspace:* devDependencies: - '@vitest/ui': - specifier: latest - version: link:../../packages/ui - axios: - specifier: ^0.26.1 - version: 0.26.1 - fastify: - specifier: 4.5.3 - version: 4.5.3 - supertest: - specifier: 6.2.4 - version: 6.2.4 - tsx: - specifier: ^3.9.0 - version: 3.9.0 - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@vitest/ui': link:../../packages/ui + axios: 0.26.1 + fastify: 4.5.3 + supertest: 6.2.4 + tsx: 3.12.7 + vite: 4.4.3 + vitest: link:../../packages/vitest examples/graphql: - dependencies: - '@rollup/plugin-graphql': - specifier: ^1.1.0 - version: 1.1.0(graphql@16.6.0)(rollup@2.79.1) - graphql: - specifier: ^16.5.0 - version: 16.6.0 + specifiers: + '@rollup/plugin-graphql': ^1.1.0 + '@vitest/ui': latest + graphql: ^16.5.0 + vite: ^4.3.9 + vitest: workspace:* + dependencies: + '@rollup/plugin-graphql': 1.1.0_graphql@16.7.1 + graphql: 16.7.1 devDependencies: - '@vitest/ui': - specifier: latest - version: link:../../packages/ui - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@vitest/ui': link:../../packages/ui + vite: 4.4.3 + vitest: link:../../packages/vitest examples/image-snapshot: + specifiers: + '@vitest/ui': latest + jest-image-snapshot: ^4.5.1 + vite: ^4.3.9 + vitest: workspace:* devDependencies: - '@vitest/ui': - specifier: latest - version: link:../../packages/ui - jest-image-snapshot: - specifier: ^4.5.1 - version: 4.5.1(jest@27.5.1) - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@vitest/ui': link:../../packages/ui + jest-image-snapshot: 4.5.1 + vite: 4.4.3 + vitest: link:../../packages/vitest examples/lit: - dependencies: - lit: - specifier: ^2.2.5 - version: 2.3.1 + specifiers: + '@vitest/ui': latest + jsdom: latest + lit: ^2.2.5 + vite: ^4.3.9 + vitest: workspace:* + dependencies: + lit: 2.7.6 devDependencies: - '@vitest/ui': - specifier: latest - version: link:../../packages/ui - jsdom: - specifier: latest - version: 22.1.0 - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@vitest/ui': link:../../packages/ui + jsdom: 22.1.0 + vite: 4.4.3 + vitest: link:../../packages/vitest examples/mocks: - dependencies: - '@vueuse/integrations': - specifier: ^8.5.0 - version: 8.9.4(axios@0.26.1)(vue@3.2.39) - axios: - specifier: ^0.26.1 - version: 0.26.1 - tinyspy: - specifier: ^0.3.2 - version: 0.3.3 + specifiers: + '@vitest/ui': latest + '@vueuse/integrations': ^8.5.0 + axios: ^0.26.1 + react: ^18.0.0 + sweetalert2: ^11.6.16 + tinyspy: ^0.3.2 + vite: ^4.3.9 + vitest: workspace:* + vue: ^3.2.39 + zustand: ^4.1.1 + dependencies: + '@vueuse/integrations': 8.9.4_axios@0.26.1+vue@3.3.4 + axios: 0.26.1 + tinyspy: 0.3.3 devDependencies: - '@vitest/ui': - specifier: latest - version: link:../../packages/ui - react: - specifier: ^18.0.0 - version: 18.2.0 - sweetalert2: - specifier: ^11.6.16 - version: 11.6.16 - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest - vue: - specifier: ^3.2.39 - version: 3.2.39 - zustand: - specifier: ^4.1.1 - version: 4.1.1(react@18.2.0) + '@vitest/ui': link:../../packages/ui + react: 18.2.0 + sweetalert2: 11.7.16 + vite: 4.4.3 + vitest: link:../../packages/vitest + vue: 3.3.4 + zustand: 4.3.9_react@18.2.0 examples/nextjs: + specifiers: + '@testing-library/react': ^13.2.0 + '@types/node': latest + '@types/react': latest + '@vitejs/plugin-react': latest + jsdom: latest + next: 12.1.5 + react: 18.0.0 + react-dom: 18.0.0 + typescript: ^4.8.4 + vitest: workspace:* dependencies: - next: - specifier: 12.1.5 - version: 12.1.5(@babel/core@7.22.5)(react-dom@18.0.0)(react@18.0.0) - react: - specifier: 18.0.0 - version: 18.0.0 - react-dom: - specifier: 18.0.0 - version: 18.0.0(react@18.0.0) + next: 12.1.5_zpnidt7m3osuk7shl3s4oenomq + react: 18.0.0 + react-dom: 18.0.0_react@18.0.0 devDependencies: - '@testing-library/react': - specifier: ^13.2.0 - version: 13.3.0(react-dom@18.0.0)(react@18.0.0) - '@types/node': - specifier: latest - version: 20.4.1 - '@types/react': - specifier: latest - version: 18.2.14 - '@vitejs/plugin-react': - specifier: latest - version: 4.0.3(vite@4.3.9) - jsdom: - specifier: latest - version: 22.1.0 - typescript: - specifier: ^4.8.4 - version: 4.8.4 - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@testing-library/react': 13.4.0_zpnidt7m3osuk7shl3s4oenomq + '@types/node': 20.4.1 + '@types/react': 18.2.14 + '@vitejs/plugin-react': 4.0.3 + jsdom: 22.1.0 + typescript: 4.9.5 + vitest: link:../../packages/vitest examples/playwright: + specifiers: + '@playwright/test': ^1.28.0 + '@vitest/ui': latest + playwright: ^1.28.0 + vite: ^4.3.9 + vitest: workspace:* devDependencies: - '@playwright/test': - specifier: ^1.28.0 - version: 1.28.0 - '@vitest/ui': - specifier: latest - version: link:../../packages/ui - playwright: - specifier: ^1.28.0 - version: 1.28.0 - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@playwright/test': 1.36.0 + '@vitest/ui': link:../../packages/ui + playwright: 1.36.0 + vite: 4.4.3 + vitest: link:../../packages/vitest examples/puppeteer: + specifiers: + '@vitest/ui': latest + puppeteer: ^13.6.0 + vite: ^4.3.9 + vitest: workspace:* devDependencies: - '@vitest/ui': - specifier: latest - version: link:../../packages/ui - puppeteer: - specifier: ^13.6.0 - version: 13.7.0 - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@vitest/ui': link:../../packages/ui + puppeteer: 13.7.0 + vite: 4.4.3 + vitest: link:../../packages/vitest examples/react: + specifiers: + '@types/react': ^17.0.45 + '@types/react-test-renderer': ^17.0.2 + '@vitejs/plugin-react': latest + '@vitest/ui': latest + happy-dom: latest + jsdom: latest + react: ^17.0.2 + react-test-renderer: 17.0.2 + vite: ^4.3.9 + vitest: workspace:* dependencies: - react: - specifier: ^17.0.2 - version: 17.0.2 + react: 17.0.2 devDependencies: - '@types/react': - specifier: ^17.0.45 - version: 17.0.49 - '@types/react-test-renderer': - specifier: ^17.0.2 - version: 17.0.2 - '@vitejs/plugin-react': - specifier: latest - version: 4.0.3(vite@4.3.9) - '@vitest/ui': - specifier: latest - version: link:../../packages/ui - happy-dom: - specifier: latest - version: 9.20.3 - jsdom: - specifier: latest - version: 22.1.0 - react-test-renderer: - specifier: 17.0.2 - version: 17.0.2(react@17.0.2) - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@types/react': 17.0.62 + '@types/react-test-renderer': 17.0.2 + '@vitejs/plugin-react': 4.0.3_vite@4.4.3 + '@vitest/ui': link:../../packages/ui + happy-dom: 10.1.1 + jsdom: 22.1.0 + react-test-renderer: 17.0.2_react@17.0.2 + vite: 4.4.3 + vitest: link:../../packages/vitest examples/react-enzyme: + specifiers: + '@types/enzyme': ^3.10.12 + '@types/react': ^17.0.45 + '@types/react-dom': ^17.0.17 + '@vitejs/plugin-react': latest + '@vitest/ui': latest + '@wojtekmaj/enzyme-adapter-react-17': ^0.6.7 + enzyme: ^3.11.0 + jsdom: ^20.0.3 + react: ^17.0.2 + react-dom: ^17.0.2 + vite: ^4.3.9 + vitest: workspace:* dependencies: - react: - specifier: ^17.0.2 - version: 17.0.2 - react-dom: - specifier: ^17.0.2 - version: 17.0.2(react@17.0.2) + react: 17.0.2 + react-dom: 17.0.2_react@17.0.2 devDependencies: - '@types/enzyme': - specifier: ^3.10.12 - version: 3.10.12 - '@types/react': - specifier: ^17.0.45 - version: 17.0.49 - '@types/react-dom': - specifier: ^17.0.17 - version: 17.0.17 - '@vitejs/plugin-react': - specifier: latest - version: 4.0.3(vite@4.3.9) - '@vitest/ui': - specifier: latest - version: link:../../packages/ui - '@wojtekmaj/enzyme-adapter-react-17': - specifier: ^0.6.7 - version: 0.6.7(enzyme@3.11.0)(react-dom@17.0.2)(react@17.0.2) - enzyme: - specifier: ^3.11.0 - version: 3.11.0 - jsdom: - specifier: ^20.0.3 - version: 20.0.3 - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@types/enzyme': 3.10.13 + '@types/react': 17.0.62 + '@types/react-dom': 17.0.20 + '@vitejs/plugin-react': 4.0.3_vite@4.4.3 + '@vitest/ui': link:../../packages/ui + '@wojtekmaj/enzyme-adapter-react-17': 0.6.7_7ltvq4e2railvf5uya4ffxpe2a + enzyme: 3.11.0 + jsdom: 20.0.3 + vite: 4.4.3 + vitest: link:../../packages/vitest examples/react-mui: - dependencies: - '@emotion/react': - specifier: ^11.9.3 - version: 11.10.4(@babel/core@7.22.5)(react@18.2.0) - '@emotion/styled': - specifier: ^11.9.3 - version: 11.10.4(@babel/core@7.22.5)(@emotion/react@11.10.4)(react@18.2.0) - '@mui/material': - specifier: ^5.9.0 - version: 5.10.3(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(react-dom@18.2.0)(react@18.2.0) - '@mui/x-date-pickers': - specifier: 5.0.0-beta.0 - version: 5.0.0-beta.0(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(@mui/material@5.10.3)(@mui/system@5.10.3)(date-fns@2.29.2)(react-dom@18.2.0)(react@18.2.0) - history: - specifier: ^5.3.0 - version: 5.3.0 - notistack: - specifier: ^2.0.5 - version: 2.0.5(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(@mui/material@5.10.3)(react-dom@18.2.0)(react@18.2.0) - react: - specifier: ^18.2.0 - version: 18.2.0 - react-dom: - specifier: ^18.2.0 - version: 18.2.0(react@18.2.0) - react-router-dom: - specifier: ^6.3.0 - version: 6.3.0(react-dom@18.2.0)(react@18.2.0) - recharts: - specifier: ^2.1.12 - version: 2.1.13(prop-types@15.8.1)(react-dom@18.2.0)(react@18.2.0) - swr: - specifier: ^1.3.0 - version: 1.3.0(react@18.2.0) + specifiers: + '@emotion/react': ^11.9.3 + '@emotion/styled': ^11.9.3 + '@mui/material': ^5.9.0 + '@mui/x-date-pickers': 5.0.0-beta.0 + '@testing-library/jest-dom': ^5.16.4 + '@testing-library/react': ^13.3.0 + '@testing-library/user-event': ^14.2.3 + '@vitest/ui': latest + date-fns: ^2.28.0 + history: ^5.3.0 + jsdom: latest + notistack: ^2.0.5 + react: ^18.2.0 + react-dom: ^18.2.0 + react-router-dom: ^6.3.0 + recharts: ^2.1.12 + swr: ^1.3.0 + vite: ^4.3.9 + vitest: workspace:* + dependencies: + '@emotion/react': 11.11.1_react@18.2.0 + '@emotion/styled': 11.11.0_xo5t6f4ryb2nvjgwj2cxjowrye + '@mui/material': 5.14.0_vizhjgize6w4e5tnsjmztd65da + '@mui/x-date-pickers': 5.0.0-beta.0_dc6gge3gqnljarlkhzo67xqsla + history: 5.3.0 + notistack: 2.0.8_tr5jdv7ejqexso4qfp7vkl3yhi + react: 18.2.0 + react-dom: 18.2.0_react@18.2.0 + react-router-dom: 6.14.1_biqbaboplfbrettd7655fr4n2y + recharts: 2.7.2_biqbaboplfbrettd7655fr4n2y + swr: 1.3.0_react@18.2.0 devDependencies: - '@testing-library/jest-dom': - specifier: ^5.16.4 - version: 5.16.5 - '@testing-library/react': - specifier: ^13.3.0 - version: 13.3.0(react-dom@18.2.0)(react@18.2.0) - '@testing-library/user-event': - specifier: ^14.2.3 - version: 14.4.3(@testing-library/dom@9.3.1) - '@vitest/ui': - specifier: latest - version: link:../../packages/ui - date-fns: - specifier: ^2.28.0 - version: 2.29.2 - jsdom: - specifier: latest - version: 22.1.0 - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@testing-library/jest-dom': 5.16.5 + '@testing-library/react': 13.4.0_biqbaboplfbrettd7655fr4n2y + '@testing-library/user-event': 14.4.3 + '@vitest/ui': link:../../packages/ui + date-fns: 2.30.0 + jsdom: 22.1.0 + vite: 4.4.3 + vitest: link:../../packages/vitest examples/react-storybook: - dependencies: - cross-fetch: - specifier: ^3.1.5 - version: 3.1.5 - react: - specifier: ^17.0.2 - version: 17.0.2 - react-dom: - specifier: ^17.0.2 - version: 17.0.2(react@17.0.2) - react-query: - specifier: ^3.39.0 - version: 3.39.2(react-dom@17.0.2)(react@17.0.2) + specifiers: + '@babel/core': ^7.18.2 + '@storybook/addon-actions': ^6.5.5 + '@storybook/addon-essentials': ^6.5.5 + '@storybook/addon-links': ^6.5.5 + '@storybook/builder-vite': ^0.1.35 + '@storybook/react': ^6.5.5 + '@storybook/testing-library': ^0.0.11 + '@storybook/testing-react': ^1.3.0 + '@testing-library/jest-dom': ^5.16.4 + '@testing-library/react': ^12.1.5 + '@types/react': ^17.0.45 + '@types/react-dom': ^17.0.17 + '@vitejs/plugin-react': ^4.0.1 + '@vitest/ui': latest + babel-loader: ^8.2.5 + cross-fetch: ^3.1.5 + jsdom: latest + msw: ^0.49.2 + msw-storybook-addon: ^1.6.3 + react: ^17.0.2 + react-dom: ^17.0.2 + react-query: ^3.39.0 + typescript: ^4.8.4 + vite: ^4.3.9 + vitest: workspace:* + dependencies: + cross-fetch: 3.1.8 + react: 17.0.2 + react-dom: 17.0.2_react@17.0.2 + react-query: 3.39.3_sfoxds7t5ydpegc3knd667wn6m devDependencies: - '@babel/core': - specifier: ^7.18.2 - version: 7.18.13 - '@storybook/addon-actions': - specifier: ^6.5.5 - version: 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/addon-essentials': - specifier: ^6.5.5 - version: 6.5.10(@babel/core@7.18.13)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4)(webpack@5.74.0) - '@storybook/addon-links': - specifier: ^6.5.5 - version: 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/builder-vite': - specifier: ^0.1.35 - version: 0.1.41(@babel/core@7.18.13)(@storybook/core-common@6.5.10)(@storybook/node-logger@6.5.10)(@storybook/source-loader@6.5.10)(react@17.0.2)(typescript@4.8.4)(vite@4.3.9) - '@storybook/react': - specifier: ^6.5.5 - version: 6.5.10(@babel/core@7.18.13)(esbuild@0.18.11)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(require-from-string@2.0.2)(typescript@4.8.4) - '@storybook/testing-library': - specifier: ^0.0.11 - version: 0.0.11(react-dom@17.0.2)(react@17.0.2) - '@storybook/testing-react': - specifier: ^1.3.0 - version: 1.3.0(@storybook/addons@6.5.10)(@storybook/client-api@6.5.10)(@storybook/preview-web@6.5.10)(@storybook/react@6.5.10)(react@17.0.2) - '@testing-library/jest-dom': - specifier: ^5.16.4 - version: 5.16.5 - '@testing-library/react': - specifier: ^12.1.5 - version: 12.1.5(react-dom@17.0.2)(react@17.0.2) - '@types/react': - specifier: ^17.0.45 - version: 17.0.49 - '@types/react-dom': - specifier: ^17.0.17 - version: 17.0.17 - '@vitejs/plugin-react': - specifier: ^4.0.1 - version: 4.0.3(vite@4.3.9) - '@vitest/ui': - specifier: latest - version: link:../../packages/ui - babel-loader: - specifier: ^8.2.5 - version: 8.2.5(@babel/core@7.18.13)(webpack@5.74.0) - jsdom: - specifier: latest - version: 22.1.0 - msw: - specifier: ^0.49.2 - version: 0.49.2(typescript@4.8.4) - msw-storybook-addon: - specifier: ^1.6.3 - version: 1.6.3(msw@0.49.2)(react-dom@17.0.2)(react@17.0.2) - typescript: - specifier: ^4.8.4 - version: 4.8.4 - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@babel/core': 7.22.8 + '@storybook/addon-actions': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/addon-essentials': 6.5.16_7i6vyke6ny6b2xsni3leqxtq5y + '@storybook/addon-links': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/builder-vite': 0.1.41_qr3s4pqg2febfejexmksv4rlaa + '@storybook/react': 6.5.16_7i6vyke6ny6b2xsni3leqxtq5y + '@storybook/testing-library': 0.0.11 + '@storybook/testing-react': 1.3.0_o7jp7fwfcghoqe4nbzdqvmyhrm + '@testing-library/jest-dom': 5.16.5 + '@testing-library/react': 12.1.5_sfoxds7t5ydpegc3knd667wn6m + '@types/react': 17.0.62 + '@types/react-dom': 17.0.20 + '@vitejs/plugin-react': 4.0.3_vite@4.4.3 + '@vitest/ui': link:../../packages/ui + babel-loader: 8.3.0_@babel+core@7.22.8 + jsdom: 22.1.0 + msw: 0.49.3_typescript@4.9.5 + msw-storybook-addon: 1.8.0_msw@0.49.3 + typescript: 4.9.5 + vite: 4.4.3 + vitest: link:../../packages/vitest examples/react-testing-lib: + specifiers: + '@testing-library/jest-dom': ^5.16.4 + '@testing-library/react': ^13.4.0 + '@testing-library/user-event': ^14.4.3 + '@types/react': ^18.0.24 + '@types/react-dom': ^18.0.8 + '@vitejs/plugin-react': latest + '@vitest/coverage-v8': latest + '@vitest/ui': latest + jsdom: latest + react: ^18.2.0 + react-dom: ^18.2.0 + typescript: ^4.8.4 + vite: ^4.3.9 + vitest: workspace:* dependencies: - react: - specifier: ^18.2.0 - version: 18.2.0 - react-dom: - specifier: ^18.2.0 - version: 18.2.0(react@18.2.0) + react: 18.2.0 + react-dom: 18.2.0_react@18.2.0 devDependencies: - '@testing-library/jest-dom': - specifier: ^5.16.4 - version: 5.16.5 - '@testing-library/react': - specifier: ^13.4.0 - version: 13.4.0(react-dom@18.2.0)(react@18.2.0) - '@testing-library/user-event': - specifier: ^14.4.3 - version: 14.4.3(@testing-library/dom@9.3.1) - '@types/react': - specifier: ^18.0.24 - version: 18.0.25 - '@types/react-dom': - specifier: ^18.0.8 - version: 18.0.8 - '@vitejs/plugin-react': - specifier: latest - version: 4.0.3(vite@4.3.9) - '@vitest/coverage-v8': - specifier: latest - version: link:../../packages/coverage-v8 - '@vitest/ui': - specifier: latest - version: link:../../packages/ui - jsdom: - specifier: latest - version: 22.1.0 - typescript: - specifier: ^4.8.4 - version: 4.8.4 - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@testing-library/jest-dom': 5.16.5 + '@testing-library/react': 13.4.0_biqbaboplfbrettd7655fr4n2y + '@testing-library/user-event': 14.4.3 + '@types/react': 18.2.14 + '@types/react-dom': 18.2.6 + '@vitejs/plugin-react': 4.0.3_vite@4.4.3 + '@vitest/coverage-v8': link:../../packages/coverage-v8 + '@vitest/ui': link:../../packages/ui + jsdom: 22.1.0 + typescript: 4.9.5 + vite: 4.4.3 + vitest: link:../../packages/vitest examples/react-testing-lib-msw: - dependencies: - '@apollo/client': - specifier: ^3.6.6 - version: 3.6.9(graphql@16.6.0)(react@17.0.2) - react: - specifier: ^17.0.2 - version: 17.0.2 - react-dom: - specifier: ^17.0.2 - version: 17.0.2(react@17.0.2) + specifiers: + '@apollo/client': ^3.6.6 + '@testing-library/react': ^12.1.5 + '@testing-library/user-event': ^13.5.0 + '@types/react': ^17.0.45 + '@types/react-dom': ^17.0.17 + '@vitejs/plugin-react': ^4.0.1 + '@vitest/ui': latest + cross-fetch: ^3.1.5 + jsdom: latest + msw: ^1.2.1 + react: ^17.0.2 + react-dom: ^17.0.2 + vite: ^4.3.9 + vitest: workspace:* + dependencies: + '@apollo/client': 3.7.17_sfoxds7t5ydpegc3knd667wn6m + react: 17.0.2 + react-dom: 17.0.2_react@17.0.2 devDependencies: - '@testing-library/react': - specifier: ^12.1.5 - version: 12.1.5(react-dom@17.0.2)(react@17.0.2) - '@testing-library/user-event': - specifier: ^13.5.0 - version: 13.5.0(@testing-library/dom@9.3.1) - '@types/react': - specifier: ^17.0.45 - version: 17.0.49 - '@types/react-dom': - specifier: ^17.0.17 - version: 17.0.17 - '@vitejs/plugin-react': - specifier: ^4.0.1 - version: 4.0.3(vite@4.3.9) - '@vitest/ui': - specifier: latest - version: link:../../packages/ui - cross-fetch: - specifier: ^3.1.5 - version: 3.1.5 - jsdom: - specifier: latest - version: 22.1.0 - msw: - specifier: ^1.2.1 - version: 1.2.1(typescript@5.1.6) - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@testing-library/react': 12.1.5_sfoxds7t5ydpegc3knd667wn6m + '@testing-library/user-event': 13.5.0 + '@types/react': 17.0.62 + '@types/react-dom': 17.0.20 + '@vitejs/plugin-react': 4.0.3_vite@4.4.3 + '@vitest/ui': link:../../packages/ui + cross-fetch: 3.1.8 + jsdom: 22.1.0 + msw: 1.2.2 + vite: 4.4.3 + vitest: link:../../packages/vitest examples/ruby: + specifiers: + '@vitejs/plugin-vue': latest + '@vue/test-utils': latest + jsdom: latest + vite: ^4.3.9 + vite-plugin-ruby: ^3.0.12 + vitest: workspace:* + vue: latest devDependencies: - '@vitejs/plugin-vue': - specifier: latest - version: 4.2.3(vite@4.3.9)(vue@3.3.4) - '@vue/test-utils': - specifier: latest - version: 2.3.2(vue@3.3.4) - jsdom: - specifier: latest - version: 22.1.0 - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vite-plugin-ruby: - specifier: ^3.0.12 - version: 3.1.2(vite@4.3.9) - vitest: - specifier: workspace:* - version: link:../../packages/vitest - vue: - specifier: latest - version: 3.3.4 + '@vitejs/plugin-vue': 4.2.3_vite@4.4.3+vue@3.3.4 + '@vue/test-utils': 2.4.0_vue@3.3.4 + jsdom: 22.1.0 + vite: 4.4.3 + vite-plugin-ruby: 3.2.2_vite@4.4.3 + vitest: link:../../packages/vitest + vue: 3.3.4 examples/solid: - dependencies: - solid-js: - specifier: ^1.4.3 - version: 1.5.2 + specifiers: + '@testing-library/jest-dom': ^5.16.4 + jsdom: latest + solid-js: ^1.4.3 + solid-testing-library: ^0.5.0 + vite: ^4.3.9 + vite-plugin-solid: ^2.5.0 + vitest: workspace:* + dependencies: + solid-js: 1.7.8 devDependencies: - '@testing-library/jest-dom': - specifier: ^5.16.4 - version: 5.16.5 - jsdom: - specifier: latest - version: 22.1.0 - solid-testing-library: - specifier: ^0.5.0 - version: 0.5.0(solid-js@1.5.2) - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vite-plugin-solid: - specifier: ^2.5.0 - version: 2.5.0(solid-js@1.5.2)(vite@4.3.9) - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@testing-library/jest-dom': 5.16.5 + jsdom: 22.1.0 + solid-testing-library: 0.5.1_solid-js@1.7.8 + vite: 4.4.3 + vite-plugin-solid: 2.7.0_solid-js@1.7.8+vite@4.4.3 + vitest: link:../../packages/vitest examples/svelte: + specifiers: + '@sveltejs/vite-plugin-svelte': latest + '@testing-library/svelte': ^4.0.3 + '@vitest/ui': latest + jsdom: latest + svelte: latest + vite: ^4.3.9 + vitest: workspace:* devDependencies: - '@sveltejs/vite-plugin-svelte': - specifier: latest - version: 2.4.2(svelte@4.0.5)(vite@4.3.9) - '@testing-library/svelte': - specifier: ^4.0.3 - version: 4.0.3(svelte@4.0.5) - '@vitest/ui': - specifier: latest - version: link:../../packages/ui - jsdom: - specifier: latest - version: 22.1.0 - svelte: - specifier: latest - version: 4.0.5 - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@sveltejs/vite-plugin-svelte': 2.4.2_svelte@4.0.5+vite@4.4.3 + '@testing-library/svelte': 4.0.3_svelte@4.0.5 + '@vitest/ui': link:../../packages/ui + jsdom: 22.1.0 + svelte: 4.0.5 + vite: 4.4.3 + vitest: link:../../packages/vitest examples/sveltekit: + specifiers: + '@sveltejs/adapter-auto': ^2.1.0 + '@sveltejs/kit': ^1.20.2 + prettier: ^2.8.8 + prettier-plugin-svelte: ^2.10.1 + svelte: ^3.59.1 + svelte-check: ^3.4.3 + tslib: ^2.5.3 + typescript: ^5.1.3 + vite: ^4.3.9 + vitest: workspace:* devDependencies: - '@sveltejs/adapter-auto': - specifier: ^2.1.0 - version: 2.1.0(@sveltejs/kit@1.20.2) - '@sveltejs/kit': - specifier: ^1.20.2 - version: 1.20.2(svelte@3.59.1)(vite@4.3.9) - prettier: - specifier: ^2.8.8 - version: 2.8.8 - prettier-plugin-svelte: - specifier: ^2.10.1 - version: 2.10.1(prettier@2.8.8)(svelte@3.59.1) - svelte: - specifier: ^3.59.1 - version: 3.59.1 - svelte-check: - specifier: ^3.4.3 - version: 3.4.3(svelte@3.59.1) - tslib: - specifier: ^2.5.3 - version: 2.5.3 - typescript: - specifier: ^5.1.3 - version: 5.1.3 - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@sveltejs/adapter-auto': 2.1.0_@sveltejs+kit@1.22.2 + '@sveltejs/kit': 1.22.2_svelte@3.59.2+vite@4.4.3 + prettier: 2.8.8 + prettier-plugin-svelte: 2.10.1_jlgs5vq3kify7hyf3gm4oz2klm + svelte: 3.59.2 + svelte-check: 3.4.6_svelte@3.59.2 + tslib: 2.6.0 + typescript: 5.1.6 + vite: 4.4.3 + vitest: link:../../packages/vitest examples/vitesse: + specifiers: + '@vitejs/plugin-vue': latest + '@vue/test-utils': ^2.0.2 + jsdom: latest + unplugin-auto-import: latest + unplugin-vue-components: latest + vite: ^4.3.9 + vitest: workspace:* + vue: latest dependencies: - vue: - specifier: latest - version: 3.3.4 + vue: 3.3.4 devDependencies: - '@vitejs/plugin-vue': - specifier: latest - version: 4.2.3(vite@4.3.9)(vue@3.3.4) - '@vue/test-utils': - specifier: ^2.0.2 - version: 2.0.2(vue@3.3.4) - jsdom: - specifier: latest - version: 22.1.0 - unplugin-auto-import: - specifier: latest - version: 0.16.4(@vueuse/core@10.2.1)(rollup@3.26.0) - unplugin-vue-components: - specifier: latest - version: 0.25.1(rollup@3.26.0)(vue@3.3.4) - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@vitejs/plugin-vue': 4.2.3_vite@4.4.3+vue@3.3.4 + '@vue/test-utils': 2.4.0_vue@3.3.4 + jsdom: 22.1.0 + unplugin-auto-import: 0.16.6 + unplugin-vue-components: 0.25.1_vue@3.3.4 + vite: 4.4.3 + vitest: link:../../packages/vitest examples/vue: + specifiers: + '@vitejs/plugin-vue': latest + '@vue/test-utils': ^2.0.0 + jsdom: latest + vite: ^4.3.9 + vitest: workspace:* + vue: latest dependencies: - vue: - specifier: latest - version: 3.3.4 + vue: 3.3.4 devDependencies: - '@vitejs/plugin-vue': - specifier: latest - version: 4.2.3(vite@4.3.9)(vue@3.3.4) - '@vue/test-utils': - specifier: ^2.0.0 - version: 2.0.0(vue@3.3.4) - jsdom: - specifier: latest - version: 22.1.0 - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@vitejs/plugin-vue': 4.2.3_vite@4.4.3+vue@3.3.4 + '@vue/test-utils': 2.4.0_vue@3.3.4 + jsdom: 22.1.0 + vite: 4.4.3 + vitest: link:../../packages/vitest examples/vue-jsx: + specifiers: + '@vitejs/plugin-vue': latest + '@vitejs/plugin-vue-jsx': latest + '@vue/test-utils': latest + jsdom: latest + vite: ^4.3.9 + vitest: workspace:* + vue: latest devDependencies: - '@vitejs/plugin-vue': - specifier: latest - version: 4.2.3(vite@4.3.9)(vue@3.3.4) - '@vitejs/plugin-vue-jsx': - specifier: latest - version: 3.0.1(vite@4.3.9)(vue@3.3.4) - '@vue/test-utils': - specifier: latest - version: 2.3.2(vue@3.3.4) - jsdom: - specifier: latest - version: 22.1.0 - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest - vue: - specifier: latest - version: 3.3.4 + '@vitejs/plugin-vue': 4.2.3_vite@4.4.3+vue@3.3.4 + '@vitejs/plugin-vue-jsx': 3.0.1_vite@4.4.3+vue@3.3.4 + '@vue/test-utils': 2.4.0_vue@3.3.4 + jsdom: 22.1.0 + vite: 4.4.3 + vitest: link:../../packages/vitest + vue: 3.3.4 examples/vue2: - dependencies: - vue: - specifier: ^2.7.2 - version: 2.7.10 + specifiers: + '@vitejs/plugin-vue2': ^1.1.2 + '@vue/test-utils': ^1.3.0 + jsdom: latest + vite: ^4.3.9 + vitest: workspace:* + vue: ^2.7.2 + vue-template-compiler: ^2.7.2 + dependencies: + vue: 2.7.14 devDependencies: - '@vitejs/plugin-vue2': - specifier: ^1.1.2 - version: 1.1.2(vite@4.3.9)(vue@2.7.10) - '@vue/test-utils': - specifier: ^1.3.0 - version: 1.3.0(vue-template-compiler@2.7.10)(vue@2.7.10) - jsdom: - specifier: latest - version: 22.1.0 - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest - vue-template-compiler: - specifier: ^2.7.2 - version: 2.7.10 + '@vitejs/plugin-vue2': 1.1.2_vite@4.4.3+vue@2.7.14 + '@vue/test-utils': 1.3.6_rhqkolmkwunxzlyyxxsuwaiuri + jsdom: 22.1.0 + vite: 4.4.3 + vitest: link:../../packages/vitest + vue-template-compiler: 2.7.14 packages/browser: + specifiers: + '@types/estree': ^1.0.1 + '@types/ws': ^8.5.5 + '@vitest/runner': workspace:* + '@vitest/ui': workspace:* + '@vitest/ws-client': workspace:* + estree-walker: ^3.0.3 + magic-string: ^0.30.1 + modern-node-polyfills: ^0.1.3 + periscopic: ^3.1.0 + rollup: ^3.26.0 + sirv: ^2.0.3 + vitest: workspace:* dependencies: - estree-walker: - specifier: ^3.0.3 - version: 3.0.3 - magic-string: - specifier: ^0.30.1 - version: 0.30.1 - modern-node-polyfills: - specifier: ^0.1.3 - version: 0.1.3(rollup@3.26.0) - sirv: - specifier: ^2.0.3 - version: 2.0.3 + estree-walker: 3.0.3 + magic-string: 0.30.1 + modern-node-polyfills: 0.1.3_rollup@3.26.2 + sirv: 2.0.3 devDependencies: - '@types/estree': - specifier: ^1.0.1 - version: 1.0.1 - '@types/ws': - specifier: ^8.5.5 - version: 8.5.5 - '@vitest/runner': - specifier: workspace:* - version: link:../runner - '@vitest/ui': - specifier: workspace:* - version: link:../ui - '@vitest/ws-client': - specifier: workspace:* - version: link:../ws-client - periscopic: - specifier: ^3.1.0 - version: 3.1.0 - rollup: - specifier: ^3.26.0 - version: 3.26.0 - vitest: - specifier: workspace:* - version: link:../vitest + '@types/estree': 1.0.1 + '@types/ws': 8.5.5 + '@vitest/runner': link:../runner + '@vitest/ui': link:../ui + '@vitest/ws-client': link:../ws-client + periscopic: 3.1.0 + rollup: 3.26.2 + vitest: link:../vitest packages/coverage-istanbul: + specifiers: + '@types/istanbul-lib-coverage': ^2.0.4 + '@types/istanbul-lib-instrument': ^1.7.4 + '@types/istanbul-lib-report': ^3.0.0 + '@types/istanbul-lib-source-maps': ^4.0.1 + '@types/istanbul-reports': ^3.0.1 + istanbul-lib-coverage: ^3.2.0 + istanbul-lib-instrument: ^5.2.1 + istanbul-lib-report: ^3.0.0 + istanbul-lib-source-maps: ^4.0.1 + istanbul-reports: ^3.1.5 + pathe: ^1.1.1 + test-exclude: ^6.0.0 + vitest: workspace:* dependencies: - istanbul-lib-coverage: - specifier: ^3.2.0 - version: 3.2.0 - istanbul-lib-instrument: - specifier: ^6.0.0 - version: 6.0.0 - istanbul-lib-report: - specifier: ^3.0.1 - version: 3.0.1 - istanbul-lib-source-maps: - specifier: ^4.0.1 - version: 4.0.1 - istanbul-reports: - specifier: ^3.1.5 - version: 3.1.5 - test-exclude: - specifier: ^6.0.0 - version: 6.0.0 + istanbul-lib-coverage: 3.2.0 + istanbul-lib-instrument: 5.2.1 + istanbul-lib-report: 3.0.0 + istanbul-lib-source-maps: 4.0.1 + istanbul-reports: 3.1.5 + test-exclude: 6.0.0 devDependencies: - '@types/istanbul-lib-coverage': - specifier: ^2.0.4 - version: 2.0.4 - '@types/istanbul-lib-instrument': - specifier: ^1.7.4 - version: 1.7.4 - '@types/istanbul-lib-report': - specifier: ^3.0.0 - version: 3.0.0 - '@types/istanbul-lib-source-maps': - specifier: ^4.0.1 - version: 4.0.1 - '@types/istanbul-reports': - specifier: ^3.0.1 - version: 3.0.1 - pathe: - specifier: ^1.1.1 - version: 1.1.1 - vitest: - specifier: workspace:* - version: link:../vitest + '@types/istanbul-lib-coverage': 2.0.4 + '@types/istanbul-lib-instrument': 1.7.4 + '@types/istanbul-lib-report': 3.0.0 + '@types/istanbul-lib-source-maps': 4.0.1 + '@types/istanbul-reports': 3.0.1 + pathe: 1.1.1 + vitest: link:../vitest packages/coverage-v8: + specifiers: + '@ampproject/remapping': ^2.2.1 + '@bcoe/v8-coverage': ^0.2.3 + '@types/istanbul-lib-coverage': ^2.0.4 + '@types/istanbul-lib-report': ^3.0.0 + '@types/istanbul-lib-source-maps': ^4.0.1 + '@types/istanbul-reports': ^3.0.1 + istanbul-lib-coverage: ^3.2.0 + istanbul-lib-report: ^3.0.0 + istanbul-lib-source-maps: ^4.0.1 + istanbul-reports: ^3.1.5 + magic-string: ^0.30.1 + pathe: ^1.1.1 + picocolors: ^1.0.0 + std-env: ^3.3.3 + test-exclude: ^6.0.0 + v8-to-istanbul: ^9.1.0 + vite-node: workspace:* + vitest: workspace:* dependencies: - '@ampproject/remapping': - specifier: ^2.2.1 - version: 2.2.1 - '@bcoe/v8-coverage': - specifier: ^0.2.3 - version: 0.2.3 - istanbul-lib-coverage: - specifier: ^3.2.0 - version: 3.2.0 - istanbul-lib-report: - specifier: ^3.0.1 - version: 3.0.1 - istanbul-lib-source-maps: - specifier: ^4.0.1 - version: 4.0.1 - istanbul-reports: - specifier: ^3.1.5 - version: 3.1.5 - magic-string: - specifier: ^0.30.1 - version: 0.30.1 - picocolors: - specifier: ^1.0.0 - version: 1.0.0 - std-env: - specifier: ^3.3.3 - version: 3.3.3 - test-exclude: - specifier: ^6.0.0 - version: 6.0.0 - v8-to-istanbul: - specifier: ^9.1.0 - version: 9.1.0 + '@ampproject/remapping': 2.2.1 + '@bcoe/v8-coverage': 0.2.3 + istanbul-lib-coverage: 3.2.0 + istanbul-lib-report: 3.0.0 + istanbul-lib-source-maps: 4.0.1 + istanbul-reports: 3.1.5 + magic-string: 0.30.1 + picocolors: 1.0.0 + std-env: 3.3.3 + test-exclude: 6.0.0 + v8-to-istanbul: 9.1.0 devDependencies: - '@types/istanbul-lib-coverage': - specifier: ^2.0.4 - version: 2.0.4 - '@types/istanbul-lib-report': - specifier: ^3.0.0 - version: 3.0.0 - '@types/istanbul-lib-source-maps': - specifier: ^4.0.1 - version: 4.0.1 - '@types/istanbul-reports': - specifier: ^3.0.1 - version: 3.0.1 - pathe: - specifier: ^1.1.1 - version: 1.1.1 - vite-node: - specifier: workspace:* - version: link:../vite-node - vitest: - specifier: workspace:* - version: link:../vitest + '@types/istanbul-lib-coverage': 2.0.4 + '@types/istanbul-lib-report': 3.0.0 + '@types/istanbul-lib-source-maps': 4.0.1 + '@types/istanbul-reports': 3.0.1 + pathe: 1.1.1 + vite-node: link:../vite-node + vitest: link:../vitest packages/expect: - dependencies: - '@vitest/spy': - specifier: workspace:* - version: link:../spy - '@vitest/utils': - specifier: workspace:* - version: link:../utils - chai: - specifier: ^4.3.7 - version: 4.3.7 + specifiers: + '@vitest/runner': workspace:* + '@vitest/spy': workspace:* + '@vitest/utils': workspace:* + chai: ^4.3.7 + picocolors: ^1.0.0 + dependencies: + '@vitest/spy': link:../spy + '@vitest/utils': link:../utils + chai: 4.3.7 devDependencies: - '@vitest/runner': - specifier: workspace:* - version: link:../runner - picocolors: - specifier: ^1.0.0 - version: 1.0.0 + '@vitest/runner': link:../runner + picocolors: 1.0.0 packages/runner: + specifiers: + '@vitest/utils': workspace:* + p-limit: ^4.0.0 + pathe: ^1.1.1 dependencies: - '@vitest/utils': - specifier: workspace:* - version: link:../utils - p-limit: - specifier: ^4.0.0 - version: 4.0.0 - pathe: - specifier: ^1.1.1 - version: 1.1.1 + '@vitest/utils': link:../utils + p-limit: 4.0.0 + pathe: 1.1.1 packages/snapshot: + specifiers: + '@types/natural-compare': ^1.4.1 + '@vitest/utils': workspace:* + magic-string: ^0.30.1 + natural-compare: ^1.4.0 + pathe: ^1.1.1 + pretty-format: ^29.5.0 dependencies: - magic-string: - specifier: ^0.30.1 - version: 0.30.1 - pathe: - specifier: ^1.1.1 - version: 1.1.1 - pretty-format: - specifier: ^29.5.0 - version: 29.5.0 + magic-string: 0.30.1 + pathe: 1.1.1 + pretty-format: 29.6.1 devDependencies: - '@types/natural-compare': - specifier: ^1.4.1 - version: 1.4.1 - '@vitest/utils': - specifier: workspace:* - version: link:../utils - natural-compare: - specifier: ^1.4.0 - version: 1.4.0 + '@types/natural-compare': 1.4.1 + '@vitest/utils': link:../utils + natural-compare: 1.4.0 packages/spy: + specifiers: + tinyspy: ^2.1.1 dependencies: - tinyspy: - specifier: ^2.1.1 - version: 2.1.1 + tinyspy: 2.1.1 packages/ui: - dependencies: - '@vitest/utils': - specifier: workspace:* - version: link:../utils - fast-glob: - specifier: ^3.3.0 - version: 3.3.0 - fflate: - specifier: ^0.8.0 - version: 0.8.0 - flatted: - specifier: ^3.2.7 - version: 3.2.7 - pathe: - specifier: ^1.1.1 - version: 1.1.1 - picocolors: - specifier: ^1.0.0 - version: 1.0.0 - sirv: - specifier: ^2.0.3 - version: 2.0.3 - vitest: - specifier: '>=0.30.1 <1' - version: link:../vitest + specifiers: + '@faker-js/faker': ^8.0.2 + '@testing-library/cypress': ^9.0.0 + '@types/codemirror': ^5.60.8 + '@types/d3-force': ^3.0.4 + '@types/d3-selection': ^3.0.5 + '@types/ws': ^8.5.5 + '@unocss/reset': ^0.53.4 + '@vitejs/plugin-vue': ^4.2.3 + '@vitejs/plugin-vue-jsx': ^3.0.1 + '@vitest/runner': workspace:* + '@vitest/utils': workspace:* + '@vitest/ws-client': workspace:* + '@vueuse/core': ^10.2.1 + ansi-to-html: ^0.7.2 + birpc: 0.2.12 + codemirror: ^5.65.13 + codemirror-theme-vars: ^0.1.2 + cypress: ^12.16.0 + d3-graph-controller: ^2.5.2 + fast-glob: ^3.3.0 + fflate: ^0.8.0 + flatted: ^3.2.7 + floating-vue: ^2.0.0-y.0 + pathe: ^1.1.1 + picocolors: ^1.0.0 + sirv: ^2.0.3 + splitpanes: ^3.1.5 + unocss: ^0.53.4 + unplugin-auto-import: ^0.16.4 + unplugin-vue-components: ^0.25.1 + vite: ^4.3.9 + vite-plugin-pages: ^0.31.0 + vue: ^3.3.4 + vue-router: ^4.2.2 + dependencies: + '@vitest/utils': link:../utils + fast-glob: 3.3.0 + fflate: 0.8.0 + flatted: 3.2.7 + pathe: 1.1.1 + picocolors: 1.0.0 + sirv: 2.0.3 devDependencies: - '@faker-js/faker': - specifier: ^8.0.2 - version: 8.0.2 - '@testing-library/cypress': - specifier: ^9.0.0 - version: 9.0.0(cypress@12.16.0) - '@types/codemirror': - specifier: ^5.60.8 - version: 5.60.8 - '@types/d3-force': - specifier: ^3.0.4 - version: 3.0.4 - '@types/d3-selection': - specifier: ^3.0.5 - version: 3.0.5 - '@types/ws': - specifier: ^8.5.5 - version: 8.5.5 - '@unocss/reset': - specifier: ^0.53.4 - version: 0.53.4 - '@vitejs/plugin-vue': - specifier: ^4.2.3 - version: 4.2.3(vite@4.3.9)(vue@3.3.4) - '@vitejs/plugin-vue-jsx': - specifier: ^3.0.1 - version: 3.0.1(vite@4.3.9)(vue@3.3.4) - '@vitest/runner': - specifier: workspace:* - version: link:../runner - '@vitest/ws-client': - specifier: workspace:* - version: link:../ws-client - '@vueuse/core': - specifier: ^10.2.1 - version: 10.2.1(vue@3.3.4) - ansi-to-html: - specifier: ^0.7.2 - version: 0.7.2 - birpc: - specifier: 0.2.12 - version: 0.2.12 - codemirror: - specifier: ^5.65.13 - version: 5.65.13 - codemirror-theme-vars: - specifier: ^0.1.2 - version: 0.1.2 - cypress: - specifier: ^12.16.0 - version: 12.16.0 - d3-graph-controller: - specifier: ^2.5.2 - version: 2.5.2 - floating-vue: - specifier: ^2.0.0-y.0 - version: 2.0.0-y.0(vue@3.3.4) - splitpanes: - specifier: ^3.1.5 - version: 3.1.5 - unocss: - specifier: ^0.53.4 - version: 0.53.4(postcss@8.4.24)(rollup@3.26.0)(vite@4.3.9) - unplugin-auto-import: - specifier: ^0.16.4 - version: 0.16.4(@vueuse/core@10.2.1)(rollup@3.26.0) - unplugin-vue-components: - specifier: ^0.25.1 - version: 0.25.1(rollup@3.26.0)(vue@3.3.4) - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vite-plugin-pages: - specifier: ^0.31.0 - version: 0.31.0(vite@4.3.9) - vue: - specifier: ^3.3.4 - version: 3.3.4 - vue-router: - specifier: ^4.2.2 - version: 4.2.2(vue@3.3.4) + '@faker-js/faker': 8.0.2 + '@testing-library/cypress': 9.0.0_cypress@12.17.1 + '@types/codemirror': 5.60.8 + '@types/d3-force': 3.0.4 + '@types/d3-selection': 3.0.5 + '@types/ws': 8.5.5 + '@unocss/reset': 0.53.5 + '@vitejs/plugin-vue': 4.2.3_vite@4.4.3+vue@3.3.4 + '@vitejs/plugin-vue-jsx': 3.0.1_vite@4.4.3+vue@3.3.4 + '@vitest/runner': link:../runner + '@vitest/ws-client': link:../ws-client + '@vueuse/core': 10.2.1_vue@3.3.4 + ansi-to-html: 0.7.2 + birpc: 0.2.12 + codemirror: 5.65.13 + codemirror-theme-vars: 0.1.2 + cypress: 12.17.1 + d3-graph-controller: 2.5.2 + floating-vue: 2.0.0-y.0_vue@3.3.4 + splitpanes: 3.1.5 + unocss: 0.53.5_vite@4.4.3 + unplugin-auto-import: 0.16.6_@vueuse+core@10.2.1 + unplugin-vue-components: 0.25.1_vue@3.3.4 + vite: 4.4.3 + vite-plugin-pages: 0.31.0_vite@4.4.3 + vue: 3.3.4 + vue-router: 4.2.4_vue@3.3.4 packages/utils: + specifiers: + diff-sequences: ^29.4.3 + loupe: ^2.3.6 + pretty-format: ^29.5.0 dependencies: - diff-sequences: - specifier: ^29.4.3 - version: 29.4.3 - loupe: - specifier: ^2.3.6 - version: 2.3.6 - pretty-format: - specifier: ^29.5.0 - version: 29.5.0 - devDependencies: - '@jridgewell/trace-mapping': - specifier: ^0.3.18 - version: 0.3.18 + diff-sequences: 29.4.3 + loupe: 2.3.6 + pretty-format: 29.6.1 packages/vite-node: + specifiers: + '@jridgewell/trace-mapping': ^0.3.18 + '@types/debug': ^4.1.8 + cac: ^6.7.14 + debug: ^4.3.4 + mlly: ^1.4.0 + pathe: ^1.1.1 + picocolors: ^1.0.0 + rollup: ^2.79.1 + vite: ^4.3.9 dependencies: - cac: - specifier: ^6.7.14 - version: 6.7.14 - debug: - specifier: ^4.3.4 - version: 4.3.4(supports-color@8.1.1) - mlly: - specifier: ^1.4.0 - version: 1.4.0 - pathe: - specifier: ^1.1.1 - version: 1.1.1 - picocolors: - specifier: ^1.0.0 - version: 1.0.0 - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) + cac: 6.7.14 + debug: 4.3.4 + mlly: 1.4.0 + pathe: 1.1.1 + picocolors: 1.0.0 + vite: 4.4.3 devDependencies: - '@jridgewell/trace-mapping': - specifier: ^0.3.18 - version: 0.3.18 - '@types/debug': - specifier: ^4.1.8 - version: 4.1.8 - import-meta-resolve: - specifier: ^2.2.2 - version: 2.2.2 - rollup: - specifier: ^2.79.1 - version: 2.79.1 + '@jridgewell/trace-mapping': 0.3.18 + '@types/debug': 4.1.8 + rollup: 2.79.1 packages/vitest: + specifiers: + '@ampproject/remapping': ^2.2.1 + '@antfu/install-pkg': ^0.1.1 + '@edge-runtime/vm': 3.0.3 + '@jridgewell/trace-mapping': ^0.3.18 + '@sinonjs/fake-timers': ^11.0.0 + '@types/chai': ^4.3.5 + '@types/chai-subset': ^1.3.3 + '@types/diff': ^5.0.3 + '@types/estree': ^1.0.1 + '@types/istanbul-lib-coverage': ^2.0.4 + '@types/istanbul-reports': ^3.0.1 + '@types/jsdom': ^21.1.1 + '@types/micromatch': ^4.0.2 + '@types/node': '*' + '@types/prompts': ^2.4.4 + '@types/sinonjs__fake-timers': ^8.1.2 + '@vitest/expect': workspace:* + '@vitest/runner': workspace:* + '@vitest/snapshot': workspace:* + '@vitest/spy': workspace:* + '@vitest/utils': workspace:* + acorn: ^8.9.0 + acorn-walk: ^8.2.0 + birpc: 0.2.12 + cac: ^6.7.14 + chai: ^4.3.7 + chai-subset: ^1.6.0 + cli-truncate: ^3.1.0 + debug: ^4.3.4 + event-target-polyfill: ^0.0.3 + execa: ^7.1.1 + expect-type: ^0.16.0 + fast-glob: ^3.3.0 + find-up: ^6.3.0 + flatted: ^3.2.7 + get-tsconfig: ^4.6.2 + happy-dom: ^9.20.3 + jsdom: ^22.1.0 + local-pkg: ^0.4.3 + log-update: ^5.0.1 + magic-string: ^0.30.1 + micromatch: ^4.0.5 + mlly: ^1.4.0 + p-limit: ^4.0.0 + pathe: ^1.1.1 + picocolors: ^1.0.0 + pkg-types: ^1.0.3 + playwright: ^1.35.1 + pretty-format: ^29.5.0 + prompts: ^2.4.2 + safaridriver: ^0.0.5 + std-env: ^3.3.3 + strip-ansi: ^7.1.0 + strip-literal: ^1.0.1 + tinybench: ^2.5.0 + tinypool: ^0.7.0 + vite: ^4.3.9 + vite-node: workspace:* + webdriverio: ^8.11.2 + why-is-node-running: ^2.2.2 + ws: ^8.13.0 dependencies: - '@types/chai': - specifier: ^4.3.5 - version: 4.3.5 - '@types/chai-subset': - specifier: ^1.3.3 - version: 1.3.3 - '@types/node': - specifier: '*' - version: 18.7.13 - '@vitest/browser': - specifier: '*' - version: link:../browser - '@vitest/expect': - specifier: workspace:* - version: link:../expect - '@vitest/runner': - specifier: workspace:* - version: link:../runner - '@vitest/snapshot': - specifier: workspace:* - version: link:../snapshot - '@vitest/spy': - specifier: workspace:* - version: link:../spy - '@vitest/ui': - specifier: '*' - version: link:../ui - '@vitest/utils': - specifier: workspace:* - version: link:../utils - acorn: - specifier: ^8.9.0 - version: 8.9.0 - acorn-walk: - specifier: ^8.2.0 - version: 8.2.0 - cac: - specifier: ^6.7.14 - version: 6.7.14 - chai: - specifier: ^4.3.7 - version: 4.3.7 - debug: - specifier: ^4.3.4 - version: 4.3.4(supports-color@8.1.1) - local-pkg: - specifier: ^0.4.3 - version: 0.4.3 - magic-string: - specifier: ^0.30.1 - version: 0.30.1 - pathe: - specifier: ^1.1.1 - version: 1.1.1 - picocolors: - specifier: ^1.0.0 - version: 1.0.0 - std-env: - specifier: ^3.3.3 - version: 3.3.3 - strip-literal: - specifier: ^1.0.1 - version: 1.0.1 - tinybench: - specifier: ^2.5.0 - version: 2.5.0 - tinypool: - specifier: ^0.7.0 - version: 0.7.0 - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.7.13) - vite-node: - specifier: workspace:* - version: link:../vite-node - why-is-node-running: - specifier: ^2.2.2 - version: 2.2.2 + '@types/chai': 4.3.5 + '@types/chai-subset': 1.3.3 + '@types/node': 20.4.1 + '@vitest/expect': link:../expect + '@vitest/runner': link:../runner + '@vitest/snapshot': link:../snapshot + '@vitest/spy': link:../spy + '@vitest/utils': link:../utils + acorn: 8.10.0 + acorn-walk: 8.2.0 + cac: 6.7.14 + chai: 4.3.7 + debug: 4.3.4 + local-pkg: 0.4.3 + magic-string: 0.30.1 + pathe: 1.1.1 + picocolors: 1.0.0 + std-env: 3.3.3 + strip-literal: 1.0.1 + tinybench: 2.5.0 + tinypool: 0.7.0 + vite: 4.4.3_@types+node@20.4.1 + vite-node: link:../vite-node + why-is-node-running: 2.2.2 devDependencies: - '@ampproject/remapping': - specifier: ^2.2.1 - version: 2.2.1 - '@antfu/install-pkg': - specifier: ^0.1.1 - version: 0.1.1 - '@edge-runtime/vm': - specifier: 3.0.3 - version: 3.0.3 - '@sinonjs/fake-timers': - specifier: ^11.0.0 - version: 11.0.0 - '@types/diff': - specifier: ^5.0.3 - version: 5.0.3 - '@types/estree': - specifier: ^1.0.1 - version: 1.0.1 - '@types/istanbul-lib-coverage': - specifier: ^2.0.4 - version: 2.0.4 - '@types/istanbul-reports': - specifier: ^3.0.1 - version: 3.0.1 - '@types/jsdom': - specifier: ^21.1.1 - version: 21.1.1 - '@types/micromatch': - specifier: ^4.0.2 - version: 4.0.2 - '@types/prompts': - specifier: ^2.4.4 - version: 2.4.4 - '@types/sinonjs__fake-timers': - specifier: ^8.1.2 - version: 8.1.2 - birpc: - specifier: 0.2.12 - version: 0.2.12 - chai-subset: - specifier: ^1.6.0 - version: 1.6.0 - cli-truncate: - specifier: ^3.1.0 - version: 3.1.0 - event-target-polyfill: - specifier: ^0.0.3 - version: 0.0.3 - execa: - specifier: ^7.1.1 - version: 7.1.1 - expect-type: - specifier: ^0.16.0 - version: 0.16.0 - fast-glob: - specifier: ^3.3.0 - version: 3.3.0 - find-up: - specifier: ^6.3.0 - version: 6.3.0 - flatted: - specifier: ^3.2.7 - version: 3.2.7 - get-tsconfig: - specifier: ^4.6.2 - version: 4.6.2 - happy-dom: - specifier: ^9.20.3 - version: 9.20.3 - jsdom: - specifier: ^22.1.0 - version: 22.1.0 - log-update: - specifier: ^5.0.1 - version: 5.0.1 - micromatch: - specifier: ^4.0.5 - version: 4.0.5 - mlly: - specifier: ^1.4.0 - version: 1.4.0 - p-limit: - specifier: ^4.0.0 - version: 4.0.0 - pkg-types: - specifier: ^1.0.3 - version: 1.0.3 - playwright: - specifier: ^1.35.1 - version: 1.35.1 - pretty-format: - specifier: ^29.5.0 - version: 29.5.0 - prompts: - specifier: ^2.4.2 - version: 2.4.2 - safaridriver: - specifier: ^0.0.5 - version: 0.0.5 - strip-ansi: - specifier: ^7.1.0 - version: 7.1.0 - webdriverio: - specifier: ^8.11.2 - version: 8.12.1(typescript@5.1.6) - ws: - specifier: ^8.13.0 - version: 8.13.0 + '@ampproject/remapping': 2.2.1 + '@antfu/install-pkg': 0.1.1 + '@edge-runtime/vm': 3.0.3 + '@jridgewell/trace-mapping': 0.3.18 + '@sinonjs/fake-timers': 11.0.0 + '@types/diff': 5.0.3 + '@types/estree': 1.0.1 + '@types/istanbul-lib-coverage': 2.0.4 + '@types/istanbul-reports': 3.0.1 + '@types/jsdom': 21.1.1 + '@types/micromatch': 4.0.2 + '@types/prompts': 2.4.4 + '@types/sinonjs__fake-timers': 8.1.2 + birpc: 0.2.12 + chai-subset: 1.6.0 + cli-truncate: 3.1.0 + event-target-polyfill: 0.0.3 + execa: 7.1.1 + expect-type: 0.16.0 + fast-glob: 3.3.0 + find-up: 6.3.0 + flatted: 3.2.7 + get-tsconfig: 4.6.2 + happy-dom: 9.20.3 + jsdom: 22.1.0 + log-update: 5.0.1 + micromatch: 4.0.5 + mlly: 1.4.0 + p-limit: 4.0.0 + pkg-types: 1.0.3 + playwright: 1.36.0 + pretty-format: 29.6.1 + prompts: 2.4.2 + safaridriver: 0.0.5 + strip-ansi: 7.1.0 + webdriverio: 8.12.1 + ws: 8.13.0 packages/web-worker: + specifiers: + '@types/debug': ^4.1.8 + '@types/ungap__structured-clone': ^0.3.0 + '@ungap/structured-clone': ^1.2.0 + debug: ^4.3.4 dependencies: - debug: - specifier: ^4.3.4 - version: 4.3.4(supports-color@8.1.1) - vitest: - specifier: '>=0.33.0' - version: link:../vitest + debug: 4.3.4 devDependencies: - '@types/debug': - specifier: ^4.1.8 - version: 4.1.8 - '@types/ungap__structured-clone': - specifier: ^0.3.0 - version: 0.3.0 - '@ungap/structured-clone': - specifier: ^1.2.0 - version: 1.2.0 + '@types/debug': 4.1.8 + '@types/ungap__structured-clone': 0.3.0 + '@ungap/structured-clone': 1.2.0 packages/ws-client: - dependencies: - birpc: - specifier: 0.2.12 - version: 0.2.12 - flatted: - specifier: ^3.2.7 - version: 3.2.7 - ws: - specifier: ^8.13.0 - version: 8.13.0 + specifiers: + '@vitest/runner': workspace:* + birpc: 0.2.12 + flatted: ^3.2.7 + rollup: ^2.79.1 + ws: ^8.13.0 + dependencies: + birpc: 0.2.12 + flatted: 3.2.7 + ws: 8.13.0 devDependencies: - '@vitest/runner': - specifier: workspace:* - version: link:../runner - rollup: - specifier: ^2.79.1 - version: 2.79.1 + '@vitest/runner': link:../runner + rollup: 2.79.1 test/bail: + specifiers: + '@vitest/browser': workspace:* + vite: ^4.3.9 + vitest: workspace:* + webdriverio: latest devDependencies: - '@vitest/browser': - specifier: workspace:* - version: link:../../packages/browser - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest - webdriverio: - specifier: latest - version: 8.12.1(typescript@5.1.6) + '@vitest/browser': link:../../packages/browser + vite: 4.4.3 + vitest: link:../../packages/vitest + webdriverio: 8.12.1 test/base: + specifiers: + vitest: workspace:* devDependencies: - vitest: - specifier: workspace:* - version: link:../../packages/vitest + vitest: link:../../packages/vitest test/benchmark: + specifiers: + vitest: workspace:* devDependencies: - vitest: - specifier: workspace:* - version: link:../../packages/vitest + vitest: link:../../packages/vitest test/browser: + specifiers: + '@vitest/browser': workspace:* + execa: ^7.1.1 + safaridriver: ^0.0.4 + vitest: workspace:* devDependencies: - '@vitest/browser': - specifier: workspace:* - version: link:../../packages/browser - execa: - specifier: ^7.1.1 - version: 7.1.1 - safaridriver: - specifier: ^0.0.4 - version: 0.0.4 - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@vitest/browser': link:../../packages/browser + execa: 7.1.1 + safaridriver: 0.0.4 + vitest: link:../../packages/vitest test/cache: + specifiers: + vitest: workspace:* devDependencies: - vitest: - specifier: workspace:* - version: link:../../packages/vitest + vitest: link:../../packages/vitest test/cjs: + specifiers: + '@types/fs-extra': ^9.0.13 + '@types/prettier': ^2.6.1 + fs-extra: ^10.1.0 + givens: 1.3.9 + history: ^5.3.0 + lodash: ^4.17.21 + prettier: ^2.6.2 + temp-dir: ^2.0.0 + vitest: workspace:* devDependencies: - '@types/fs-extra': - specifier: ^9.0.13 - version: 9.0.13 - '@types/prettier': - specifier: ^2.6.1 - version: 2.7.0 - fs-extra: - specifier: ^10.1.0 - version: 10.1.0 - givens: - specifier: 1.3.9 - version: 1.3.9 - history: - specifier: ^5.3.0 - version: 5.3.0 - lodash: - specifier: ^4.17.21 - version: 4.17.21 - prettier: - specifier: ^2.6.2 - version: 2.7.1 - temp-dir: - specifier: ^2.0.0 - version: 2.0.0 - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@types/fs-extra': 9.0.13 + '@types/prettier': 2.7.3 + fs-extra: 10.1.0 + givens: 1.3.9 + history: 5.3.0 + lodash: 4.17.21 + prettier: 2.8.8 + temp-dir: 2.0.0 + vitest: link:../../packages/vitest test/config: + specifiers: + vite: ^4.3.9 + vitest: workspace:* devDependencies: - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest + vite: 4.4.3 + vitest: link:../../packages/vitest test/core: + specifiers: + '@vitest/expect': workspace:* + '@vitest/runner': workspace:* + '@vitest/utils': workspace:* + acorn: ^8.8.2 + tinyspy: ^1.0.2 + url: ^0.11.0 + vitest: workspace:* devDependencies: - '@vitest/expect': - specifier: workspace:* - version: link:../../packages/expect - '@vitest/runner': - specifier: workspace:* - version: link:../../packages/runner - '@vitest/utils': - specifier: workspace:* - version: link:../../packages/utils - acorn: - specifier: ^8.8.2 - version: 8.8.2 - tinyspy: - specifier: ^1.0.2 - version: 1.0.2 - url: - specifier: ^0.11.0 - version: 0.11.0 - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@vitest/expect': link:../../packages/expect + '@vitest/runner': link:../../packages/runner + '@vitest/utils': link:../../packages/utils + acorn: 8.10.0 + tinyspy: 1.1.1 + url: 0.11.1 + vitest: link:../../packages/vitest test/coverage-test: + specifiers: + '@types/istanbul-lib-coverage': ^2.0.4 + '@vitejs/plugin-vue': latest + '@vitest/browser': workspace:* + '@vitest/coverage-istanbul': workspace:* + '@vitest/coverage-v8': workspace:* + '@vue/test-utils': latest + happy-dom: latest + istanbul-lib-coverage: ^3.2.0 + vite: ^4.3.9 + vitest: workspace:* + vue: latest + webdriverio: latest devDependencies: - '@types/istanbul-lib-coverage': - specifier: ^2.0.4 - version: 2.0.4 - '@vitejs/plugin-vue': - specifier: latest - version: 4.2.3(vite@4.3.9)(vue@3.3.4) - '@vitest/browser': - specifier: workspace:* - version: link:../../packages/browser - '@vitest/coverage-istanbul': - specifier: workspace:* - version: link:../../packages/coverage-istanbul - '@vitest/coverage-v8': - specifier: workspace:* - version: link:../../packages/coverage-v8 - '@vue/test-utils': - specifier: latest - version: 2.3.2(vue@3.3.4) - happy-dom: - specifier: latest - version: 9.20.3 - istanbul-lib-coverage: - specifier: ^3.2.0 - version: 3.2.0 - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest - vue: - specifier: latest - version: 3.3.4 - webdriverio: - specifier: latest - version: 8.12.1(typescript@5.1.6) + '@types/istanbul-lib-coverage': 2.0.4 + '@vitejs/plugin-vue': 4.2.3_vite@4.4.3+vue@3.3.4 + '@vitest/browser': link:../../packages/browser + '@vitest/coverage-istanbul': link:../../packages/coverage-istanbul + '@vitest/coverage-v8': link:../../packages/coverage-v8 + '@vue/test-utils': 2.4.0_vue@3.3.4 + happy-dom: 10.1.1 + istanbul-lib-coverage: 3.2.0 + vite: 4.4.3 + vitest: link:../../packages/vitest + vue: 3.3.4 + webdriverio: 8.12.1 test/css: + specifiers: + jsdom: ^20.0.0 + vitest: workspace:* devDependencies: - jsdom: - specifier: ^20.0.0 - version: 20.0.0 - vitest: - specifier: workspace:* - version: link:../../packages/vitest + jsdom: 20.0.3 + vitest: link:../../packages/vitest test/edge-runtime: + specifiers: + '@edge-runtime/vm': 1.1.0-beta.26 + '@vitest/web-worker': workspace:* + vitest: workspace:* devDependencies: - '@edge-runtime/vm': - specifier: 1.1.0-beta.26 - version: 1.1.0-beta.26 - '@vitest/web-worker': - specifier: workspace:* - version: link:../../packages/web-worker - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@edge-runtime/vm': 1.1.0-beta.26 + '@vitest/web-worker': link:../../packages/web-worker + vitest: link:../../packages/vitest test/env-custom: + specifiers: + vitest: workspace:* + vitest-environment-custom: file:./vitest-environment-custom devDependencies: - vitest: - specifier: workspace:* - version: link:../../packages/vitest - vitest-environment-custom: - specifier: file:./vitest-environment-custom - version: file:test/env-custom/vitest-environment-custom + vitest: link:../../packages/vitest + vitest-environment-custom: file:test/env-custom/vitest-environment-custom test/env-glob: + specifiers: + vitest: workspace:* devDependencies: - vitest: - specifier: workspace:* - version: link:../../packages/vitest + vitest: link:../../packages/vitest test/env-mixed: + specifiers: + happy-dom: latest + vite: ^4.3.9 + vitest: workspace:* devDependencies: - happy-dom: - specifier: latest - version: 9.20.3 - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest + happy-dom: 10.1.1 + vite: 4.4.3 + vitest: link:../../packages/vitest test/esm: + specifiers: + css-what: 6.1.0 + tslib: 2.4.0 + vitest: workspace:* dependencies: - css-what: - specifier: 6.1.0 - version: 6.1.0 - tslib: - specifier: 2.4.0 - version: 2.4.0 + css-what: 6.1.0 + tslib: 2.4.0 devDependencies: - vitest: - specifier: workspace:* - version: link:../../packages/vitest + vitest: link:../../packages/vitest test/failing: + specifiers: + '@vitest/runner': workspace:* + vitest: workspace:* devDependencies: - '@vitest/runner': - specifier: workspace:* - version: link:../../packages/runner - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@vitest/runner': link:../../packages/runner + vitest: link:../../packages/vitest test/fails: + specifiers: + '@vitest/coverage-istanbul': workspace:* + jsdom: ^21.0.0 + vitest: workspace:* devDependencies: - '@vitest/coverage-istanbul': - specifier: workspace:* - version: link:../../packages/coverage-istanbul - jsdom: - specifier: ^21.0.0 - version: 21.0.0 - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@vitest/coverage-istanbul': link:../../packages/coverage-istanbul + jsdom: 21.1.2 + vitest: link:../../packages/vitest test/filters: + specifiers: + vite: ^4.3.9 + vitest: workspace:* devDependencies: - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest + vite: 4.4.3 + vitest: link:../../packages/vitest test/global-setup: + specifiers: + vitest: workspace:* devDependencies: - vitest: - specifier: workspace:* - version: link:../../packages/vitest + vitest: link:../../packages/vitest test/global-setup-fail: + specifiers: + vitest: workspace:* devDependencies: - vitest: - specifier: workspace:* - version: link:../../packages/vitest + vitest: link:../../packages/vitest test/import-meta: + specifiers: + vitest: workspace:* devDependencies: - vitest: - specifier: workspace:* - version: link:../../packages/vitest + vitest: link:../../packages/vitest test/mixed-pools: + specifiers: + vitest: workspace:* devDependencies: - vitest: - specifier: workspace:* - version: link:../../packages/vitest + vitest: link:../../packages/vitest test/path-resolution: + specifiers: + '@edge-runtime/vm': 1.1.0-beta.26 + '@vitest/test-path-resolution-target': workspace:* + '@vitest/web-worker': workspace:* + vitest: workspace:* devDependencies: - '@edge-runtime/vm': - specifier: 1.1.0-beta.26 - version: 1.1.0-beta.26 - '@vitest/test-path-resolution-target': - specifier: workspace:* - version: link:../path-resolution-target - '@vitest/web-worker': - specifier: workspace:* - version: link:../../packages/web-worker - vitest: - specifier: workspace:* - version: link:../../packages/vitest - - test/path-resolution-target: {} + '@edge-runtime/vm': 1.1.0-beta.26 + '@vitest/test-path-resolution-target': link:../path-resolution-target + '@vitest/web-worker': link:../../packages/web-worker + vitest: link:../../packages/vitest + + test/path-resolution-target: + specifiers: {} test/public-api: + specifiers: + '@vitest/browser': workspace:* + vitest: workspace:* devDependencies: - '@vitest/browser': - specifier: workspace:* - version: link:../../packages/browser - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@vitest/browser': link:../../packages/browser + vitest: link:../../packages/vitest test/related: + specifiers: + vitest: workspace:* devDependencies: - vitest: - specifier: workspace:* - version: link:../../packages/vitest + vitest: link:../../packages/vitest test/reporters: + specifiers: + flatted: ^3.2.7 + pkg-reporter: ./reportPkg/ + strip-ansi: ^7.0.1 + vitest: workspace:* + vitest-sonar-reporter: 0.3.3 devDependencies: - flatted: - specifier: ^3.2.7 - version: 3.2.7 - pkg-reporter: - specifier: ./reportPkg/ - version: link:reportPkg - strip-ansi: - specifier: ^7.0.1 - version: 7.0.1 - vitest: - specifier: workspace:* - version: link:../../packages/vitest - vitest-sonar-reporter: - specifier: 0.3.3 - version: 0.3.3(vitest@packages+vitest) + flatted: 3.2.7 + pkg-reporter: link:reportPkg + strip-ansi: 7.1.0 + vitest: link:../../packages/vitest + vitest-sonar-reporter: 0.3.3_vitest@packages+vitest test/resolve: + specifiers: + happy-dom: ^9.20.3 + vitest: workspace:* devDependencies: - happy-dom: - specifier: ^9.20.3 - version: 9.20.3 - vitest: - specifier: workspace:* - version: link:../../packages/vitest + happy-dom: 9.20.3 + vitest: link:../../packages/vitest test/run: + specifiers: + vite: ^4.3.9 + vitest: workspace:* devDependencies: - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest + vite: 4.4.3 + vitest: link:../../packages/vitest test/run-once: + specifiers: + vitest: workspace:* devDependencies: - vitest: - specifier: workspace:* - version: link:../../packages/vitest + vitest: link:../../packages/vitest test/setup: + specifiers: + vitest: workspace:* devDependencies: - vitest: - specifier: workspace:* - version: link:../../packages/vitest + vitest: link:../../packages/vitest test/shard: + specifiers: + vitest: workspace:* devDependencies: - vitest: - specifier: workspace:* - version: link:../../packages/vitest + vitest: link:../../packages/vitest test/single-thread: + specifiers: + vitest: workspace:* devDependencies: - vitest: - specifier: workspace:* - version: link:../../packages/vitest + vitest: link:../../packages/vitest test/snapshots: + specifiers: + vitest: workspace:* dependencies: - vitest: - specifier: workspace:* - version: link:../../packages/vitest + vitest: link:../../packages/vitest test/stacktraces: + specifiers: + vitest: workspace:* devDependencies: - vitest: - specifier: workspace:* - version: link:../../packages/vitest + vitest: link:../../packages/vitest test/test-utils: + specifiers: + execa: ^7.1.1 + strip-ansi: ^7.0.1 + vite: ^4.3.9 + vitest: workspace:* devDependencies: - execa: - specifier: ^7.1.1 - version: 7.1.1 - strip-ansi: - specifier: ^7.0.1 - version: 7.0.1 - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vite-node: - specifier: workspace:* - version: link:../../packages/vite-node - vitest: - specifier: workspace:* - version: link:../../packages/vitest + execa: 7.1.1 + strip-ansi: 7.1.0 + vite: 4.4.3 + vitest: link:../../packages/vitest test/typescript: + specifiers: + typescript: ^4.8.4 + vitest: workspace:* + vue-tsc: ^0.40.13 dependencies: - vitest: - specifier: workspace:* - version: link:../../packages/vitest + vitest: link:../../packages/vitest devDependencies: - typescript: - specifier: ^4.8.4 - version: 4.8.4 - vue-tsc: - specifier: ^0.40.13 - version: 0.40.13(typescript@4.8.4) + typescript: 4.9.5 + vue-tsc: 0.40.13_typescript@4.9.5 test/ui: + specifiers: + execa: ^6.1.0 + fs-extra: ^10.1.0 + playwright-chromium: ^1.27.0 + vitest: workspace:* devDependencies: - execa: - specifier: ^6.1.0 - version: 6.1.0 - fs-extra: - specifier: ^10.1.0 - version: 10.1.0 - playwright-chromium: - specifier: ^1.27.0 - version: 1.30.0 - vitest: - specifier: workspace:* - version: link:../../packages/vitest + execa: 6.1.0 + fs-extra: 10.1.0 + playwright-chromium: 1.36.0 + vitest: link:../../packages/vitest test/utils: + specifiers: + '@vitest/utils': workspace:* + vitest: workspace:* devDependencies: - '@vitest/utils': - specifier: workspace:* - version: link:../../packages/utils - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@vitest/utils': link:../../packages/utils + vitest: link:../../packages/vitest test/vite-config: + specifiers: + pathe: ^1.1.0 + vitest: workspace:* devDependencies: - pathe: - specifier: ^1.1.0 - version: 1.1.0 - vitest: - specifier: workspace:* - version: link:../../packages/vitest + pathe: 1.1.1 + vitest: link:../../packages/vitest test/vite-node: + specifiers: + '@types/inquirer': ^9.0.3 + execa: ^6.1.0 + inquirer: ^9.2.7 + vite-node: workspace:* + vitest: workspace:* devDependencies: - '@types/inquirer': - specifier: ^9.0.3 - version: 9.0.3 - execa: - specifier: ^6.1.0 - version: 6.1.0 - inquirer: - specifier: ^9.2.7 - version: 9.2.7 - vite-node: - specifier: workspace:* - version: link:../../packages/vite-node - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@types/inquirer': 9.0.3 + execa: 6.1.0 + inquirer: 9.2.7 + vite-node: link:../../packages/vite-node + vitest: link:../../packages/vitest test/watch: + specifiers: + '@vitest/browser': workspace:* + vite: ^4.3.9 + vitest: workspace:* + webdriverio: latest devDependencies: - '@vitest/browser': - specifier: workspace:* - version: link:../../packages/browser - vite: - specifier: ^4.3.9 - version: 4.3.9(@types/node@18.16.19) - vitest: - specifier: workspace:* - version: link:../../packages/vitest - webdriverio: - specifier: latest - version: 8.12.1(typescript@5.1.6) + '@vitest/browser': link:../../packages/browser + vite: 4.4.3 + vitest: link:../../packages/vitest + webdriverio: 8.12.1 test/web-worker: + specifiers: + '@vitest/web-worker': workspace:* + vitest: workspace:* devDependencies: - '@vitest/web-worker': - specifier: workspace:* - version: link:../../packages/web-worker - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@vitest/web-worker': link:../../packages/web-worker + vitest: link:../../packages/vitest test/workspaces: + specifiers: + '@types/istanbul-lib-coverage': ^2.0.4 + istanbul-lib-coverage: ^3.2.0 + jsdom: latest + vitest: workspace:* devDependencies: - '@types/istanbul-lib-coverage': - specifier: ^2.0.4 - version: 2.0.4 - istanbul-lib-coverage: - specifier: ^3.2.0 - version: 3.2.0 - jsdom: - specifier: latest - version: 22.1.0 - vitest: - specifier: workspace:* - version: link:../../packages/vitest + '@types/istanbul-lib-coverage': 2.0.4 + istanbul-lib-coverage: 3.2.0 + jsdom: 22.1.0 + vitest: link:../../packages/vitest packages: - /@aashutoshrathi/word-wrap@1.2.6: + /@aashutoshrathi/word-wrap/1.2.6: resolution: {integrity: sha512-1Yjs2SvM8TflER/OD3cOjhWWOZb58A2t7wpE2S9XfBYTiIl+XFhQG2bjy4Pu1I+EAlCNUzRDYDdFwFYUKvXcIA==} engines: {node: '>=0.10.0'} dev: true - /@adobe/css-tools@4.0.1: - resolution: {integrity: sha512-+u76oB43nOHrF4DDWRLWDCtci7f3QJoEBigemIdIeTi1ODqjx6Tad9NCVnPRwewWlKkVab5PlK8DCtPTyX7S8g==} + /@adobe/css-tools/4.2.0: + resolution: {integrity: sha512-E09FiIft46CmH5Qnjb0wsW54/YQd69LsxeKUOWawmws1XWvyFGURnAChH0mlr7YPFR1ofwvUQfcL0J3lMxXqPA==} dev: true - /@algolia/autocomplete-core@1.9.3(algoliasearch@4.14.2)(search-insights@2.6.0): + /@algolia/autocomplete-core/1.9.3_algoliasearch@4.18.0: resolution: {integrity: sha512-009HdfugtGCdC4JdXUbVJClA0q0zh24yyePn+KUGk3rP7j8FEe/m5Yo/z65gn6nP/cM39PxpzqKrL7A6fP6PPw==} dependencies: - '@algolia/autocomplete-plugin-algolia-insights': 1.9.3(algoliasearch@4.14.2)(search-insights@2.6.0) - '@algolia/autocomplete-shared': 1.9.3(algoliasearch@4.14.2) + '@algolia/autocomplete-plugin-algolia-insights': 1.9.3_algoliasearch@4.18.0 + '@algolia/autocomplete-shared': 1.9.3_algoliasearch@4.18.0 transitivePeerDependencies: - '@algolia/client-search' - algoliasearch - search-insights dev: true - /@algolia/autocomplete-plugin-algolia-insights@1.9.3(algoliasearch@4.14.2)(search-insights@2.6.0): + /@algolia/autocomplete-plugin-algolia-insights/1.9.3_algoliasearch@4.18.0: resolution: {integrity: sha512-a/yTUkcO/Vyy+JffmAnTWbr4/90cLzw+CC3bRbhnULr/EM0fGNvM13oQQ14f2moLMcVDyAx/leczLlAOovhSZg==} peerDependencies: search-insights: '>= 1 < 3' dependencies: - '@algolia/autocomplete-shared': 1.9.3(algoliasearch@4.14.2) - search-insights: 2.6.0 + '@algolia/autocomplete-shared': 1.9.3_algoliasearch@4.18.0 transitivePeerDependencies: - '@algolia/client-search' - algoliasearch dev: true - /@algolia/autocomplete-preset-algolia@1.9.3(algoliasearch@4.14.2): + /@algolia/autocomplete-preset-algolia/1.9.3_algoliasearch@4.18.0: resolution: {integrity: sha512-d4qlt6YmrLMYy95n5TB52wtNDr6EgAIPH81dvvvW8UmuWRgxEtY0NJiPwl/h95JtG2vmRM804M0DSwMCNZlzRA==} peerDependencies: '@algolia/client-search': '>= 4.9.1 < 6' @@ -2006,11 +1510,11 @@ packages: '@algolia/client-search': optional: true dependencies: - '@algolia/autocomplete-shared': 1.9.3(algoliasearch@4.14.2) - algoliasearch: 4.14.2 + '@algolia/autocomplete-shared': 1.9.3_algoliasearch@4.18.0 + algoliasearch: 4.18.0 dev: true - /@algolia/autocomplete-shared@1.9.3(algoliasearch@4.14.2): + /@algolia/autocomplete-shared/1.9.3_algoliasearch@4.18.0: resolution: {integrity: sha512-Wnm9E4Ye6Rl6sTTqjoymD+l8DjSTHsHboVRYrKgEt8Q7UHm9nYbqhN/i0fhUYA3OAEH7WA8x3jfpnmJm3rKvaQ==} peerDependencies: '@algolia/client-search': '>= 4.9.1 < 6' @@ -2019,131 +1523,124 @@ packages: '@algolia/client-search': optional: true dependencies: - algoliasearch: 4.14.2 + algoliasearch: 4.18.0 dev: true - /@algolia/cache-browser-local-storage@4.14.2: - resolution: {integrity: sha512-FRweBkK/ywO+GKYfAWbrepewQsPTIEirhi1BdykX9mxvBPtGNKccYAxvGdDCumU1jL4r3cayio4psfzKMejBlA==} + /@algolia/cache-browser-local-storage/4.18.0: + resolution: {integrity: sha512-rUAs49NLlO8LVLgGzM4cLkw8NJLKguQLgvFmBEe3DyzlinoqxzQMHfKZs6TSq4LZfw/z8qHvRo8NcTAAUJQLcw==} dependencies: - '@algolia/cache-common': 4.14.2 + '@algolia/cache-common': 4.18.0 dev: true - /@algolia/cache-common@4.14.2: - resolution: {integrity: sha512-SbvAlG9VqNanCErr44q6lEKD2qoK4XtFNx9Qn8FK26ePCI8I9yU7pYB+eM/cZdS9SzQCRJBbHUumVr4bsQ4uxg==} + /@algolia/cache-common/4.18.0: + resolution: {integrity: sha512-BmxsicMR4doGbeEXQu8yqiGmiyvpNvejYJtQ7rvzttEAMxOPoWEHrWyzBQw4x7LrBY9pMrgv4ZlUaF8PGzewHg==} dev: true - /@algolia/cache-in-memory@4.14.2: - resolution: {integrity: sha512-HrOukWoop9XB/VFojPv1R5SVXowgI56T9pmezd/djh2JnVN/vXswhXV51RKy4nCpqxyHt/aGFSq2qkDvj6KiuQ==} + /@algolia/cache-in-memory/4.18.0: + resolution: {integrity: sha512-evD4dA1nd5HbFdufBxLqlJoob7E2ozlqJZuV3YlirNx5Na4q1LckIuzjNYZs2ddLzuTc/Xd5O3Ibf7OwPskHxw==} dependencies: - '@algolia/cache-common': 4.14.2 + '@algolia/cache-common': 4.18.0 dev: true - /@algolia/client-account@4.14.2: - resolution: {integrity: sha512-WHtriQqGyibbb/Rx71YY43T0cXqyelEU0lB2QMBRXvD2X0iyeGl4qMxocgEIcbHyK7uqE7hKgjT8aBrHqhgc1w==} + /@algolia/client-account/4.18.0: + resolution: {integrity: sha512-XsDnlROr3+Z1yjxBJjUMfMazi1V155kVdte6496atvBgOEtwCzTs3A+qdhfsAnGUvaYfBrBkL0ThnhMIBCGcew==} dependencies: - '@algolia/client-common': 4.14.2 - '@algolia/client-search': 4.14.2 - '@algolia/transporter': 4.14.2 + '@algolia/client-common': 4.18.0 + '@algolia/client-search': 4.18.0 + '@algolia/transporter': 4.18.0 dev: true - /@algolia/client-analytics@4.14.2: - resolution: {integrity: sha512-yBvBv2mw+HX5a+aeR0dkvUbFZsiC4FKSnfqk9rrfX+QrlNOKEhCG0tJzjiOggRW4EcNqRmaTULIYvIzQVL2KYQ==} + /@algolia/client-analytics/4.18.0: + resolution: {integrity: sha512-chEUSN4ReqU7uRQ1C8kDm0EiPE+eJeAXiWcBwLhEynfNuTfawN9P93rSZktj7gmExz0C8XmkbBU19IQ05wCNrQ==} dependencies: - '@algolia/client-common': 4.14.2 - '@algolia/client-search': 4.14.2 - '@algolia/requester-common': 4.14.2 - '@algolia/transporter': 4.14.2 + '@algolia/client-common': 4.18.0 + '@algolia/client-search': 4.18.0 + '@algolia/requester-common': 4.18.0 + '@algolia/transporter': 4.18.0 dev: true - /@algolia/client-common@4.14.2: - resolution: {integrity: sha512-43o4fslNLcktgtDMVaT5XwlzsDPzlqvqesRi4MjQz2x4/Sxm7zYg5LRYFol1BIhG6EwxKvSUq8HcC/KxJu3J0Q==} + /@algolia/client-common/4.18.0: + resolution: {integrity: sha512-7N+soJFP4wn8tjTr3MSUT/U+4xVXbz4jmeRfWfVAzdAbxLAQbHa0o/POSdTvQ8/02DjCLelloZ1bb4ZFVKg7Wg==} dependencies: - '@algolia/requester-common': 4.14.2 - '@algolia/transporter': 4.14.2 + '@algolia/requester-common': 4.18.0 + '@algolia/transporter': 4.18.0 dev: true - /@algolia/client-personalization@4.14.2: - resolution: {integrity: sha512-ACCoLi0cL8CBZ1W/2juehSltrw2iqsQBnfiu/Rbl9W2yE6o2ZUb97+sqN/jBqYNQBS+o0ekTMKNkQjHHAcEXNw==} + /@algolia/client-personalization/4.18.0: + resolution: {integrity: sha512-+PeCjODbxtamHcPl+couXMeHEefpUpr7IHftj4Y4Nia1hj8gGq4VlIcqhToAw8YjLeCTfOR7r7xtj3pJcYdP8A==} dependencies: - '@algolia/client-common': 4.14.2 - '@algolia/requester-common': 4.14.2 - '@algolia/transporter': 4.14.2 + '@algolia/client-common': 4.18.0 + '@algolia/requester-common': 4.18.0 + '@algolia/transporter': 4.18.0 dev: true - /@algolia/client-search@4.14.2: - resolution: {integrity: sha512-L5zScdOmcZ6NGiVbLKTvP02UbxZ0njd5Vq9nJAmPFtjffUSOGEp11BmD2oMJ5QvARgx2XbX4KzTTNS5ECYIMWw==} + /@algolia/client-search/4.18.0: + resolution: {integrity: sha512-F9xzQXTjm6UuZtnsLIew6KSraXQ0AzS/Ee+OD+mQbtcA/K1sg89tqb8TkwjtiYZ0oij13u3EapB3gPZwm+1Y6g==} dependencies: - '@algolia/client-common': 4.14.2 - '@algolia/requester-common': 4.14.2 - '@algolia/transporter': 4.14.2 + '@algolia/client-common': 4.18.0 + '@algolia/requester-common': 4.18.0 + '@algolia/transporter': 4.18.0 dev: true - /@algolia/logger-common@4.14.2: - resolution: {integrity: sha512-/JGlYvdV++IcMHBnVFsqEisTiOeEr6cUJtpjz8zc0A9c31JrtLm318Njc72p14Pnkw3A/5lHHh+QxpJ6WFTmsA==} + /@algolia/logger-common/4.18.0: + resolution: {integrity: sha512-46etYgSlkoKepkMSyaoriSn2JDgcrpc/nkOgou/lm0y17GuMl9oYZxwKKTSviLKI5Irk9nSKGwnBTQYwXOYdRg==} dev: true - /@algolia/logger-console@4.14.2: - resolution: {integrity: sha512-8S2PlpdshbkwlLCSAB5f8c91xyc84VM9Ar9EdfE9UmX+NrKNYnWR1maXXVDQQoto07G1Ol/tYFnFVhUZq0xV/g==} + /@algolia/logger-console/4.18.0: + resolution: {integrity: sha512-3P3VUYMl9CyJbi/UU1uUNlf6Z8N2ltW3Oqhq/nR7vH0CjWv32YROq3iGWGxB2xt3aXobdUPXs6P0tHSKRmNA6g==} dependencies: - '@algolia/logger-common': 4.14.2 + '@algolia/logger-common': 4.18.0 dev: true - /@algolia/requester-browser-xhr@4.14.2: - resolution: {integrity: sha512-CEh//xYz/WfxHFh7pcMjQNWgpl4wFB85lUMRyVwaDPibNzQRVcV33YS+63fShFWc2+42YEipFGH2iPzlpszmDw==} + /@algolia/requester-browser-xhr/4.18.0: + resolution: {integrity: sha512-/AcWHOBub2U4TE/bPi4Gz1XfuLK6/7dj4HJG+Z2SfQoS1RjNLshZclU3OoKIkFp8D2NC7+BNsPvr9cPLyW8nyQ==} dependencies: - '@algolia/requester-common': 4.14.2 + '@algolia/requester-common': 4.18.0 dev: true - /@algolia/requester-common@4.14.2: - resolution: {integrity: sha512-73YQsBOKa5fvVV3My7iZHu1sUqmjjfs9TteFWwPwDmnad7T0VTCopttcsM3OjLxZFtBnX61Xxl2T2gmG2O4ehg==} + /@algolia/requester-common/4.18.0: + resolution: {integrity: sha512-xlT8R1qYNRBCi1IYLsx7uhftzdfsLPDGudeQs+xvYB4sQ3ya7+ppolB/8m/a4F2gCkEO6oxpp5AGemM7kD27jA==} dev: true - /@algolia/requester-node-http@4.14.2: - resolution: {integrity: sha512-oDbb02kd1o5GTEld4pETlPZLY0e+gOSWjWMJHWTgDXbv9rm/o2cF7japO6Vj1ENnrqWvLBmW1OzV9g6FUFhFXg==} + /@algolia/requester-node-http/4.18.0: + resolution: {integrity: sha512-TGfwj9aeTVgOUhn5XrqBhwUhUUDnGIKlI0kCBMdR58XfXcfdwomka+CPIgThRbfYw04oQr31A6/95ZH2QVJ9UQ==} dependencies: - '@algolia/requester-common': 4.14.2 + '@algolia/requester-common': 4.18.0 dev: true - /@algolia/transporter@4.14.2: - resolution: {integrity: sha512-t89dfQb2T9MFQHidjHcfhh6iGMNwvuKUvojAj+JsrHAGbuSy7yE4BylhLX6R0Q1xYRoC4Vvv+O5qIw/LdnQfsQ==} + /@algolia/transporter/4.18.0: + resolution: {integrity: sha512-xbw3YRUGtXQNG1geYFEDDuFLZt4Z8YNKbamHPkzr3rWc6qp4/BqEeXcI2u/P/oMq2yxtXgMxrCxOPA8lyIe5jw==} dependencies: - '@algolia/cache-common': 4.14.2 - '@algolia/logger-common': 4.14.2 - '@algolia/requester-common': 4.14.2 + '@algolia/cache-common': 4.18.0 + '@algolia/logger-common': 4.18.0 + '@algolia/requester-common': 4.18.0 dev: true - /@ampproject/remapping@2.2.0: - resolution: {integrity: sha512-qRmjj8nj9qmLTQXXmaR1cck3UXSRMPrbsLJAasZpF+t3riI71BXed5ebIOYwQntykeZuhjsdweEc9BxH5Jc26w==} + /@ampproject/remapping/2.2.1: + resolution: {integrity: sha512-lFMjJTrFL3j7L9yBxwYfCq2k6qqwHyzuUl/XBnif78PWTJYyL/dfowQHWE3sp6U6ZzqWiiIZnpTMO96zhkjwtg==} engines: {node: '>=6.0.0'} dependencies: - '@jridgewell/gen-mapping': 0.1.1 + '@jridgewell/gen-mapping': 0.3.3 '@jridgewell/trace-mapping': 0.3.18 - /@ampproject/remapping@2.2.1: - resolution: {integrity: sha512-lFMjJTrFL3j7L9yBxwYfCq2k6qqwHyzuUl/XBnif78PWTJYyL/dfowQHWE3sp6U6ZzqWiiIZnpTMO96zhkjwtg==} - engines: {node: '>=6.0.0'} - dependencies: - '@jridgewell/gen-mapping': 0.3.2 - '@jridgewell/trace-mapping': 0.3.18 - - /@antfu/eslint-config-basic@0.39.6(@typescript-eslint/eslint-plugin@5.60.0)(@typescript-eslint/parser@5.60.0)(eslint@8.44.0)(typescript@5.1.6): - resolution: {integrity: sha512-vFy/qk6sCstCJmgj01tVtuC+pZ5PseJkuZueD2mtzWwFLewOMeeDn1UbyOWQEiLtmW7o6aqhikgp3VOHgxzFxw==} + /@antfu/eslint-config-basic/0.39.7_hoiolsckdkz7sxrkgp2zqjnw7y: + resolution: {integrity: sha512-R7usUebEr+T5EcZ8sMy2/naNU5etpXtzC34wHCEBETlmYVGQpkYcpSztDy67T3B3Ywj95VsgGLDjW77fANW/LQ==} peerDependencies: eslint: '>=7.4.0' dependencies: eslint: 8.44.0 - eslint-plugin-antfu: 0.39.6(eslint@8.44.0)(typescript@5.1.6) - eslint-plugin-eslint-comments: 3.2.0(eslint@8.44.0) + eslint-plugin-antfu: 0.39.7_iqf7tbmerllfqanu4l3d6aqdn4 + eslint-plugin-eslint-comments: 3.2.0_eslint@8.44.0 eslint-plugin-html: 7.1.0 - eslint-plugin-import: /eslint-plugin-i@2.27.5-3(@typescript-eslint/parser@5.60.0)(eslint@8.44.0) - eslint-plugin-jsonc: 2.9.0(eslint@8.44.0) - eslint-plugin-markdown: 3.0.0(eslint@8.44.0) - eslint-plugin-n: 16.0.0(eslint@8.44.0) + eslint-plugin-import: /eslint-plugin-i/2.27.5-3_owyyv4y74swggqrdagvp7hd7n4 + eslint-plugin-jsonc: 2.9.0_eslint@8.44.0 + eslint-plugin-markdown: 3.0.0_eslint@8.44.0 + eslint-plugin-n: 16.0.1_eslint@8.44.0 eslint-plugin-no-only-tests: 3.1.0 - eslint-plugin-promise: 6.1.1(eslint@8.44.0) - eslint-plugin-unicorn: 47.0.0(eslint@8.44.0) - eslint-plugin-unused-imports: 2.0.0(@typescript-eslint/eslint-plugin@5.60.0)(eslint@8.44.0) - eslint-plugin-yml: 1.8.0(eslint@8.44.0) + eslint-plugin-promise: 6.1.1_eslint@8.44.0 + eslint-plugin-unicorn: 47.0.0_eslint@8.44.0 + eslint-plugin-unused-imports: 2.0.0_fjgzgq23hjlrbj45h2rdrfisla + eslint-plugin-yml: 1.8.0_eslint@8.44.0 jsonc-eslint-parser: 2.3.0 yaml-eslint-parser: 1.2.2 transitivePeerDependencies: @@ -2155,17 +1652,17 @@ packages: - typescript dev: true - /@antfu/eslint-config-ts@0.39.6(eslint@8.44.0)(typescript@5.1.6): - resolution: {integrity: sha512-ri1WebgsBSfEFftMgRAmM4AxqN37sP4Ft+OdaXJ9AHSh1EvJCzGOgVARcEEDvSVDFRoRuTTg99dMXwfwsYdiPA==} + /@antfu/eslint-config-ts/0.39.7_iqf7tbmerllfqanu4l3d6aqdn4: + resolution: {integrity: sha512-EaeR9VeCGFMNUr4mf8DBJa82UfZNM9o2fc27sVzX3ORDEjf6wtsc2YVVBlKlhAoZBNTj2qtX2DeCNC38N/j+Lg==} peerDependencies: eslint: '>=7.4.0' typescript: '>=3.9' dependencies: - '@antfu/eslint-config-basic': 0.39.6(@typescript-eslint/eslint-plugin@5.60.0)(@typescript-eslint/parser@5.60.0)(eslint@8.44.0)(typescript@5.1.6) - '@typescript-eslint/eslint-plugin': 5.60.0(@typescript-eslint/parser@5.60.0)(eslint@8.44.0)(typescript@5.1.6) - '@typescript-eslint/parser': 5.60.0(eslint@8.44.0)(typescript@5.1.6) + '@antfu/eslint-config-basic': 0.39.7_hoiolsckdkz7sxrkgp2zqjnw7y + '@typescript-eslint/eslint-plugin': 5.62.0_l3h7p4bxv72z3fumgmc6kvfciu + '@typescript-eslint/parser': 5.62.0_iqf7tbmerllfqanu4l3d6aqdn4 eslint: 8.44.0 - eslint-plugin-jest: 27.2.1(@typescript-eslint/eslint-plugin@5.60.0)(eslint@8.44.0)(typescript@5.1.6) + eslint-plugin-jest: 27.2.2_qtrczavcy63fstz24hwardykcu typescript: 5.1.6 transitivePeerDependencies: - eslint-import-resolver-typescript @@ -2174,15 +1671,15 @@ packages: - supports-color dev: true - /@antfu/eslint-config-vue@0.39.6(@typescript-eslint/eslint-plugin@5.60.0)(@typescript-eslint/parser@5.60.0)(eslint@8.44.0)(typescript@5.1.6): - resolution: {integrity: sha512-+GOo5No7IWnjMK2fZ9crhdJrsUa4C13aiT28hlZpWLg8Chd9QqyqBN8O4bBYnGhifoDnBWHVyDMp2rlAiNLI/g==} + /@antfu/eslint-config-vue/0.39.7_hoiolsckdkz7sxrkgp2zqjnw7y: + resolution: {integrity: sha512-YAhU+88cu9c/TFY4VIs4MhOzaxK7ZPiT7DVs+4PpQvTEOOV17dZipp7HGJHfBK/5MtscCm7FGWuo5TamN5gydw==} peerDependencies: eslint: '>=7.4.0' dependencies: - '@antfu/eslint-config-basic': 0.39.6(@typescript-eslint/eslint-plugin@5.60.0)(@typescript-eslint/parser@5.60.0)(eslint@8.44.0)(typescript@5.1.6) - '@antfu/eslint-config-ts': 0.39.6(eslint@8.44.0)(typescript@5.1.6) + '@antfu/eslint-config-basic': 0.39.7_hoiolsckdkz7sxrkgp2zqjnw7y + '@antfu/eslint-config-ts': 0.39.7_iqf7tbmerllfqanu4l3d6aqdn4 eslint: 8.44.0 - eslint-plugin-vue: 9.15.0(eslint@8.44.0) + eslint-plugin-vue: 9.15.1_eslint@8.44.0 local-pkg: 0.4.3 transitivePeerDependencies: - '@typescript-eslint/eslint-plugin' @@ -2194,24 +1691,24 @@ packages: - typescript dev: true - /@antfu/eslint-config@0.39.6(eslint@8.44.0)(typescript@5.1.6): - resolution: {integrity: sha512-RlSWVhqSF7L5w8+ZUB8iR2GF+pZjyE0GstzaecR5xFnv8BJOXeNW1f594ODbznkytaLixJZd/eJZacRK/yfWrA==} + /@antfu/eslint-config/0.39.7_iqf7tbmerllfqanu4l3d6aqdn4: + resolution: {integrity: sha512-xztW6zdjHz+yIaw25kn97e3s6vGtAI43YF6wdooioUJPmOXsjSYY9lRh2k3RaHzQALKbNRUjZO8KdjOOLasg1g==} peerDependencies: eslint: '>=7.4.0' dependencies: - '@antfu/eslint-config-vue': 0.39.6(@typescript-eslint/eslint-plugin@5.60.0)(@typescript-eslint/parser@5.60.0)(eslint@8.44.0)(typescript@5.1.6) - '@typescript-eslint/eslint-plugin': 5.60.0(@typescript-eslint/parser@5.60.0)(eslint@8.44.0)(typescript@5.1.6) - '@typescript-eslint/parser': 5.60.0(eslint@8.44.0)(typescript@5.1.6) + '@antfu/eslint-config-vue': 0.39.7_hoiolsckdkz7sxrkgp2zqjnw7y + '@typescript-eslint/eslint-plugin': 5.62.0_l3h7p4bxv72z3fumgmc6kvfciu + '@typescript-eslint/parser': 5.62.0_iqf7tbmerllfqanu4l3d6aqdn4 eslint: 8.44.0 - eslint-plugin-eslint-comments: 3.2.0(eslint@8.44.0) + eslint-plugin-eslint-comments: 3.2.0_eslint@8.44.0 eslint-plugin-html: 7.1.0 - eslint-plugin-import: /eslint-plugin-i@2.27.5-3(@typescript-eslint/parser@5.60.0)(eslint@8.44.0) - eslint-plugin-jsonc: 2.9.0(eslint@8.44.0) - eslint-plugin-n: 16.0.0(eslint@8.44.0) - eslint-plugin-promise: 6.1.1(eslint@8.44.0) - eslint-plugin-unicorn: 47.0.0(eslint@8.44.0) - eslint-plugin-vue: 9.15.0(eslint@8.44.0) - eslint-plugin-yml: 1.8.0(eslint@8.44.0) + eslint-plugin-import: /eslint-plugin-i/2.27.5-3_owyyv4y74swggqrdagvp7hd7n4 + eslint-plugin-jsonc: 2.9.0_eslint@8.44.0 + eslint-plugin-n: 16.0.1_eslint@8.44.0 + eslint-plugin-promise: 6.1.1_eslint@8.44.0 + eslint-plugin-unicorn: 47.0.0_eslint@8.44.0 + eslint-plugin-vue: 9.15.1_eslint@8.44.0 + eslint-plugin-yml: 1.8.0_eslint@8.44.0 jsonc-eslint-parser: 2.3.0 yaml-eslint-parser: 1.2.2 transitivePeerDependencies: @@ -2222,583 +1719,377 @@ packages: - typescript dev: true - /@antfu/install-pkg@0.1.1: + /@antfu/install-pkg/0.1.1: resolution: {integrity: sha512-LyB/8+bSfa0DFGC06zpCEfs89/XoWZwws5ygEa5D+Xsm3OfI+aXQ86VgVG7Acyef+rSZ5HE7J8rrxzrQeM3PjQ==} dependencies: execa: 5.1.1 find-up: 5.0.0 dev: true - /@antfu/ni@0.21.4: + /@antfu/ni/0.21.4: resolution: {integrity: sha512-O0Uv9LbLDSoEg26fnMDdDRiPwFJnQSoD4WnrflDwKCJm8Cx/0mV4cGxwBLXan5mGIrpK4Dd7vizf4rQm0QCEAA==} hasBin: true dev: true - /@antfu/utils@0.7.4: - resolution: {integrity: sha512-qe8Nmh9rYI/HIspLSTwtbMFPj6dISG6+dJnOguTlPNXtCvS2uezdxscVBb7/3DrmNbQK49TDqpkSQ1chbRGdpQ==} + /@antfu/utils/0.7.5: + resolution: {integrity: sha512-dlR6LdS+0SzOAPx/TPRhnoi7hE251OVeT2Snw0RguNbBSbjUHdWr0l3vcUUDg26rEysT89kCbtw1lVorBXLLCg==} dev: true - /@apideck/better-ajv-errors@0.3.6(ajv@8.11.0): + /@apideck/better-ajv-errors/0.3.6_ajv@8.12.0: resolution: {integrity: sha512-P+ZygBLZtkp0qqOAJJVX4oX/sFo5JR3eBWwwuqHHhK0GIgQOKWrAfiAaWX0aArHkRWHMuggFEgAZNxVPwPZYaA==} engines: {node: '>=10'} peerDependencies: ajv: '>=8' dependencies: - ajv: 8.11.0 + ajv: 8.12.0 json-schema: 0.4.0 jsonpointer: 5.0.1 leven: 3.1.0 dev: true - /@apollo/client@3.6.9(graphql@16.6.0)(react@17.0.2): - resolution: {integrity: sha512-Y1yu8qa2YeaCUBVuw08x8NHenFi0sw2I3KCu7Kw9mDSu86HmmtHJkCAifKVrN2iPgDTW/BbP3EpSV8/EQCcxZA==} + /@apollo/client/3.7.17_sfoxds7t5ydpegc3knd667wn6m: + resolution: {integrity: sha512-0EErSHEtKPNl5wgWikHJbKFAzJ/k11O0WO2QyqZSHpdxdAnw7UWHY4YiLbHCFG7lhrD+NTQ3Z/H9Jn4rcikoJA==} peerDependencies: graphql: ^14.0.0 || ^15.0.0 || ^16.0.0 graphql-ws: ^5.5.5 react: ^16.8.0 || ^17.0.0 || ^18.0.0 + react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 subscriptions-transport-ws: ^0.9.0 || ^0.11.0 peerDependenciesMeta: graphql-ws: optional: true react: optional: true + react-dom: + optional: true subscriptions-transport-ws: optional: true dependencies: - '@graphql-typed-document-node/core': 3.1.1(graphql@16.6.0) - '@wry/context': 0.6.1 - '@wry/equality': 0.5.3 - '@wry/trie': 0.3.2 - graphql: 16.6.0 - graphql-tag: 2.12.6(graphql@16.6.0) + '@graphql-typed-document-node/core': 3.2.0 + '@wry/context': 0.7.3 + '@wry/equality': 0.5.6 + '@wry/trie': 0.4.3 + graphql-tag: 2.12.6 hoist-non-react-statics: 3.3.2 - optimism: 0.16.1 + optimism: 0.16.2 prop-types: 15.8.1 react: 17.0.2 + react-dom: 17.0.2_react@17.0.2 + response-iterator: 0.2.6 symbol-observable: 4.0.0 ts-invariant: 0.10.3 - tslib: 2.4.0 + tslib: 2.6.0 zen-observable-ts: 1.2.5 dev: false - /@babel/code-frame@7.18.6: - resolution: {integrity: sha512-TDCmlK5eOvH+eH7cdAFlNXeVJqWIQ7gW9tY1GJIpUtFb6CmjVyq2VM3u71bOyR8CRihcCgMUYoDNyLXao3+70Q==} - engines: {node: '>=6.9.0'} - dependencies: - '@babel/highlight': 7.22.5 - - /@babel/code-frame@7.22.5: + /@babel/code-frame/7.22.5: resolution: {integrity: sha512-Xmwn266vad+6DAqEB2A6V/CcZVp62BbwVmcOJc2RPuwih1kw02TjQvWVWlcKGbBPd+8/0V5DEkOcizRGYsspYQ==} engines: {node: '>=6.9.0'} dependencies: '@babel/highlight': 7.22.5 - /@babel/compat-data@7.22.5: - resolution: {integrity: sha512-4Jc/YuIaYqKnDDz892kPIledykKg12Aw1PYX5i/TY28anJtacvM1Rrr8wbieB9GfEJwlzqT0hUEao0CxEebiDA==} + /@babel/compat-data/7.22.6: + resolution: {integrity: sha512-29tfsWTq2Ftu7MXmimyC0C5FDZv5DYxOZkh3XD3+QW4V/BYuv/LyEsjj3c0hqedEaDt6DBfDvexMKU8YevdqFg==} engines: {node: '>=6.9.0'} - /@babel/core@7.12.9: + /@babel/core/7.12.9: resolution: {integrity: sha512-gTXYh3M5wb7FRXQy+FErKFAv90BnlOuNn1QkCK2lREoPAjrQCO49+HVSrFoe5uakFAF5eenS75KbO2vQiLrTMQ==} engines: {node: '>=6.9.0'} dependencies: '@babel/code-frame': 7.22.5 - '@babel/generator': 7.22.5 + '@babel/generator': 7.22.7 '@babel/helper-module-transforms': 7.22.5 - '@babel/helpers': 7.22.5 - '@babel/parser': 7.22.5 + '@babel/helpers': 7.22.6 + '@babel/parser': 7.22.7 '@babel/template': 7.22.5 - '@babel/traverse': 7.22.5 + '@babel/traverse': 7.22.8 '@babel/types': 7.22.5 convert-source-map: 1.9.0 - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 gensync: 1.0.0-beta.2 json5: 2.2.3 lodash: 4.17.21 resolve: 1.22.2 - semver: 5.7.1 + semver: 5.7.2 source-map: 0.5.7 transitivePeerDependencies: - supports-color dev: true - /@babel/core@7.18.13: - resolution: {integrity: sha512-ZisbOvRRusFktksHSG6pjj1CSvkPkcZq/KHD45LAkVP/oiHJkNBZWfpvlLmX8OtHDG8IuzsFlVRWo08w7Qxn0A==} - engines: {node: '>=6.9.0'} - dependencies: - '@ampproject/remapping': 2.2.0 - '@babel/code-frame': 7.18.6 - '@babel/generator': 7.18.13 - '@babel/helper-compilation-targets': 7.18.9(@babel/core@7.18.13) - '@babel/helper-module-transforms': 7.18.9 - '@babel/helpers': 7.18.9 - '@babel/parser': 7.18.13 - '@babel/template': 7.18.10 - '@babel/traverse': 7.18.13 - '@babel/types': 7.18.13 - convert-source-map: 1.8.0 - debug: 4.3.4(supports-color@8.1.1) - gensync: 1.0.0-beta.2 - json5: 2.2.1 - semver: 6.3.0 - transitivePeerDependencies: - - supports-color - - /@babel/core@7.20.5: - resolution: {integrity: sha512-UdOWmk4pNWTm/4DlPUl/Pt4Gz4rcEMb7CY0Y3eJl5Yz1vI8ZJGmHWaVE55LoxRjdpx0z259GE9U5STA9atUinQ==} - engines: {node: '>=6.9.0'} - dependencies: - '@ampproject/remapping': 2.2.1 - '@babel/code-frame': 7.22.5 - '@babel/generator': 7.22.5 - '@babel/helper-compilation-targets': 7.22.5(@babel/core@7.20.5) - '@babel/helper-module-transforms': 7.22.5 - '@babel/helpers': 7.22.5 - '@babel/parser': 7.22.5 - '@babel/template': 7.22.5 - '@babel/traverse': 7.22.5 - '@babel/types': 7.22.5 - convert-source-map: 1.9.0 - debug: 4.3.4(supports-color@8.1.1) - gensync: 1.0.0-beta.2 - json5: 2.2.3 - semver: 6.3.0 - transitivePeerDependencies: - - supports-color - dev: true - - /@babel/core@7.22.5: - resolution: {integrity: sha512-SBuTAjg91A3eKOvD+bPEz3LlhHZRNu1nFOVts9lzDJTXshHTjII0BAtDS3Y2DAkdZdDKWVZGVwkDfc4Clxn1dg==} + /@babel/core/7.22.8: + resolution: {integrity: sha512-75+KxFB4CZqYRXjx4NlR4J7yGvKumBuZTmV4NV6v09dVXXkuYVYLT68N6HCzLvfJ+fWCxQsntNzKwwIXL4bHnw==} engines: {node: '>=6.9.0'} dependencies: '@ampproject/remapping': 2.2.1 '@babel/code-frame': 7.22.5 - '@babel/generator': 7.22.5 - '@babel/helper-compilation-targets': 7.22.5(@babel/core@7.22.5) + '@babel/generator': 7.22.7 + '@babel/helper-compilation-targets': 7.22.6_@babel+core@7.22.8 '@babel/helper-module-transforms': 7.22.5 - '@babel/helpers': 7.22.5 - '@babel/parser': 7.22.5 + '@babel/helpers': 7.22.6 + '@babel/parser': 7.22.7 '@babel/template': 7.22.5 - '@babel/traverse': 7.22.5 + '@babel/traverse': 7.22.8 '@babel/types': 7.22.5 + '@nicolo-ribaudo/semver-v6': 6.3.3 convert-source-map: 1.9.0 - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 gensync: 1.0.0-beta.2 json5: 2.2.3 - semver: 6.3.0 transitivePeerDependencies: - supports-color - /@babel/generator@7.18.13: - resolution: {integrity: sha512-CkPg8ySSPuHTYPJYo7IRALdqyjM9HCbt/3uOBEFbzyGVP6Mn8bwFPB0jX6982JVNBlYzM1nnPkfjuXSOPtQeEQ==} - engines: {node: '>=6.9.0'} - dependencies: - '@babel/types': 7.22.5 - '@jridgewell/gen-mapping': 0.3.2 - jsesc: 2.5.2 - - /@babel/generator@7.22.5: - resolution: {integrity: sha512-+lcUbnTRhd0jOewtFSedLyiPsD5tswKkbgcezOqqWFUVNEwoUTlpPOBmvhG7OXWLR4jMdv0czPGH5XbflnD1EA==} + /@babel/generator/7.22.7: + resolution: {integrity: sha512-p+jPjMG+SI8yvIaxGgeW24u7q9+5+TGpZh8/CuB7RhBKd7RCy8FayNEFNNKrNK/eUcY/4ExQqLmyrvBXKsIcwQ==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 - '@jridgewell/gen-mapping': 0.3.2 + '@jridgewell/gen-mapping': 0.3.3 '@jridgewell/trace-mapping': 0.3.18 jsesc: 2.5.2 - /@babel/helper-annotate-as-pure@7.18.6: - resolution: {integrity: sha512-duORpUiYrEpzKIop6iNbjnwKLAKnJ47csTyRACyEmWj0QdUrm5aqNJGHSSEQSUAvNW0ojX0dOmK9dZduvkfeXA==} + /@babel/helper-annotate-as-pure/7.22.5: + resolution: {integrity: sha512-LvBTxu8bQSQkcyKOU+a1btnNFQ1dMAd0R6PyW3arXes06F6QLWLIrd681bxRPIXlrMGR3XYnW9JyML7dP3qgxg==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 dev: true - /@babel/helper-builder-binary-assignment-operator-visitor@7.18.9: - resolution: {integrity: sha512-yFQ0YCHoIqarl8BCRwBL8ulYUaZpz3bNsA7oFepAzee+8/+ImtADXNOmO5vJvsPff3qi+hvpkY/NYBTrBQgdNw==} + /@babel/helper-builder-binary-assignment-operator-visitor/7.22.5: + resolution: {integrity: sha512-m1EP3lVOPptR+2DwD125gziZNcmoNSHGmJROKoy87loWUQyJaVXDgpmruWqDARZSmtYQ+Dl25okU8+qhVzuykw==} engines: {node: '>=6.9.0'} dependencies: - '@babel/helper-explode-assignable-expression': 7.18.6 '@babel/types': 7.22.5 dev: true - /@babel/helper-compilation-targets@7.18.9(@babel/core@7.18.13): - resolution: {integrity: sha512-tzLCyVmqUiFlcFoAPLA/gL9TeYrF61VLNtb+hvkuVaB5SUjW7jcfrglBIX1vUIoT7CLP3bBlIMeyEsIl2eFQNg==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0 - dependencies: - '@babel/compat-data': 7.22.5 - '@babel/core': 7.18.13 - '@babel/helper-validator-option': 7.22.5 - browserslist: 4.21.3 - semver: 6.3.0 - - /@babel/helper-compilation-targets@7.22.5(@babel/core@7.18.13): - resolution: {integrity: sha512-Ji+ywpHeuqxB8WDxraCiqR0xfhYjiDE/e6k7FuIaANnoOFxAHskHChz4vA1mJC9Lbm01s1PVAGhQY4FUKSkGZw==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0 - dependencies: - '@babel/compat-data': 7.22.5 - '@babel/core': 7.18.13 - '@babel/helper-validator-option': 7.22.5 - browserslist: 4.21.3 - lru-cache: 5.1.1 - semver: 6.3.0 - dev: true - - /@babel/helper-compilation-targets@7.22.5(@babel/core@7.20.5): - resolution: {integrity: sha512-Ji+ywpHeuqxB8WDxraCiqR0xfhYjiDE/e6k7FuIaANnoOFxAHskHChz4vA1mJC9Lbm01s1PVAGhQY4FUKSkGZw==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0 - dependencies: - '@babel/compat-data': 7.22.5 - '@babel/core': 7.20.5 - '@babel/helper-validator-option': 7.22.5 - browserslist: 4.21.3 - lru-cache: 5.1.1 - semver: 6.3.0 - dev: true - - /@babel/helper-compilation-targets@7.22.5(@babel/core@7.22.5): - resolution: {integrity: sha512-Ji+ywpHeuqxB8WDxraCiqR0xfhYjiDE/e6k7FuIaANnoOFxAHskHChz4vA1mJC9Lbm01s1PVAGhQY4FUKSkGZw==} + /@babel/helper-compilation-targets/7.22.6_@babel+core@7.22.8: + resolution: {integrity: sha512-534sYEqWD9VfUm3IPn2SLcH4Q3P86XL+QvqdC7ZsFrzyyPF3T4XGiVghF6PTYNdWg6pXuoqXxNQAhbYeEInTzA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0 dependencies: - '@babel/compat-data': 7.22.5 - '@babel/core': 7.22.5 + '@babel/compat-data': 7.22.6 + '@babel/core': 7.22.8 '@babel/helper-validator-option': 7.22.5 - browserslist: 4.21.3 + '@nicolo-ribaudo/semver-v6': 6.3.3 + browserslist: 4.21.9 lru-cache: 5.1.1 - semver: 6.3.0 - - /@babel/helper-create-class-features-plugin@7.21.0(@babel/core@7.18.13): - resolution: {integrity: sha512-Q8wNiMIdwsv5la5SPxNYzzkPnjgC0Sy0i7jLkVOCdllu/xcVNkr3TeZzbHBJrj+XXRqzX5uCyCoV9eu6xUG7KQ==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-annotate-as-pure': 7.18.6 - '@babel/helper-environment-visitor': 7.22.5 - '@babel/helper-function-name': 7.22.5 - '@babel/helper-member-expression-to-functions': 7.21.0 - '@babel/helper-optimise-call-expression': 7.18.6 - '@babel/helper-replace-supers': 7.20.7 - '@babel/helper-skip-transparent-expression-wrappers': 7.20.0 - '@babel/helper-split-export-declaration': 7.22.5 - transitivePeerDependencies: - - supports-color - dev: true - - /@babel/helper-create-class-features-plugin@7.21.0(@babel/core@7.20.5): - resolution: {integrity: sha512-Q8wNiMIdwsv5la5SPxNYzzkPnjgC0Sy0i7jLkVOCdllu/xcVNkr3TeZzbHBJrj+XXRqzX5uCyCoV9eu6xUG7KQ==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0 - dependencies: - '@babel/core': 7.20.5 - '@babel/helper-annotate-as-pure': 7.18.6 - '@babel/helper-environment-visitor': 7.22.5 - '@babel/helper-function-name': 7.22.5 - '@babel/helper-member-expression-to-functions': 7.21.0 - '@babel/helper-optimise-call-expression': 7.18.6 - '@babel/helper-replace-supers': 7.20.7 - '@babel/helper-skip-transparent-expression-wrappers': 7.20.0 - '@babel/helper-split-export-declaration': 7.22.5 - transitivePeerDependencies: - - supports-color - dev: true - /@babel/helper-create-class-features-plugin@7.21.0(@babel/core@7.22.5): - resolution: {integrity: sha512-Q8wNiMIdwsv5la5SPxNYzzkPnjgC0Sy0i7jLkVOCdllu/xcVNkr3TeZzbHBJrj+XXRqzX5uCyCoV9eu6xUG7KQ==} + /@babel/helper-create-class-features-plugin/7.22.6_@babel+core@7.22.8: + resolution: {integrity: sha512-iwdzgtSiBxF6ni6mzVnZCF3xt5qE6cEA0J7nFt8QOAWZ0zjCFceEgpn3vtb2V7WFR6QzP2jmIFOHMTRo7eNJjQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-annotate-as-pure': 7.18.6 + '@babel/core': 7.22.8 + '@babel/helper-annotate-as-pure': 7.22.5 '@babel/helper-environment-visitor': 7.22.5 '@babel/helper-function-name': 7.22.5 - '@babel/helper-member-expression-to-functions': 7.21.0 - '@babel/helper-optimise-call-expression': 7.18.6 - '@babel/helper-replace-supers': 7.20.7 - '@babel/helper-skip-transparent-expression-wrappers': 7.20.0 - '@babel/helper-split-export-declaration': 7.22.5 + '@babel/helper-member-expression-to-functions': 7.22.5 + '@babel/helper-optimise-call-expression': 7.22.5 + '@babel/helper-replace-supers': 7.22.5 + '@babel/helper-skip-transparent-expression-wrappers': 7.22.5 + '@babel/helper-split-export-declaration': 7.22.6 + '@nicolo-ribaudo/semver-v6': 6.3.3 transitivePeerDependencies: - supports-color dev: true - /@babel/helper-create-regexp-features-plugin@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-7LcpH1wnQLGrI+4v+nPp+zUvIkF9x0ddv1Hkdue10tg3gmRnLy97DXh4STiOf1qeIInyD69Qv5kKSZzKD8B/7A==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-annotate-as-pure': 7.18.6 - regexpu-core: 5.1.0 - dev: true - - /@babel/helper-create-regexp-features-plugin@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-7LcpH1wnQLGrI+4v+nPp+zUvIkF9x0ddv1Hkdue10tg3gmRnLy97DXh4STiOf1qeIInyD69Qv5kKSZzKD8B/7A==} + /@babel/helper-create-regexp-features-plugin/7.22.6_@babel+core@7.22.8: + resolution: {integrity: sha512-nBookhLKxAWo/TUCmhnaEJyLz2dekjQvv5SRpE9epWQBcpedWLKt8aZdsuT9XV5ovzR3fENLjRXVT0GsSlGGhA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-annotate-as-pure': 7.18.6 - regexpu-core: 5.1.0 + '@babel/core': 7.22.8 + '@babel/helper-annotate-as-pure': 7.22.5 + '@nicolo-ribaudo/semver-v6': 6.3.3 + regexpu-core: 5.3.2 dev: true - /@babel/helper-define-polyfill-provider@0.1.5(@babel/core@7.22.5): + /@babel/helper-define-polyfill-provider/0.1.5_@babel+core@7.22.8: resolution: {integrity: sha512-nXuzCSwlJ/WKr8qxzW816gwyT6VZgiJG17zR40fou70yfAcqjoNyTLl/DQ+FExw5Hx5KNqshmN8Ldl/r2N7cTg==} peerDependencies: '@babel/core': ^7.4.0-0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-compilation-targets': 7.22.5(@babel/core@7.22.5) + '@babel/core': 7.22.8 + '@babel/helper-compilation-targets': 7.22.6_@babel+core@7.22.8 '@babel/helper-module-imports': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 - '@babel/traverse': 7.22.5 - debug: 4.3.4(supports-color@8.1.1) - lodash.debounce: 4.0.8 - resolve: 1.22.2 - semver: 6.3.0 - transitivePeerDependencies: - - supports-color - dev: true - - /@babel/helper-define-polyfill-provider@0.3.2(@babel/core@7.18.13): - resolution: {integrity: sha512-r9QJJ+uDWrd+94BSPcP6/de67ygLtvVy6cK4luE6MOuDsZIdoaPBnfSpbO/+LTifjPckbKXRuI9BB/Z2/y3iTg==} - peerDependencies: - '@babel/core': ^7.4.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-compilation-targets': 7.22.5(@babel/core@7.18.13) - '@babel/helper-plugin-utils': 7.22.5 - debug: 4.3.4(supports-color@8.1.1) + '@babel/traverse': 7.22.8 + debug: 4.3.4 lodash.debounce: 4.0.8 resolve: 1.22.2 - semver: 6.3.0 + semver: 6.3.1 transitivePeerDependencies: - supports-color dev: true - /@babel/helper-define-polyfill-provider@0.3.2(@babel/core@7.22.5): - resolution: {integrity: sha512-r9QJJ+uDWrd+94BSPcP6/de67ygLtvVy6cK4luE6MOuDsZIdoaPBnfSpbO/+LTifjPckbKXRuI9BB/Z2/y3iTg==} + /@babel/helper-define-polyfill-provider/0.4.1_@babel+core@7.22.8: + resolution: {integrity: sha512-kX4oXixDxG197yhX+J3Wp+NpL2wuCFjWQAr6yX2jtCnflK9ulMI51ULFGIrWiX1jGfvAxdHp+XQCcP2bZGPs9A==} peerDependencies: '@babel/core': ^7.4.0-0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-compilation-targets': 7.22.5(@babel/core@7.22.5) + '@babel/core': 7.22.8 + '@babel/helper-compilation-targets': 7.22.6_@babel+core@7.22.8 '@babel/helper-plugin-utils': 7.22.5 - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 lodash.debounce: 4.0.8 resolve: 1.22.2 - semver: 6.3.0 transitivePeerDependencies: - supports-color dev: true - /@babel/helper-environment-visitor@7.22.5: + /@babel/helper-environment-visitor/7.22.5: resolution: {integrity: sha512-XGmhECfVA/5sAt+H+xpSg0mfrHq6FzNr9Oxh7PSEBBRUb/mL7Kz3NICXb194rCqAEdxkhPT1a88teizAFyvk8Q==} engines: {node: '>=6.9.0'} - /@babel/helper-explode-assignable-expression@7.18.6: - resolution: {integrity: sha512-eyAYAsQmB80jNfg4baAtLeWAQHfHFiR483rzFK+BhETlGZaQC9bsfrugfXDCbRHLQbIA7U5NxhhOxN7p/dWIcg==} - engines: {node: '>=6.9.0'} - dependencies: - '@babel/types': 7.22.5 - dev: true - - /@babel/helper-function-name@7.22.5: + /@babel/helper-function-name/7.22.5: resolution: {integrity: sha512-wtHSq6jMRE3uF2otvfuD3DIvVhOsSNshQl0Qrd7qC9oQJzHvOL4qQXlQn2916+CXGywIjpGuIkoyZRRxHPiNQQ==} engines: {node: '>=6.9.0'} dependencies: '@babel/template': 7.22.5 '@babel/types': 7.22.5 - /@babel/helper-hoist-variables@7.22.5: + /@babel/helper-hoist-variables/7.22.5: resolution: {integrity: sha512-wGjk9QZVzvknA6yKIUURb8zY3grXCcOZt+/7Wcy8O2uctxhplmUPkOdlgoNhmdVee2c92JXbf1xpMtVNbfoxRw==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 - /@babel/helper-member-expression-to-functions@7.21.0: - resolution: {integrity: sha512-Muu8cdZwNN6mRRNG6lAYErJ5X3bRevgYR2O8wN0yn7jJSnGDu6eG59RfT29JHxGUovyfrh6Pj0XzmR7drNVL3Q==} + /@babel/helper-member-expression-to-functions/7.22.5: + resolution: {integrity: sha512-aBiH1NKMG0H2cGZqspNvsaBe6wNGjbJjuLy29aU+eDZjSbbN53BaxlpB02xm9v34pLTZ1nIQPFYn2qMZoa5BQQ==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 dev: true - /@babel/helper-module-imports@7.16.0: - resolution: {integrity: sha512-kkH7sWzKPq0xt3H1n+ghb4xEMP8k0U7XV3kkB+ZGy69kDk2ySFW1qPi06sjKzFY3t1j6XbJSqr4mF9L7CYVyhg==} + /@babel/helper-module-imports/7.18.6: + resolution: {integrity: sha512-0NFvs3VkuSYbFi1x2Vd6tKrywq+z/cLeYC/RJNFrIX/30Bf5aiGYbtvGXolEktzJH8o5E5KJ3tT+nkxuuZFVlA==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 dev: true - /@babel/helper-module-imports@7.22.5: + /@babel/helper-module-imports/7.22.5: resolution: {integrity: sha512-8Dl6+HD/cKifutF5qGd/8ZJi84QeAKh+CEe1sBzz8UayBBGg1dAIJrdHOcOM5b2MpzWL2yuotJTtGjETq0qjXg==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 - /@babel/helper-module-transforms@7.18.9: - resolution: {integrity: sha512-KYNqY0ICwfv19b31XzvmI/mfcylOzbLtowkw+mfvGPAQ3kfCnMLYbED3YecL5tPd8nAYFQFAd6JHp2LxZk/J1g==} - engines: {node: '>=6.9.0'} - dependencies: - '@babel/helper-environment-visitor': 7.22.5 - '@babel/helper-module-imports': 7.22.5 - '@babel/helper-simple-access': 7.22.5 - '@babel/helper-split-export-declaration': 7.22.5 - '@babel/helper-validator-identifier': 7.22.5 - '@babel/template': 7.22.5 - '@babel/traverse': 7.22.5 - '@babel/types': 7.22.5 - transitivePeerDependencies: - - supports-color - - /@babel/helper-module-transforms@7.22.5: + /@babel/helper-module-transforms/7.22.5: resolution: {integrity: sha512-+hGKDt/Ze8GFExiVHno/2dvG5IdstpzCq0y4Qc9OJ25D4q3pKfiIP/4Vp3/JvhDkLKsDK2api3q3fpIgiIF5bw==} engines: {node: '>=6.9.0'} dependencies: '@babel/helper-environment-visitor': 7.22.5 '@babel/helper-module-imports': 7.22.5 '@babel/helper-simple-access': 7.22.5 - '@babel/helper-split-export-declaration': 7.22.5 + '@babel/helper-split-export-declaration': 7.22.6 '@babel/helper-validator-identifier': 7.22.5 '@babel/template': 7.22.5 - '@babel/traverse': 7.22.5 + '@babel/traverse': 7.22.8 '@babel/types': 7.22.5 transitivePeerDependencies: - supports-color - /@babel/helper-optimise-call-expression@7.18.6: - resolution: {integrity: sha512-HP59oD9/fEHQkdcbgFCnbmgH5vIQTJbxh2yf+CdM89/glUNnuzr87Q8GIjGEnOktTROemO0Pe0iPAYbqZuOUiA==} + /@babel/helper-optimise-call-expression/7.22.5: + resolution: {integrity: sha512-HBwaojN0xFRx4yIvpwGqxiV2tUfl7401jlok564NgB9EHS1y6QT17FmKWm4ztqjeVdXLuC4fSvHc5ePpQjoTbw==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 dev: true - /@babel/helper-plugin-utils@7.10.4: + /@babel/helper-plugin-utils/7.10.4: resolution: {integrity: sha512-O4KCvQA6lLiMU9l2eawBPMf1xPP8xPfB3iEQw150hOVTqj/rfXz0ThTb4HEzqQfs2Bmo5Ay8BzxfzVtBrr9dVg==} dev: true - /@babel/helper-plugin-utils@7.22.5: + /@babel/helper-plugin-utils/7.22.5: resolution: {integrity: sha512-uLls06UVKgFG9QD4OeFYLEGteMIAa5kpTPcFL28yuCIIzsf6ZyKZMllKVOCZFhiZ5ptnwX4mtKdWCBE/uT4amg==} engines: {node: '>=6.9.0'} - - /@babel/helper-remap-async-to-generator@7.18.9(@babel/core@7.18.13): - resolution: {integrity: sha512-dI7q50YKd8BAv3VEfgg7PS7yD3Rtbi2J1XMXaalXO0W0164hYLnh8zpjRS0mte9MfVp/tltvr/cfdXPvJr1opA==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-annotate-as-pure': 7.18.6 - '@babel/helper-environment-visitor': 7.22.5 - '@babel/helper-wrap-function': 7.18.11 - '@babel/types': 7.22.5 - transitivePeerDependencies: - - supports-color dev: true - /@babel/helper-remap-async-to-generator@7.18.9(@babel/core@7.22.5): - resolution: {integrity: sha512-dI7q50YKd8BAv3VEfgg7PS7yD3Rtbi2J1XMXaalXO0W0164hYLnh8zpjRS0mte9MfVp/tltvr/cfdXPvJr1opA==} + /@babel/helper-remap-async-to-generator/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-cU0Sq1Rf4Z55fgz7haOakIyM7+x/uCFwXpLPaeRzfoUtAEAuUZjZvFPjL/rk5rW693dIgn2hng1W7xbT7lWT4g==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-annotate-as-pure': 7.18.6 + '@babel/core': 7.22.8 + '@babel/helper-annotate-as-pure': 7.22.5 '@babel/helper-environment-visitor': 7.22.5 - '@babel/helper-wrap-function': 7.18.11 + '@babel/helper-wrap-function': 7.22.5 '@babel/types': 7.22.5 transitivePeerDependencies: - supports-color dev: true - /@babel/helper-replace-supers@7.20.7: - resolution: {integrity: sha512-vujDMtB6LVfNW13jhlCrp48QNslK6JXi7lQG736HVbHz/mbf4Dc7tIRh1Xf5C0rF7BP8iiSxGMCmY6Ci1ven3A==} + /@babel/helper-replace-supers/7.22.5: + resolution: {integrity: sha512-aLdNM5I3kdI/V9xGNyKSF3X/gTyMUBohTZ+/3QdQKAA9vxIiy12E+8E2HoOP1/DjeqU+g6as35QHJNMDDYpuCg==} engines: {node: '>=6.9.0'} dependencies: '@babel/helper-environment-visitor': 7.22.5 - '@babel/helper-member-expression-to-functions': 7.21.0 - '@babel/helper-optimise-call-expression': 7.18.6 + '@babel/helper-member-expression-to-functions': 7.22.5 + '@babel/helper-optimise-call-expression': 7.22.5 '@babel/template': 7.22.5 - '@babel/traverse': 7.22.5 + '@babel/traverse': 7.22.8 '@babel/types': 7.22.5 transitivePeerDependencies: - supports-color dev: true - /@babel/helper-simple-access@7.22.5: + /@babel/helper-simple-access/7.22.5: resolution: {integrity: sha512-n0H99E/K+Bika3++WNL17POvo4rKWZ7lZEp1Q+fStVbUi8nxPQEBOlTmCOxW/0JsS56SKKQ+ojAe2pHKJHN35w==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 - /@babel/helper-skip-transparent-expression-wrappers@7.20.0: - resolution: {integrity: sha512-5y1JYeNKfvnT8sZcK9DVRtpTbGiomYIHviSP3OQWmDPU3DeH4a1ZlT/N2lyQ5P8egjcRaT/Y9aNqUxK0WsnIIg==} + /@babel/helper-skip-transparent-expression-wrappers/7.22.5: + resolution: {integrity: sha512-tK14r66JZKiC43p8Ki33yLBVJKlQDFoA8GYN67lWCDCqoL6EMMSuM9b+Iff2jHaM/RRFYl7K+iiru7hbRqNx8Q==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 dev: true - /@babel/helper-split-export-declaration@7.22.5: - resolution: {integrity: sha512-thqK5QFghPKWLhAV321lxF95yCg2K3Ob5yw+M3VHWfdia0IkPXUtoLH8x/6Fh486QUvzhb8YOWHChTVen2/PoQ==} + /@babel/helper-split-export-declaration/7.22.6: + resolution: {integrity: sha512-AsUnxuLhRYsisFiaJwvp1QF+I3KjD5FOxut14q/GzovUe6orHLesW2C7d754kRm53h5gqrz6sFl6sxc4BVtE/g==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 - /@babel/helper-string-parser@7.22.5: + /@babel/helper-string-parser/7.22.5: resolution: {integrity: sha512-mM4COjgZox8U+JcXQwPijIZLElkgEpO5rsERVDJTc2qfCDfERyob6k5WegS14SX18IIjv+XD+GrqNumY5JRCDw==} engines: {node: '>=6.9.0'} - /@babel/helper-validator-identifier@7.22.5: + /@babel/helper-validator-identifier/7.22.5: resolution: {integrity: sha512-aJXu+6lErq8ltp+JhkJUfk1MTGyuA4v7f3pA+BJ5HLfNC6nAQ0Cpi9uOquUj8Hehg0aUiHzWQbOVJGao6ztBAQ==} engines: {node: '>=6.9.0'} - /@babel/helper-validator-option@7.22.5: + /@babel/helper-validator-option/7.22.5: resolution: {integrity: sha512-R3oB6xlIVKUnxNUxbmgq7pKjxpru24zlimpE8WK47fACIlM0II/Hm1RS8IaOI7NgCr6LNS+jl5l75m20npAziw==} engines: {node: '>=6.9.0'} - /@babel/helper-wrap-function@7.18.11: - resolution: {integrity: sha512-oBUlbv+rjZLh2Ks9SKi4aL7eKaAXBWleHzU89mP0G6BMUlRxSckk9tSIkgDGydhgFxHuGSlBQZfnaD47oBEB7w==} + /@babel/helper-wrap-function/7.22.5: + resolution: {integrity: sha512-bYqLIBSEshYcYQyfks8ewYA8S30yaGSeRslcvKMvoUk6HHPySbxHq9YRi6ghhzEU+yhQv9bP/jXnygkStOcqZw==} engines: {node: '>=6.9.0'} dependencies: '@babel/helper-function-name': 7.22.5 '@babel/template': 7.22.5 - '@babel/traverse': 7.22.5 + '@babel/traverse': 7.22.8 '@babel/types': 7.22.5 transitivePeerDependencies: - supports-color dev: true - /@babel/helpers@7.18.9: - resolution: {integrity: sha512-Jf5a+rbrLoR4eNdUmnFu8cN5eNJT6qdTdOg5IHIzq87WwyRw9PwguLFOWYgktN/60IP4fgDUawJvs7PjQIzELQ==} - engines: {node: '>=6.9.0'} - dependencies: - '@babel/template': 7.22.5 - '@babel/traverse': 7.22.5 - '@babel/types': 7.22.5 - transitivePeerDependencies: - - supports-color - - /@babel/helpers@7.22.5: - resolution: {integrity: sha512-pSXRmfE1vzcUIDFQcSGA5Mr+GxBV9oiRKDuDxXvWQQBCh8HoIjs/2DlDB7H8smac1IVrB9/xdXj2N3Wol9Cr+Q==} + /@babel/helpers/7.22.6: + resolution: {integrity: sha512-YjDs6y/fVOYFV8hAf1rxd1QvR9wJe1pDBZ2AREKq/SDayfPzgk0PBnVuTCE5X1acEpMMNOVUqoe+OwiZGJ+OaA==} engines: {node: '>=6.9.0'} dependencies: '@babel/template': 7.22.5 - '@babel/traverse': 7.22.5 + '@babel/traverse': 7.22.8 '@babel/types': 7.22.5 transitivePeerDependencies: - supports-color - /@babel/highlight@7.22.5: + /@babel/highlight/7.22.5: resolution: {integrity: sha512-BSKlD1hgnedS5XRnGOljZawtag7H1yPfQp0tdNJCHoH6AZ+Pcm9VvkrK59/Yy593Ypg0zMxH2BxD1VPYUQ7UIw==} engines: {node: '>=6.9.0'} dependencies: @@ -2806,2156 +2097,1309 @@ packages: chalk: 2.4.2 js-tokens: 4.0.0 - /@babel/parser@7.18.13: - resolution: {integrity: sha512-dgXcIfMuQ0kgzLB2b9tRZs7TTFFaGM2AbtA4fJgUUYukzGH4jwsS7hzQHEGs67jdehpm22vkgKwvbU+aEflgwg==} - engines: {node: '>=6.0.0'} - hasBin: true - dependencies: - '@babel/types': 7.22.5 - - /@babel/parser@7.22.5: - resolution: {integrity: sha512-DFZMC9LJUG9PLOclRC32G63UXwzqS2koQC8dkx+PLdmt1xSePYpbT/NbsrJy8Q/muXz7o/h/d4A7Fuyixm559Q==} + /@babel/parser/7.22.7: + resolution: {integrity: sha512-7NF8pOkHP5o2vpmGgNGcfAeCvOYhGLyA3Z4eBQkT1RJlWu47n63bCs93QfJ2hIAFCil7L5P2IWhs1oToVgrL0Q==} engines: {node: '>=6.0.0'} hasBin: true dependencies: '@babel/types': 7.22.5 - /@babel/plugin-bugfix-safari-id-destructuring-collision-in-function-expression@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-Dgxsyg54Fx1d4Nge8UnvTrED63vrwOdPmyvPzlNN/boaliRP54pm3pGzZD1SJUwrBA+Cs/xdG8kXX6Mn/RfISQ==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-bugfix-safari-id-destructuring-collision-in-function-expression@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-Dgxsyg54Fx1d4Nge8UnvTrED63vrwOdPmyvPzlNN/boaliRP54pm3pGzZD1SJUwrBA+Cs/xdG8kXX6Mn/RfISQ==} + /@babel/plugin-bugfix-safari-id-destructuring-collision-in-function-expression/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-NP1M5Rf+u2Gw9qfSO4ihjcTGW5zXTi36ITLd4/EoAcEhIZ0yjMqmftDNl3QC19CX7olhrjpyU454g/2W7X0jvQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-bugfix-v8-spread-parameters-in-optional-chaining@7.18.9(@babel/core@7.18.13): - resolution: {integrity: sha512-AHrP9jadvH7qlOj6PINbgSuphjQUAK7AOT7DPjBo9EHoLhQTnnK5u45e1Hd4DbSQEO9nqPWtQ89r+XEOWFScKg==} + /@babel/plugin-bugfix-v8-spread-parameters-in-optional-chaining/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-31Bb65aZaUwqCbWMnZPduIZxCBngHFlzyN6Dq6KAJjtx+lx6ohKHubc61OomYi7XwVD4Ol0XCVz4h+pYFR048g==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.13.0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-skip-transparent-expression-wrappers': 7.20.0 - '@babel/plugin-proposal-optional-chaining': 7.18.9(@babel/core@7.18.13) + '@babel/helper-skip-transparent-expression-wrappers': 7.22.5 + '@babel/plugin-transform-optional-chaining': 7.22.6_@babel+core@7.22.8 dev: true - /@babel/plugin-bugfix-v8-spread-parameters-in-optional-chaining@7.18.9(@babel/core@7.22.5): - resolution: {integrity: sha512-AHrP9jadvH7qlOj6PINbgSuphjQUAK7AOT7DPjBo9EHoLhQTnnK5u45e1Hd4DbSQEO9nqPWtQ89r+XEOWFScKg==} + /@babel/plugin-proposal-class-properties/7.18.6_@babel+core@7.22.8: + resolution: {integrity: sha512-cumfXOF0+nzZrrN8Rf0t7M+tF6sZc7vhQwYQck9q1/5w2OExlD+b4v4RpMJFaV1Z7WcDRgO6FqvxqxGlwo+RHQ==} engines: {node: '>=6.9.0'} peerDependencies: - '@babel/core': ^7.13.0 + '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 + '@babel/helper-create-class-features-plugin': 7.22.6_@babel+core@7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-skip-transparent-expression-wrappers': 7.20.0 - '@babel/plugin-proposal-optional-chaining': 7.18.9(@babel/core@7.22.5) + transitivePeerDependencies: + - supports-color dev: true - /@babel/plugin-proposal-async-generator-functions@7.18.10(@babel/core@7.18.13): - resolution: {integrity: sha512-1mFuY2TOsR1hxbjCo4QL+qlIjV07p4H4EUYw2J/WCqsvFV6V9X9z9YhXbWndc/4fw+hYGlDT7egYxliMp5O6Ew==} + /@babel/plugin-proposal-decorators/7.22.7_@babel+core@7.22.8: + resolution: {integrity: sha512-omXqPF7Onq4Bb7wHxXjM3jSMSJvUUbvDvmmds7KI5n9Cq6Ln5I05I1W2nRlRof1rGdiUxJrxwe285WF96XlBXQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 - '@babel/helper-environment-visitor': 7.22.5 + '@babel/core': 7.22.8 + '@babel/helper-create-class-features-plugin': 7.22.6_@babel+core@7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-remap-async-to-generator': 7.18.9(@babel/core@7.18.13) - '@babel/plugin-syntax-async-generators': 7.8.4(@babel/core@7.18.13) + '@babel/helper-replace-supers': 7.22.5 + '@babel/helper-split-export-declaration': 7.22.6 + '@babel/plugin-syntax-decorators': 7.22.5_@babel+core@7.22.8 transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-proposal-async-generator-functions@7.18.10(@babel/core@7.22.5): - resolution: {integrity: sha512-1mFuY2TOsR1hxbjCo4QL+qlIjV07p4H4EUYw2J/WCqsvFV6V9X9z9YhXbWndc/4fw+hYGlDT7egYxliMp5O6Ew==} + /@babel/plugin-proposal-export-default-from/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-UCe1X/hplyv6A5g2WnQ90tnHRvYL29dabCWww92lO7VdfMVTVReBTRrhiMrKQejHD9oVkdnRdwYuzUZkBVQisg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-environment-visitor': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-remap-async-to-generator': 7.18.9(@babel/core@7.22.5) - '@babel/plugin-syntax-async-generators': 7.8.4(@babel/core@7.22.5) - transitivePeerDependencies: - - supports-color + '@babel/plugin-syntax-export-default-from': 7.22.5_@babel+core@7.22.8 dev: true - /@babel/plugin-proposal-class-properties@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-cumfXOF0+nzZrrN8Rf0t7M+tF6sZc7vhQwYQck9q1/5w2OExlD+b4v4RpMJFaV1Z7WcDRgO6FqvxqxGlwo+RHQ==} + /@babel/plugin-proposal-nullish-coalescing-operator/7.18.6_@babel+core@7.22.8: + resolution: {integrity: sha512-wQxQzxYeJqHcfppzBDnm1yAY0jSRkUXR2z8RePZYrKwMKgMlE8+Z6LUno+bd6LvbGh8Gltvy74+9pIYkr+XkKA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 - '@babel/helper-create-class-features-plugin': 7.21.0(@babel/core@7.18.13) + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - transitivePeerDependencies: - - supports-color + '@babel/plugin-syntax-nullish-coalescing-operator': 7.8.3_@babel+core@7.22.8 dev: true - /@babel/plugin-proposal-class-properties@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-cumfXOF0+nzZrrN8Rf0t7M+tF6sZc7vhQwYQck9q1/5w2OExlD+b4v4RpMJFaV1Z7WcDRgO6FqvxqxGlwo+RHQ==} - engines: {node: '>=6.9.0'} + /@babel/plugin-proposal-object-rest-spread/7.12.1_@babel+core@7.12.9: + resolution: {integrity: sha512-s6SowJIjzlhx8o7lsFx5zmY4At6CTtDvgNQDdPzkBQucle58A6b/TTeEBYtyDgmcXjUTM+vE8YOGHZzzbc/ioA==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-create-class-features-plugin': 7.21.0(@babel/core@7.22.5) - '@babel/helper-plugin-utils': 7.22.5 - transitivePeerDependencies: - - supports-color + '@babel/core': 7.12.9 + '@babel/helper-plugin-utils': 7.10.4 + '@babel/plugin-syntax-object-rest-spread': 7.8.3_@babel+core@7.12.9 + '@babel/plugin-transform-parameters': 7.22.5_@babel+core@7.12.9 dev: true - /@babel/plugin-proposal-class-static-block@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-+I3oIiNxrCpup3Gi8n5IGMwj0gOCAjcJUSQEcotNnCCPMEnixawOQ+KeJPlgfjzx+FKQ1QSyZOWe7wmoJp7vhw==} + /@babel/plugin-proposal-object-rest-spread/7.20.7_@babel+core@7.22.8: + resolution: {integrity: sha512-d2S98yCiLxDVmBmE8UjGcfPvNEUbA1U5q5WxaWFUGRzJSVAZqm5W6MbPct0jxnegUZ0niLeNX+IOzEs7wYg9Dg==} engines: {node: '>=6.9.0'} peerDependencies: - '@babel/core': ^7.12.0 + '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 - '@babel/helper-create-class-features-plugin': 7.21.0(@babel/core@7.18.13) + '@babel/compat-data': 7.22.6 + '@babel/core': 7.22.8 + '@babel/helper-compilation-targets': 7.22.6_@babel+core@7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-class-static-block': 7.14.5(@babel/core@7.18.13) - transitivePeerDependencies: - - supports-color + '@babel/plugin-syntax-object-rest-spread': 7.8.3_@babel+core@7.22.8 + '@babel/plugin-transform-parameters': 7.22.5_@babel+core@7.22.8 dev: true - /@babel/plugin-proposal-class-static-block@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-+I3oIiNxrCpup3Gi8n5IGMwj0gOCAjcJUSQEcotNnCCPMEnixawOQ+KeJPlgfjzx+FKQ1QSyZOWe7wmoJp7vhw==} + /@babel/plugin-proposal-optional-chaining/7.21.0_@babel+core@7.22.8: + resolution: {integrity: sha512-p4zeefM72gpmEe2fkUr/OnOXpWEf8nAgk7ZYVqqfFiyIG7oFfVZcCrU64hWn5xp4tQ9LkV4bTIa5rD0KANpKNA==} engines: {node: '>=6.9.0'} peerDependencies: - '@babel/core': ^7.12.0 + '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-create-class-features-plugin': 7.21.0(@babel/core@7.22.5) + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-class-static-block': 7.14.5(@babel/core@7.22.5) - transitivePeerDependencies: - - supports-color + '@babel/helper-skip-transparent-expression-wrappers': 7.22.5 + '@babel/plugin-syntax-optional-chaining': 7.8.3_@babel+core@7.22.8 dev: true - /@babel/plugin-proposal-decorators@7.18.10(@babel/core@7.22.5): - resolution: {integrity: sha512-wdGTwWF5QtpTY/gbBtQLAiCnoxfD4qMbN87NYZle1dOZ9Os8Y6zXcKrIaOU8W+TIvFUWVGG9tUgNww3CjXRVVw==} + /@babel/plugin-proposal-private-methods/7.18.6_@babel+core@7.22.8: + resolution: {integrity: sha512-nutsvktDItsNn4rpGItSNV2sz1XwS+nfU0Rg8aCx3W3NOKVzdMjJRu0O5OkgDp3ZGICSTbgRpxZoWsxoKRvbeA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-create-class-features-plugin': 7.21.0(@babel/core@7.22.5) + '@babel/core': 7.22.8 + '@babel/helper-create-class-features-plugin': 7.22.6_@babel+core@7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-replace-supers': 7.20.7 - '@babel/helper-split-export-declaration': 7.22.5 - '@babel/plugin-syntax-decorators': 7.18.6(@babel/core@7.22.5) transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-proposal-dynamic-import@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-1auuwmK+Rz13SJj36R+jqFPMJWyKEDd7lLSdOj4oJK0UTgGueSAtkrCvz9ewmgyU/P941Rv2fQwZJN8s6QruXw==} + /@babel/plugin-proposal-private-property-in-object/7.21.0-placeholder-for-preset-env.2_@babel+core@7.22.8: + resolution: {integrity: sha512-SOSkfJDddaM7mak6cPEpswyTRnuRltl429hMraQEglW+OkovnCzsiszTmsrlY//qLFjCpQDFRvjdm2wA5pPm9w==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 - '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-dynamic-import': 7.8.3(@babel/core@7.18.13) + '@babel/core': 7.22.8 dev: true - /@babel/plugin-proposal-dynamic-import@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-1auuwmK+Rz13SJj36R+jqFPMJWyKEDd7lLSdOj4oJK0UTgGueSAtkrCvz9ewmgyU/P941Rv2fQwZJN8s6QruXw==} + /@babel/plugin-proposal-private-property-in-object/7.21.11_@babel+core@7.22.8: + resolution: {integrity: sha512-0QZ8qP/3RLDVBwBFoWAwCtgcDZJVwA5LUJRZU8x2YFfKNuFq161wK3cuGrALu5yiPu+vzwTAg/sMWVNeWeNyaw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 + '@babel/helper-annotate-as-pure': 7.22.5 + '@babel/helper-create-class-features-plugin': 7.22.6_@babel+core@7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-dynamic-import': 7.8.3(@babel/core@7.22.5) + '@babel/plugin-syntax-private-property-in-object': 7.14.5_@babel+core@7.22.8 + transitivePeerDependencies: + - supports-color dev: true - /@babel/plugin-proposal-export-default-from@7.18.10(@babel/core@7.22.5): - resolution: {integrity: sha512-5H2N3R2aQFxkV4PIBUR/i7PUSwgTZjouJKzI8eKswfIjT0PhvzkPn0t0wIS5zn6maQuvtT0t1oHtMUz61LOuow==} - engines: {node: '>=6.9.0'} + /@babel/plugin-proposal-unicode-property-regex/7.18.6_@babel+core@7.22.8: + resolution: {integrity: sha512-2BShG/d5yoZyXZfVePH91urL5wTG6ASZU9M4o03lKK8u8UW1y08OMttBSOADTcJrnPMpvDXRG3G8fyLh4ovs8w==} + engines: {node: '>=4'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 + '@babel/helper-create-regexp-features-plugin': 7.22.6_@babel+core@7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-export-default-from': 7.18.6(@babel/core@7.22.5) dev: true - /@babel/plugin-proposal-export-namespace-from@7.18.9(@babel/core@7.18.13): - resolution: {integrity: sha512-k1NtHyOMvlDDFeb9G5PhUXuGj8m/wiwojgQVEhJ/fsVsMCpLyOP4h0uGEjYJKrRI+EVPlb5Jk+Gt9P97lOGwtA==} - engines: {node: '>=6.9.0'} + /@babel/plugin-syntax-async-generators/7.8.4_@babel+core@7.22.8: + resolution: {integrity: sha512-tycmZxkGfZaxhMRbXlPXuVFpdWlXpir2W4AMhSJgRKzk/eDlIXOhb2LHWoLpDF7TEHylV5zNhykX6KAgHJmTNw==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-export-namespace-from': 7.8.3(@babel/core@7.18.13) dev: true - /@babel/plugin-proposal-export-namespace-from@7.18.9(@babel/core@7.22.5): - resolution: {integrity: sha512-k1NtHyOMvlDDFeb9G5PhUXuGj8m/wiwojgQVEhJ/fsVsMCpLyOP4h0uGEjYJKrRI+EVPlb5Jk+Gt9P97lOGwtA==} - engines: {node: '>=6.9.0'} + /@babel/plugin-syntax-class-properties/7.12.13_@babel+core@7.22.8: + resolution: {integrity: sha512-fm4idjKla0YahUNgFNLCB0qySdsoPiZP3iQE3rky0mBUtMZ23yDJ9SJdg6dXTSDnulOVqiF3Hgr9nbXvXTQZYA==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-export-namespace-from': 7.8.3(@babel/core@7.22.5) dev: true - /@babel/plugin-proposal-json-strings@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-lr1peyn9kOdbYc0xr0OdHTZ5FMqS6Di+H0Fz2I/JwMzGmzJETNeOFq2pBySw6X/KFL5EWDjlJuMsUGRFb8fQgQ==} + /@babel/plugin-syntax-class-static-block/7.14.5_@babel+core@7.22.8: + resolution: {integrity: sha512-b+YyPmr6ldyNnM6sqYeMWE+bgJcJpO6yS4QD7ymxgH34GBPNDM/THBh8iunyvKIZztiwLH4CJZ0RxTk9emgpjw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-json-strings': 7.8.3(@babel/core@7.18.13) dev: true - /@babel/plugin-proposal-json-strings@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-lr1peyn9kOdbYc0xr0OdHTZ5FMqS6Di+H0Fz2I/JwMzGmzJETNeOFq2pBySw6X/KFL5EWDjlJuMsUGRFb8fQgQ==} + /@babel/plugin-syntax-decorators/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-avpUOBS7IU6al8MmF1XpAyj9QYeLPuSDJI5D4pVMSMdL7xQokKqJPYQC67RCT0aCTashUXPiGwMJ0DEXXCEmMA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-json-strings': 7.8.3(@babel/core@7.22.5) dev: true - /@babel/plugin-proposal-logical-assignment-operators@7.18.9(@babel/core@7.18.13): - resolution: {integrity: sha512-128YbMpjCrP35IOExw2Fq+x55LMP42DzhOhX2aNNIdI9avSWl2PI0yuBWarr3RYpZBSPtabfadkH2yeRiMD61Q==} - engines: {node: '>=6.9.0'} + /@babel/plugin-syntax-dynamic-import/7.8.3_@babel+core@7.22.8: + resolution: {integrity: sha512-5gdGbFon+PszYzqs83S3E5mpi7/y/8M9eC90MRTZfduQOYW76ig6SOSPNe41IG5LoP3FGBn2N0RjVDSQiS94kQ==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-logical-assignment-operators': 7.10.4(@babel/core@7.18.13) dev: true - /@babel/plugin-proposal-logical-assignment-operators@7.18.9(@babel/core@7.22.5): - resolution: {integrity: sha512-128YbMpjCrP35IOExw2Fq+x55LMP42DzhOhX2aNNIdI9avSWl2PI0yuBWarr3RYpZBSPtabfadkH2yeRiMD61Q==} + /@babel/plugin-syntax-export-default-from/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-ODAqWWXB/yReh/jVQDag/3/tl6lgBueQkk/TcfW/59Oykm4c8a55XloX0CTk2k2VJiFWMgHby9xNX29IbCv9dQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-logical-assignment-operators': 7.10.4(@babel/core@7.22.5) dev: true - /@babel/plugin-proposal-nullish-coalescing-operator@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-wQxQzxYeJqHcfppzBDnm1yAY0jSRkUXR2z8RePZYrKwMKgMlE8+Z6LUno+bd6LvbGh8Gltvy74+9pIYkr+XkKA==} - engines: {node: '>=6.9.0'} + /@babel/plugin-syntax-export-namespace-from/7.8.3_@babel+core@7.22.8: + resolution: {integrity: sha512-MXf5laXo6c1IbEbegDmzGPwGNTsHZmEy6QGznu5Sh2UCWvueywb2ee+CCE4zQiZstxU9BMoQO9i6zUFSY0Kj0Q==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-nullish-coalescing-operator': 7.8.3(@babel/core@7.18.13) dev: true - /@babel/plugin-proposal-nullish-coalescing-operator@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-wQxQzxYeJqHcfppzBDnm1yAY0jSRkUXR2z8RePZYrKwMKgMlE8+Z6LUno+bd6LvbGh8Gltvy74+9pIYkr+XkKA==} + /@babel/plugin-syntax-flow/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-9RdCl0i+q0QExayk2nOS7853w08yLucnnPML6EN9S8fgMPVtdLDCdx/cOQ/i44Lb9UeQX9A35yaqBBOMMZxPxQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-nullish-coalescing-operator': 7.8.3(@babel/core@7.22.5) dev: true - /@babel/plugin-proposal-numeric-separator@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-ozlZFogPqoLm8WBr5Z8UckIoE4YQ5KESVcNudyXOR8uqIkliTEgJ3RoketfG6pmzLdeZF0H/wjE9/cCEitBl7Q==} + /@babel/plugin-syntax-import-assertions/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-rdV97N7KqsRzeNGoWUOK6yUsWarLjE5Su/Snk9IYPU9CwkWHs4t+rTGOvffTR8XGkJMTAdLfO0xVnXm8wugIJg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-numeric-separator': 7.10.4(@babel/core@7.18.13) dev: true - /@babel/plugin-proposal-numeric-separator@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-ozlZFogPqoLm8WBr5Z8UckIoE4YQ5KESVcNudyXOR8uqIkliTEgJ3RoketfG6pmzLdeZF0H/wjE9/cCEitBl7Q==} + /@babel/plugin-syntax-import-attributes/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-KwvoWDeNKPETmozyFE0P2rOLqh39EoQHNjqizrI5B8Vt0ZNS7M56s7dAiAqbYfiAYOuIzIh96z3iR2ktgu3tEg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-numeric-separator': 7.10.4(@babel/core@7.22.5) dev: true - /@babel/plugin-proposal-object-rest-spread@7.12.1(@babel/core@7.12.9): - resolution: {integrity: sha512-s6SowJIjzlhx8o7lsFx5zmY4At6CTtDvgNQDdPzkBQucle58A6b/TTeEBYtyDgmcXjUTM+vE8YOGHZzzbc/ioA==} + /@babel/plugin-syntax-import-meta/7.10.4_@babel+core@7.22.8: + resolution: {integrity: sha512-Yqfm+XDx0+Prh3VSeEQCPU81yC+JWZ2pDPFSS4ZdpfZhp4MkFMaDC1UqseovEKwSUpnIL7+vK+Clp7bfh0iD7g==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.12.9 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-object-rest-spread': 7.8.3(@babel/core@7.12.9) - '@babel/plugin-transform-parameters': 7.18.8(@babel/core@7.12.9) dev: true - /@babel/plugin-proposal-object-rest-spread@7.18.9(@babel/core@7.18.13): - resolution: {integrity: sha512-kDDHQ5rflIeY5xl69CEqGEZ0KY369ehsCIEbTGb4siHG5BE9sga/T0r0OUwyZNLMmZE79E1kbsqAjwFCW4ds6Q==} - engines: {node: '>=6.9.0'} + /@babel/plugin-syntax-json-strings/7.8.3_@babel+core@7.22.8: + resolution: {integrity: sha512-lY6kdGpWHvjoe2vk4WrAapEuBR69EMxZl+RoGRhrFGNYVK8mOPAW8VfbT/ZgrFbXlDNiiaxQnAtgVCZ6jv30EA==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/compat-data': 7.22.5 - '@babel/core': 7.18.13 - '@babel/helper-compilation-targets': 7.22.5(@babel/core@7.18.13) + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-object-rest-spread': 7.8.3(@babel/core@7.18.13) - '@babel/plugin-transform-parameters': 7.18.8(@babel/core@7.18.13) dev: true - /@babel/plugin-proposal-object-rest-spread@7.18.9(@babel/core@7.22.5): - resolution: {integrity: sha512-kDDHQ5rflIeY5xl69CEqGEZ0KY369ehsCIEbTGb4siHG5BE9sga/T0r0OUwyZNLMmZE79E1kbsqAjwFCW4ds6Q==} - engines: {node: '>=6.9.0'} + /@babel/plugin-syntax-jsx/7.12.1_@babel+core@7.12.9: + resolution: {integrity: sha512-1yRi7yAtB0ETgxdY9ti/p2TivUxJkTdhu/ZbF9MshVGqOx1TdB3b7xCXs49Fupgg50N45KcAsRP/ZqWjs9SRjg==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/compat-data': 7.22.5 - '@babel/core': 7.22.5 - '@babel/helper-compilation-targets': 7.22.5(@babel/core@7.22.5) + '@babel/core': 7.12.9 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-object-rest-spread': 7.8.3(@babel/core@7.22.5) - '@babel/plugin-transform-parameters': 7.18.8(@babel/core@7.22.5) dev: true - /@babel/plugin-proposal-optional-catch-binding@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-Q40HEhs9DJQyaZfUjjn6vE8Cv4GmMHCYuMGIWUnlxH6400VGxOuwWsPt4FxXxJkC/5eOzgn0z21M9gMT4MOhbw==} + /@babel/plugin-syntax-jsx/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-gvyP4hZrgrs/wWMaocvxZ44Hw0b3W8Pe+cMxc8V1ULQ07oh8VNbIRaoD1LRZVTvD+0nieDKjfgKg89sD7rrKrg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-optional-catch-binding': 7.8.3(@babel/core@7.18.13) dev: true - /@babel/plugin-proposal-optional-catch-binding@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-Q40HEhs9DJQyaZfUjjn6vE8Cv4GmMHCYuMGIWUnlxH6400VGxOuwWsPt4FxXxJkC/5eOzgn0z21M9gMT4MOhbw==} - engines: {node: '>=6.9.0'} + /@babel/plugin-syntax-logical-assignment-operators/7.10.4_@babel+core@7.22.8: + resolution: {integrity: sha512-d8waShlpFDinQ5MtvGU9xDAOzKH47+FFoney2baFIoMr952hKOLp1HR7VszoZvOsV/4+RRszNY7D17ba0te0ig==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-optional-catch-binding': 7.8.3(@babel/core@7.22.5) dev: true - /@babel/plugin-proposal-optional-chaining@7.18.9(@babel/core@7.18.13): - resolution: {integrity: sha512-v5nwt4IqBXihxGsW2QmCWMDS3B3bzGIk/EQVZz2ei7f3NJl8NzAJVvUmpDW5q1CRNY+Beb/k58UAH1Km1N411w==} - engines: {node: '>=6.9.0'} + /@babel/plugin-syntax-nullish-coalescing-operator/7.8.3_@babel+core@7.22.8: + resolution: {integrity: sha512-aSff4zPII1u2QD7y+F8oDsz19ew4IGEJg9SVW+bqwpwtfFleiQDMdzA/R+UlWDzfnHFCxxleFT0PMIrR36XLNQ==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-skip-transparent-expression-wrappers': 7.20.0 - '@babel/plugin-syntax-optional-chaining': 7.8.3(@babel/core@7.18.13) dev: true - /@babel/plugin-proposal-optional-chaining@7.18.9(@babel/core@7.22.5): - resolution: {integrity: sha512-v5nwt4IqBXihxGsW2QmCWMDS3B3bzGIk/EQVZz2ei7f3NJl8NzAJVvUmpDW5q1CRNY+Beb/k58UAH1Km1N411w==} - engines: {node: '>=6.9.0'} + /@babel/plugin-syntax-numeric-separator/7.10.4_@babel+core@7.22.8: + resolution: {integrity: sha512-9H6YdfkcK/uOnY/K7/aA2xpzaAgkQn37yzWUMRK7OaPOqOpGS1+n0H5hxT9AUw9EsSjPW8SVyMJwYRtWs3X3ug==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-skip-transparent-expression-wrappers': 7.20.0 - '@babel/plugin-syntax-optional-chaining': 7.8.3(@babel/core@7.22.5) dev: true - /@babel/plugin-proposal-private-methods@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-nutsvktDItsNn4rpGItSNV2sz1XwS+nfU0Rg8aCx3W3NOKVzdMjJRu0O5OkgDp3ZGICSTbgRpxZoWsxoKRvbeA==} - engines: {node: '>=6.9.0'} + /@babel/plugin-syntax-object-rest-spread/7.8.3_@babel+core@7.12.9: + resolution: {integrity: sha512-XoqMijGZb9y3y2XskN+P1wUGiVwWZ5JmoDRwx5+3GmEplNyVM2s2Dg8ILFQm8rWM48orGy5YpI5Bl8U1y7ydlA==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 - '@babel/helper-create-class-features-plugin': 7.21.0(@babel/core@7.18.13) + '@babel/core': 7.12.9 '@babel/helper-plugin-utils': 7.22.5 - transitivePeerDependencies: - - supports-color dev: true - /@babel/plugin-proposal-private-methods@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-nutsvktDItsNn4rpGItSNV2sz1XwS+nfU0Rg8aCx3W3NOKVzdMjJRu0O5OkgDp3ZGICSTbgRpxZoWsxoKRvbeA==} - engines: {node: '>=6.9.0'} + /@babel/plugin-syntax-object-rest-spread/7.8.3_@babel+core@7.22.8: + resolution: {integrity: sha512-XoqMijGZb9y3y2XskN+P1wUGiVwWZ5JmoDRwx5+3GmEplNyVM2s2Dg8ILFQm8rWM48orGy5YpI5Bl8U1y7ydlA==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-create-class-features-plugin': 7.21.0(@babel/core@7.22.5) + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - transitivePeerDependencies: - - supports-color dev: true - /@babel/plugin-proposal-private-property-in-object@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-9Rysx7FOctvT5ouj5JODjAFAkgGoudQuLPamZb0v1TGLpapdNaftzifU8NTWQm0IRjqoYypdrSmyWgkocDQ8Dw==} - engines: {node: '>=6.9.0'} + /@babel/plugin-syntax-optional-catch-binding/7.8.3_@babel+core@7.22.8: + resolution: {integrity: sha512-6VPD0Pc1lpTqw0aKoeRTMiB+kWhAoT24PA+ksWSBrFtl5SIRVpZlwN3NNPQjehA2E/91FV3RjLWoVTglWcSV3Q==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 - '@babel/helper-annotate-as-pure': 7.18.6 - '@babel/helper-create-class-features-plugin': 7.21.0(@babel/core@7.18.13) + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-private-property-in-object': 7.14.5(@babel/core@7.18.13) - transitivePeerDependencies: - - supports-color dev: true - /@babel/plugin-proposal-private-property-in-object@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-9Rysx7FOctvT5ouj5JODjAFAkgGoudQuLPamZb0v1TGLpapdNaftzifU8NTWQm0IRjqoYypdrSmyWgkocDQ8Dw==} - engines: {node: '>=6.9.0'} + /@babel/plugin-syntax-optional-chaining/7.8.3_@babel+core@7.22.8: + resolution: {integrity: sha512-KoK9ErH1MBlCPxV0VANkXW2/dw4vlbGDrFgz8bmUsBGYkFRcbRwMh6cIJubdPrkxRwuGdtCk0v/wPTKbQgBjkg==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-annotate-as-pure': 7.18.6 - '@babel/helper-create-class-features-plugin': 7.21.0(@babel/core@7.22.5) + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-private-property-in-object': 7.14.5(@babel/core@7.22.5) - transitivePeerDependencies: - - supports-color dev: true - /@babel/plugin-proposal-unicode-property-regex@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-2BShG/d5yoZyXZfVePH91urL5wTG6ASZU9M4o03lKK8u8UW1y08OMttBSOADTcJrnPMpvDXRG3G8fyLh4ovs8w==} - engines: {node: '>=4'} + /@babel/plugin-syntax-private-property-in-object/7.14.5_@babel+core@7.22.8: + resolution: {integrity: sha512-0wVnp9dxJ72ZUJDV27ZfbSj6iHLoytYZmh3rFcxNnvsJF3ktkzLDZPy/mA17HGsaQT3/DQsWYX1f1QGWkCoVUg==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 - '@babel/helper-create-regexp-features-plugin': 7.18.6(@babel/core@7.18.13) + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-proposal-unicode-property-regex@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-2BShG/d5yoZyXZfVePH91urL5wTG6ASZU9M4o03lKK8u8UW1y08OMttBSOADTcJrnPMpvDXRG3G8fyLh4ovs8w==} - engines: {node: '>=4'} + /@babel/plugin-syntax-top-level-await/7.14.5_@babel+core@7.22.8: + resolution: {integrity: sha512-hx++upLv5U1rgYfwe1xBQUhRmU41NEvpUvrp8jkrSCdvGSnM5/qdRMtylJ6PG5OFkBaHkbTAKTnd3/YyESRHFw==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-create-regexp-features-plugin': 7.18.6(@babel/core@7.22.5) + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-async-generators@7.8.4(@babel/core@7.18.13): - resolution: {integrity: sha512-tycmZxkGfZaxhMRbXlPXuVFpdWlXpir2W4AMhSJgRKzk/eDlIXOhb2LHWoLpDF7TEHylV5zNhykX6KAgHJmTNw==} + /@babel/plugin-syntax-typescript/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-1mS2o03i7t1c6VzH6fdQ3OA8tcEIxwG18zIPRp+UY1Ihv6W+XZzBCVxExF9upussPXJ0xE9XRHwMoNs1ep/nRQ==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-async-generators@7.8.4(@babel/core@7.22.5): - resolution: {integrity: sha512-tycmZxkGfZaxhMRbXlPXuVFpdWlXpir2W4AMhSJgRKzk/eDlIXOhb2LHWoLpDF7TEHylV5zNhykX6KAgHJmTNw==} + /@babel/plugin-syntax-unicode-sets-regex/7.18.6_@babel+core@7.22.8: + resolution: {integrity: sha512-727YkEAPwSIQTv5im8QHz3upqp92JTWhidIC81Tdx4VJYIte/VndKf1qKrfnnhPLiPghStWfvC/iFaMCQu7Nqg==} + engines: {node: '>=6.9.0'} peerDependencies: - '@babel/core': ^7.0.0-0 + '@babel/core': ^7.0.0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 + '@babel/helper-create-regexp-features-plugin': 7.22.6_@babel+core@7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-bigint@7.8.3(@babel/core@7.22.5): - resolution: {integrity: sha512-wnTnFlG+YxQm3vDxpGE57Pj0srRU4sHE/mDkt1qv2YJJSeUAec2ma4WLUnUPeKjyrfntVwe/N6dCXpU+zL3Npg==} + /@babel/plugin-transform-arrow-functions/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-26lTNXoVRdAnsaDXPpvCNUq+OVWEVC6bx7Vvz9rC53F2bagUWW4u4ii2+h8Fejfh7RYqPxn+libeFBBck9muEw==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-class-properties@7.12.13(@babel/core@7.18.13): - resolution: {integrity: sha512-fm4idjKla0YahUNgFNLCB0qySdsoPiZP3iQE3rky0mBUtMZ23yDJ9SJdg6dXTSDnulOVqiF3Hgr9nbXvXTQZYA==} + /@babel/plugin-transform-async-generator-functions/7.22.7_@babel+core@7.22.8: + resolution: {integrity: sha512-7HmE7pk/Fmke45TODvxvkxRMV9RazV+ZZzhOL9AG8G29TLrr3jkjwF7uJfxZ30EoXpO+LJkq4oA8NjO2DTnEDg==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 + '@babel/helper-environment-visitor': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 + '@babel/helper-remap-async-to-generator': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-syntax-async-generators': 7.8.4_@babel+core@7.22.8 + transitivePeerDependencies: + - supports-color dev: true - /@babel/plugin-syntax-class-properties@7.12.13(@babel/core@7.22.5): - resolution: {integrity: sha512-fm4idjKla0YahUNgFNLCB0qySdsoPiZP3iQE3rky0mBUtMZ23yDJ9SJdg6dXTSDnulOVqiF3Hgr9nbXvXTQZYA==} + /@babel/plugin-transform-async-to-generator/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-b1A8D8ZzE/VhNDoV1MSJTnpKkCG5bJo+19R4o4oy03zM7ws8yEMK755j61Dc3EyvdysbqH5BOOTquJ7ZX9C6vQ==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 + '@babel/helper-module-imports': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 + '@babel/helper-remap-async-to-generator': 7.22.5_@babel+core@7.22.8 + transitivePeerDependencies: + - supports-color dev: true - /@babel/plugin-syntax-class-static-block@7.14.5(@babel/core@7.18.13): - resolution: {integrity: sha512-b+YyPmr6ldyNnM6sqYeMWE+bgJcJpO6yS4QD7ymxgH34GBPNDM/THBh8iunyvKIZztiwLH4CJZ0RxTk9emgpjw==} + /@babel/plugin-transform-block-scoped-functions/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-tdXZ2UdknEKQWKJP1KMNmuF5Lx3MymtMN/pvA+p/VEkhK8jVcQ1fzSy8KM9qRYhAf2/lV33hoMPKI/xaI9sADA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-class-static-block@7.14.5(@babel/core@7.22.5): - resolution: {integrity: sha512-b+YyPmr6ldyNnM6sqYeMWE+bgJcJpO6yS4QD7ymxgH34GBPNDM/THBh8iunyvKIZztiwLH4CJZ0RxTk9emgpjw==} + /@babel/plugin-transform-block-scoping/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-EcACl1i5fSQ6bt+YGuU/XGCeZKStLmyVGytWkpyhCLeQVA0eu6Wtiw92V+I1T/hnezUv7j74dA/Ro69gWcU+hg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-decorators@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-fqyLgjcxf/1yhyZ6A+yo1u9gJ7eleFQod2lkaUsF9DQ7sbbY3Ligym3L0+I2c0WmqNKDpoD9UTb1AKP3qRMOAQ==} + /@babel/plugin-transform-class-properties/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-nDkQ0NfkOhPTq8YCLiWNxp1+f9fCobEjCb0n8WdbNUBc4IB5V7P1QnX9IjpSoquKrXF5SKojHleVNs2vGeHCHQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 + '@babel/helper-create-class-features-plugin': 7.22.6_@babel+core@7.22.8 '@babel/helper-plugin-utils': 7.22.5 + transitivePeerDependencies: + - supports-color dev: true - /@babel/plugin-syntax-dynamic-import@7.8.3(@babel/core@7.18.13): - resolution: {integrity: sha512-5gdGbFon+PszYzqs83S3E5mpi7/y/8M9eC90MRTZfduQOYW76ig6SOSPNe41IG5LoP3FGBn2N0RjVDSQiS94kQ==} + /@babel/plugin-transform-class-static-block/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-SPToJ5eYZLxlnp1UzdARpOGeC2GbHvr9d/UV0EukuVx8atktg194oe+C5BqQ8jRTkgLRVOPYeXRSBg1IlMoVRA==} + engines: {node: '>=6.9.0'} peerDependencies: - '@babel/core': ^7.0.0-0 + '@babel/core': ^7.12.0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 + '@babel/helper-create-class-features-plugin': 7.22.6_@babel+core@7.22.8 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-class-static-block': 7.14.5_@babel+core@7.22.8 + transitivePeerDependencies: + - supports-color dev: true - /@babel/plugin-syntax-dynamic-import@7.8.3(@babel/core@7.22.5): - resolution: {integrity: sha512-5gdGbFon+PszYzqs83S3E5mpi7/y/8M9eC90MRTZfduQOYW76ig6SOSPNe41IG5LoP3FGBn2N0RjVDSQiS94kQ==} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-syntax-export-default-from@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-Kr//z3ujSVNx6E9z9ih5xXXMqK07VVTuqPmqGe6Mss/zW5XPeLZeSDZoP9ab/hT4wPKqAgjl2PnhPrcpk8Seew==} + /@babel/plugin-transform-classes/7.22.6_@babel+core@7.22.8: + resolution: {integrity: sha512-58EgM6nuPNG6Py4Z3zSuu0xWu2VfodiMi72Jt5Kj2FECmaYk1RrTXA45z6KBFsu9tRgwQDwIiY4FXTt+YsSFAQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-syntax-export-namespace-from@7.8.3(@babel/core@7.18.13): - resolution: {integrity: sha512-MXf5laXo6c1IbEbegDmzGPwGNTsHZmEy6QGznu5Sh2UCWvueywb2ee+CCE4zQiZstxU9BMoQO9i6zUFSY0Kj0Q==} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-syntax-export-namespace-from@7.8.3(@babel/core@7.22.5): - resolution: {integrity: sha512-MXf5laXo6c1IbEbegDmzGPwGNTsHZmEy6QGznu5Sh2UCWvueywb2ee+CCE4zQiZstxU9BMoQO9i6zUFSY0Kj0Q==} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 + '@babel/helper-annotate-as-pure': 7.22.5 + '@babel/helper-compilation-targets': 7.22.6_@babel+core@7.22.8 + '@babel/helper-environment-visitor': 7.22.5 + '@babel/helper-function-name': 7.22.5 + '@babel/helper-optimise-call-expression': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 + '@babel/helper-replace-supers': 7.22.5 + '@babel/helper-split-export-declaration': 7.22.6 + globals: 11.12.0 + transitivePeerDependencies: + - supports-color dev: true - /@babel/plugin-syntax-flow@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-LUbR+KNTBWCUAqRG9ex5Gnzu2IOkt8jRJbHHXFT9q+L9zm7M/QQbEqXyw1n1pohYvOyWC8CjeyjrSaIwiYjK7A==} + /@babel/plugin-transform-computed-properties/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-4GHWBgRf0krxPX+AaPtgBAlTgTeZmqDynokHOX7aqqAB4tHs3U2Y02zH6ETFdLZGcg9UQSD1WCmkVrE9ErHeOg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 + '@babel/template': 7.22.5 dev: true - /@babel/plugin-syntax-import-assertions@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-/DU3RXad9+bZwrgWJQKbr39gYbJpLJHezqEzRzi/BHRlJ9zsQb4CK2CA/5apllXNomwA1qHwzvHl+AdEmC5krQ==} + /@babel/plugin-transform-destructuring/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-GfqcFuGW8vnEqTUBM7UtPd5A4q797LTvvwKxXTgRsFjoqaJiEg9deBG6kWeQYkVEL569NpnmpC0Pkr/8BLKGnQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-import-assertions@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-/DU3RXad9+bZwrgWJQKbr39gYbJpLJHezqEzRzi/BHRlJ9zsQb4CK2CA/5apllXNomwA1qHwzvHl+AdEmC5krQ==} + /@babel/plugin-transform-dotall-regex/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-5/Yk9QxCQCl+sOIB1WelKnVRxTJDSAIxtJLL2/pqL14ZVlbH0fUQUZa/T5/UnQtBNgghR7mfB8ERBKyKPCi7Vw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-syntax-import-meta@7.10.4(@babel/core@7.22.5): - resolution: {integrity: sha512-Yqfm+XDx0+Prh3VSeEQCPU81yC+JWZ2pDPFSS4ZdpfZhp4MkFMaDC1UqseovEKwSUpnIL7+vK+Clp7bfh0iD7g==} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-syntax-json-strings@7.8.3(@babel/core@7.18.13): - resolution: {integrity: sha512-lY6kdGpWHvjoe2vk4WrAapEuBR69EMxZl+RoGRhrFGNYVK8mOPAW8VfbT/ZgrFbXlDNiiaxQnAtgVCZ6jv30EA==} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-syntax-json-strings@7.8.3(@babel/core@7.22.5): - resolution: {integrity: sha512-lY6kdGpWHvjoe2vk4WrAapEuBR69EMxZl+RoGRhrFGNYVK8mOPAW8VfbT/ZgrFbXlDNiiaxQnAtgVCZ6jv30EA==} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 + '@babel/helper-create-regexp-features-plugin': 7.22.6_@babel+core@7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-jsx@7.12.1(@babel/core@7.12.9): - resolution: {integrity: sha512-1yRi7yAtB0ETgxdY9ti/p2TivUxJkTdhu/ZbF9MshVGqOx1TdB3b7xCXs49Fupgg50N45KcAsRP/ZqWjs9SRjg==} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.12.9 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-syntax-jsx@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-6mmljtAedFGTWu2p/8WIORGwy+61PLgOMPOdazc7YoJ9ZCWUyFy3A6CpPkRKLKD1ToAesxX8KGEViAiLo9N+7Q==} + /@babel/plugin-transform-duplicate-keys/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-dEnYD+9BBgld5VBXHnF/DbYGp3fqGMsyxKbtD1mDyIA7AkTSpKXFhCVuj/oQVOoALfBs77DudA0BE4d5mcpmqw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-jsx@7.18.6(@babel/core@7.20.5): - resolution: {integrity: sha512-6mmljtAedFGTWu2p/8WIORGwy+61PLgOMPOdazc7YoJ9ZCWUyFy3A6CpPkRKLKD1ToAesxX8KGEViAiLo9N+7Q==} + /@babel/plugin-transform-dynamic-import/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-0MC3ppTB1AMxd8fXjSrbPa7LT9hrImt+/fcj+Pg5YMD7UQyWp/02+JWpdnCymmsXwIx5Z+sYn1bwCn4ZJNvhqQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.20.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-dynamic-import': 7.8.3_@babel+core@7.22.8 dev: true - /@babel/plugin-syntax-jsx@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-6mmljtAedFGTWu2p/8WIORGwy+61PLgOMPOdazc7YoJ9ZCWUyFy3A6CpPkRKLKD1ToAesxX8KGEViAiLo9N+7Q==} + /@babel/plugin-transform-exponentiation-operator/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-vIpJFNM/FjZ4rh1myqIya9jXwrwwgFRHPjT3DkUA9ZLHuzox8jiXkOLvwm1H+PQIP3CqfC++WPKeuDi0Sjdj1g==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - - /@babel/plugin-syntax-logical-assignment-operators@7.10.4(@babel/core@7.18.13): - resolution: {integrity: sha512-d8waShlpFDinQ5MtvGU9xDAOzKH47+FFoney2baFIoMr952hKOLp1HR7VszoZvOsV/4+RRszNY7D17ba0te0ig==} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-syntax-logical-assignment-operators@7.10.4(@babel/core@7.22.5): - resolution: {integrity: sha512-d8waShlpFDinQ5MtvGU9xDAOzKH47+FFoney2baFIoMr952hKOLp1HR7VszoZvOsV/4+RRszNY7D17ba0te0ig==} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-syntax-nullish-coalescing-operator@7.8.3(@babel/core@7.18.13): - resolution: {integrity: sha512-aSff4zPII1u2QD7y+F8oDsz19ew4IGEJg9SVW+bqwpwtfFleiQDMdzA/R+UlWDzfnHFCxxleFT0PMIrR36XLNQ==} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-syntax-nullish-coalescing-operator@7.8.3(@babel/core@7.22.5): - resolution: {integrity: sha512-aSff4zPII1u2QD7y+F8oDsz19ew4IGEJg9SVW+bqwpwtfFleiQDMdzA/R+UlWDzfnHFCxxleFT0PMIrR36XLNQ==} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-syntax-numeric-separator@7.10.4(@babel/core@7.18.13): - resolution: {integrity: sha512-9H6YdfkcK/uOnY/K7/aA2xpzaAgkQn37yzWUMRK7OaPOqOpGS1+n0H5hxT9AUw9EsSjPW8SVyMJwYRtWs3X3ug==} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 + '@babel/helper-builder-binary-assignment-operator-visitor': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-numeric-separator@7.10.4(@babel/core@7.22.5): - resolution: {integrity: sha512-9H6YdfkcK/uOnY/K7/aA2xpzaAgkQn37yzWUMRK7OaPOqOpGS1+n0H5hxT9AUw9EsSjPW8SVyMJwYRtWs3X3ug==} + /@babel/plugin-transform-export-namespace-from/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-X4hhm7FRnPgd4nDA4b/5V280xCx6oL7Oob5+9qVS5C13Zq4bh1qq7LU0GgRU6b5dBWBvhGaXYVB4AcN6+ol6vg==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-export-namespace-from': 7.8.3_@babel+core@7.22.8 dev: true - /@babel/plugin-syntax-object-rest-spread@7.8.3(@babel/core@7.12.9): - resolution: {integrity: sha512-XoqMijGZb9y3y2XskN+P1wUGiVwWZ5JmoDRwx5+3GmEplNyVM2s2Dg8ILFQm8rWM48orGy5YpI5Bl8U1y7ydlA==} + /@babel/plugin-transform-flow-strip-types/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-tujNbZdxdG0/54g/oua8ISToaXTFBf8EnSb5PgQSciIXWOWKX3S4+JR7ZE9ol8FZwf9kxitzkGQ+QWeov/mCiA==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.12.9 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-flow': 7.22.5_@babel+core@7.22.8 dev: true - /@babel/plugin-syntax-object-rest-spread@7.8.3(@babel/core@7.18.13): - resolution: {integrity: sha512-XoqMijGZb9y3y2XskN+P1wUGiVwWZ5JmoDRwx5+3GmEplNyVM2s2Dg8ILFQm8rWM48orGy5YpI5Bl8U1y7ydlA==} + /@babel/plugin-transform-for-of/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-3kxQjX1dU9uudwSshyLeEipvrLjBCVthCgeTp6CzE/9JYrlAIaeekVxRpCWsDDfYTfRZRoCeZatCQvwo+wvK8A==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-object-rest-spread@7.8.3(@babel/core@7.22.5): - resolution: {integrity: sha512-XoqMijGZb9y3y2XskN+P1wUGiVwWZ5JmoDRwx5+3GmEplNyVM2s2Dg8ILFQm8rWM48orGy5YpI5Bl8U1y7ydlA==} + /@babel/plugin-transform-function-name/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-UIzQNMS0p0HHiQm3oelztj+ECwFnj+ZRV4KnguvlsD2of1whUeM6o7wGNj6oLwcDoAXQ8gEqfgC24D+VdIcevg==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 + '@babel/helper-compilation-targets': 7.22.6_@babel+core@7.22.8 + '@babel/helper-function-name': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-optional-catch-binding@7.8.3(@babel/core@7.18.13): - resolution: {integrity: sha512-6VPD0Pc1lpTqw0aKoeRTMiB+kWhAoT24PA+ksWSBrFtl5SIRVpZlwN3NNPQjehA2E/91FV3RjLWoVTglWcSV3Q==} + /@babel/plugin-transform-json-strings/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-DuCRB7fu8MyTLbEQd1ew3R85nx/88yMoqo2uPSjevMj3yoN7CDM8jkgrY0wmVxfJZyJ/B9fE1iq7EQppWQmR5A==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-json-strings': 7.8.3_@babel+core@7.22.8 dev: true - /@babel/plugin-syntax-optional-catch-binding@7.8.3(@babel/core@7.22.5): - resolution: {integrity: sha512-6VPD0Pc1lpTqw0aKoeRTMiB+kWhAoT24PA+ksWSBrFtl5SIRVpZlwN3NNPQjehA2E/91FV3RjLWoVTglWcSV3Q==} + /@babel/plugin-transform-literals/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-fTLj4D79M+mepcw3dgFBTIDYpbcB9Sm0bpm4ppXPaO+U+PKFFyV9MGRvS0gvGw62sd10kT5lRMKXAADb9pWy8g==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-optional-chaining@7.8.3(@babel/core@7.18.13): - resolution: {integrity: sha512-KoK9ErH1MBlCPxV0VANkXW2/dw4vlbGDrFgz8bmUsBGYkFRcbRwMh6cIJubdPrkxRwuGdtCk0v/wPTKbQgBjkg==} + /@babel/plugin-transform-logical-assignment-operators/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-MQQOUW1KL8X0cDWfbwYP+TbVbZm16QmQXJQ+vndPtH/BoO0lOKpVoEDMI7+PskYxH+IiE0tS8xZye0qr1lGzSA==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-logical-assignment-operators': 7.10.4_@babel+core@7.22.8 dev: true - /@babel/plugin-syntax-optional-chaining@7.8.3(@babel/core@7.22.5): - resolution: {integrity: sha512-KoK9ErH1MBlCPxV0VANkXW2/dw4vlbGDrFgz8bmUsBGYkFRcbRwMh6cIJubdPrkxRwuGdtCk0v/wPTKbQgBjkg==} + /@babel/plugin-transform-member-expression-literals/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-RZEdkNtzzYCFl9SE9ATaUMTj2hqMb4StarOJLrZRbqqU4HSBE7UlBw9WBWQiDzrJZJdUWiMTVDI6Gv/8DPvfew==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-private-property-in-object@7.14.5(@babel/core@7.18.13): - resolution: {integrity: sha512-0wVnp9dxJ72ZUJDV27ZfbSj6iHLoytYZmh3rFcxNnvsJF3ktkzLDZPy/mA17HGsaQT3/DQsWYX1f1QGWkCoVUg==} + /@babel/plugin-transform-modules-amd/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-R+PTfLTcYEmb1+kK7FNkhQ1gP4KgjpSO6HfH9+f8/yfp2Nt3ggBjiVpRwmwTlfqZLafYKJACy36yDXlEmI9HjQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 + '@babel/helper-module-transforms': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 + transitivePeerDependencies: + - supports-color dev: true - /@babel/plugin-syntax-private-property-in-object@7.14.5(@babel/core@7.22.5): - resolution: {integrity: sha512-0wVnp9dxJ72ZUJDV27ZfbSj6iHLoytYZmh3rFcxNnvsJF3ktkzLDZPy/mA17HGsaQT3/DQsWYX1f1QGWkCoVUg==} + /@babel/plugin-transform-modules-commonjs/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-B4pzOXj+ONRmuaQTg05b3y/4DuFz3WcCNAXPLb2Q0GT0TrGKGxNKV4jwsXts+StaM0LQczZbOpj8o1DLPDJIiA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 + '@babel/helper-module-transforms': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 + '@babel/helper-simple-access': 7.22.5 + transitivePeerDependencies: + - supports-color dev: true - /@babel/plugin-syntax-top-level-await@7.14.5(@babel/core@7.18.13): - resolution: {integrity: sha512-hx++upLv5U1rgYfwe1xBQUhRmU41NEvpUvrp8jkrSCdvGSnM5/qdRMtylJ6PG5OFkBaHkbTAKTnd3/YyESRHFw==} + /@babel/plugin-transform-modules-systemjs/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-emtEpoaTMsOs6Tzz+nbmcePl6AKVtS1yC4YNAeMun9U8YCsgadPNxnOPQ8GhHFB2qdx+LZu9LgoC0Lthuu05DQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 + '@babel/helper-hoist-variables': 7.22.5 + '@babel/helper-module-transforms': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 + '@babel/helper-validator-identifier': 7.22.5 + transitivePeerDependencies: + - supports-color dev: true - /@babel/plugin-syntax-top-level-await@7.14.5(@babel/core@7.22.5): - resolution: {integrity: sha512-hx++upLv5U1rgYfwe1xBQUhRmU41NEvpUvrp8jkrSCdvGSnM5/qdRMtylJ6PG5OFkBaHkbTAKTnd3/YyESRHFw==} + /@babel/plugin-transform-modules-umd/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-+S6kzefN/E1vkSsKx8kmQuqeQsvCKCd1fraCM7zXm4SFoggI099Tr4G8U81+5gtMdUeMQ4ipdQffbKLX0/7dBQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 + '@babel/helper-module-transforms': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 + transitivePeerDependencies: + - supports-color dev: true - /@babel/plugin-syntax-typescript@7.20.0(@babel/core@7.20.5): - resolution: {integrity: sha512-rd9TkG+u1CExzS4SM1BlMEhMXwFLKVjOAFFCDx9PbX5ycJWDoWMcwdJH9RhkPu1dOgn5TrxLot/Gx6lWFuAUNQ==} + /@babel/plugin-transform-named-capturing-groups-regex/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-YgLLKmS3aUBhHaxp5hi1WJTgOUb/NCuDHzGT9z9WTt3YG+CPRhJs6nprbStx6DnWM4dh6gt7SU3sZodbZ08adQ==} engines: {node: '>=6.9.0'} peerDependencies: - '@babel/core': ^7.0.0-0 + '@babel/core': ^7.0.0 dependencies: - '@babel/core': 7.20.5 + '@babel/core': 7.22.8 + '@babel/helper-create-regexp-features-plugin': 7.22.6_@babel+core@7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-typescript@7.20.0(@babel/core@7.22.5): - resolution: {integrity: sha512-rd9TkG+u1CExzS4SM1BlMEhMXwFLKVjOAFFCDx9PbX5ycJWDoWMcwdJH9RhkPu1dOgn5TrxLot/Gx6lWFuAUNQ==} + /@babel/plugin-transform-new-target/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-AsF7K0Fx/cNKVyk3a+DW0JLo+Ua598/NxMRvxDnkpCIGFh43+h/v2xyhRUYf6oD8gE4QtL83C7zZVghMjHd+iw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-arrow-functions@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-9S9X9RUefzrsHZmKMbDXxweEH+YlE8JJEuat9FdvW9Qh1cw7W64jELCtWNkPBPX5En45uy28KGvA/AySqUh8CQ==} + /@babel/plugin-transform-nullish-coalescing-operator/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-6CF8g6z1dNYZ/VXok5uYkkBBICHZPiGEl7oDnAx2Mt1hlHVHOSIKWJaXHjQJA5VB43KZnXZDIexMchY4y2PGdA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-nullish-coalescing-operator': 7.8.3_@babel+core@7.22.8 dev: true - /@babel/plugin-transform-arrow-functions@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-9S9X9RUefzrsHZmKMbDXxweEH+YlE8JJEuat9FdvW9Qh1cw7W64jELCtWNkPBPX5En45uy28KGvA/AySqUh8CQ==} + /@babel/plugin-transform-numeric-separator/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-NbslED1/6M+sXiwwtcAB/nieypGw02Ejf4KtDeMkCEpP6gWFMX1wI9WKYua+4oBneCCEmulOkRpwywypVZzs/g==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-numeric-separator': 7.10.4_@babel+core@7.22.8 dev: true - /@babel/plugin-transform-async-to-generator@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-ARE5wZLKnTgPW7/1ftQmSi1CmkqqHo2DNmtztFhvgtOWSDfq0Cq9/9L+KnZNYSNrydBekhW3rwShduf59RoXag==} + /@babel/plugin-transform-object-rest-spread/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-Kk3lyDmEslH9DnvCDA1s1kkd3YWQITiBOHngOtDL9Pt6BZjzqb6hiOlb8VfjiiQJ2unmegBqZu0rx5RxJb5vmQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 - '@babel/helper-module-imports': 7.22.5 + '@babel/compat-data': 7.22.6 + '@babel/core': 7.22.8 + '@babel/helper-compilation-targets': 7.22.6_@babel+core@7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-remap-async-to-generator': 7.18.9(@babel/core@7.18.13) - transitivePeerDependencies: - - supports-color + '@babel/plugin-syntax-object-rest-spread': 7.8.3_@babel+core@7.22.8 + '@babel/plugin-transform-parameters': 7.22.5_@babel+core@7.22.8 dev: true - /@babel/plugin-transform-async-to-generator@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-ARE5wZLKnTgPW7/1ftQmSi1CmkqqHo2DNmtztFhvgtOWSDfq0Cq9/9L+KnZNYSNrydBekhW3rwShduf59RoXag==} + /@babel/plugin-transform-object-super/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-klXqyaT9trSjIUrcsYIfETAzmOEZL3cBYqOYLJxBHfMFFggmXOv+NYSX/Jbs9mzMVESw/WycLFPRx8ba/b2Ipw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-module-imports': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-remap-async-to-generator': 7.18.9(@babel/core@7.22.5) + '@babel/helper-replace-supers': 7.22.5 transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-transform-block-scoped-functions@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-ExUcOqpPWnliRcPqves5HJcJOvHvIIWfuS4sroBUenPuMdmW+SMHDakmtS7qOo13sVppmUijqeTv7qqGsvURpQ==} + /@babel/plugin-transform-optional-catch-binding/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-pH8orJahy+hzZje5b8e2QIlBWQvGpelS76C63Z+jhZKsmzfNaPQ+LaW6dcJ9bxTpo1mtXbgHwy765Ro3jftmUg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-optional-catch-binding': 7.8.3_@babel+core@7.22.8 dev: true - /@babel/plugin-transform-block-scoped-functions@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-ExUcOqpPWnliRcPqves5HJcJOvHvIIWfuS4sroBUenPuMdmW+SMHDakmtS7qOo13sVppmUijqeTv7qqGsvURpQ==} + /@babel/plugin-transform-optional-chaining/7.22.6_@babel+core@7.22.8: + resolution: {integrity: sha512-Vd5HiWml0mDVtcLHIoEU5sw6HOUW/Zk0acLs/SAeuLzkGNOPc9DB4nkUajemhCmTIz3eiaKREZn2hQQqF79YTg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 + '@babel/helper-skip-transparent-expression-wrappers': 7.22.5 + '@babel/plugin-syntax-optional-chaining': 7.8.3_@babel+core@7.22.8 dev: true - /@babel/plugin-transform-block-scoping@7.18.9(@babel/core@7.18.13): - resolution: {integrity: sha512-5sDIJRV1KtQVEbt/EIBwGy4T01uYIo4KRB3VUqzkhrAIOGx7AoctL9+Ux88btY0zXdDyPJ9mW+bg+v+XEkGmtw==} + /@babel/plugin-transform-parameters/7.22.5_@babel+core@7.12.9: + resolution: {integrity: sha512-AVkFUBurORBREOmHRKo06FjHYgjrabpdqRSwq6+C7R5iTCZOsM4QbcB27St0a4U6fffyAOqh3s/qEfybAhfivg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.12.9 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-block-scoping@7.18.9(@babel/core@7.22.5): - resolution: {integrity: sha512-5sDIJRV1KtQVEbt/EIBwGy4T01uYIo4KRB3VUqzkhrAIOGx7AoctL9+Ux88btY0zXdDyPJ9mW+bg+v+XEkGmtw==} + /@babel/plugin-transform-parameters/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-AVkFUBurORBREOmHRKo06FjHYgjrabpdqRSwq6+C7R5iTCZOsM4QbcB27St0a4U6fffyAOqh3s/qEfybAhfivg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-classes@7.18.9(@babel/core@7.18.13): - resolution: {integrity: sha512-EkRQxsxoytpTlKJmSPYrsOMjCILacAjtSVkd4gChEe2kXjFCun3yohhW5I7plXJhCemM0gKsaGMcO8tinvCA5g==} + /@babel/plugin-transform-private-methods/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-PPjh4gyrQnGe97JTalgRGMuU4icsZFnWkzicB/fUtzlKUqvsWBKEpPPfr5a2JiyirZkHxnAqkQMO5Z5B2kK3fA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 - '@babel/helper-annotate-as-pure': 7.18.6 - '@babel/helper-environment-visitor': 7.22.5 - '@babel/helper-function-name': 7.22.5 - '@babel/helper-optimise-call-expression': 7.18.6 + '@babel/core': 7.22.8 + '@babel/helper-create-class-features-plugin': 7.22.6_@babel+core@7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-replace-supers': 7.20.7 - '@babel/helper-split-export-declaration': 7.22.5 - globals: 11.12.0 transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-transform-classes@7.18.9(@babel/core@7.22.5): - resolution: {integrity: sha512-EkRQxsxoytpTlKJmSPYrsOMjCILacAjtSVkd4gChEe2kXjFCun3yohhW5I7plXJhCemM0gKsaGMcO8tinvCA5g==} + /@babel/plugin-transform-private-property-in-object/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-/9xnaTTJcVoBtSSmrVyhtSvO3kbqS2ODoh2juEU72c3aYonNF0OMGiaz2gjukyKM2wBBYJP38S4JiE0Wfb5VMQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-annotate-as-pure': 7.18.6 - '@babel/helper-environment-visitor': 7.22.5 - '@babel/helper-function-name': 7.22.5 - '@babel/helper-optimise-call-expression': 7.18.6 + '@babel/core': 7.22.8 + '@babel/helper-annotate-as-pure': 7.22.5 + '@babel/helper-create-class-features-plugin': 7.22.6_@babel+core@7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-replace-supers': 7.20.7 - '@babel/helper-split-export-declaration': 7.22.5 - globals: 11.12.0 + '@babel/plugin-syntax-private-property-in-object': 7.14.5_@babel+core@7.22.8 transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-transform-computed-properties@7.18.9(@babel/core@7.18.13): - resolution: {integrity: sha512-+i0ZU1bCDymKakLxn5srGHrsAPRELC2WIbzwjLhHW9SIE1cPYkLCL0NlnXMZaM1vhfgA2+M7hySk42VBvrkBRw==} + /@babel/plugin-transform-property-literals/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-TiOArgddK3mK/x1Qwf5hay2pxI6wCZnvQqrFSqbtg1GLl2JcNMitVH/YnqjP+M31pLUeTfzY1HAXFDnUBV30rQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-computed-properties@7.18.9(@babel/core@7.22.5): - resolution: {integrity: sha512-+i0ZU1bCDymKakLxn5srGHrsAPRELC2WIbzwjLhHW9SIE1cPYkLCL0NlnXMZaM1vhfgA2+M7hySk42VBvrkBRw==} + /@babel/plugin-transform-react-display-name/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-PVk3WPYudRF5z4GKMEYUrLjPl38fJSKNaEOkFuoprioowGuWN6w2RKznuFNSlJx7pzzXXStPUnNSOEO0jL5EVw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-destructuring@7.18.13(@babel/core@7.18.13): - resolution: {integrity: sha512-TodpQ29XekIsex2A+YJPj5ax2plkGa8YYY6mFjCohk/IG9IY42Rtuj1FuDeemfg2ipxIFLzPeA83SIBnlhSIow==} + /@babel/plugin-transform-react-jsx-development/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-bDhuzwWMuInwCYeDeMzyi7TaBgRQei6DqxhbyniL7/VG4RSS7HtSL2QbY4eESy1KJqlWt8g3xeEBGPuo+XqC8A==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 - '@babel/helper-plugin-utils': 7.22.5 + '@babel/core': 7.22.8 + '@babel/plugin-transform-react-jsx': 7.22.5_@babel+core@7.22.8 dev: true - /@babel/plugin-transform-destructuring@7.18.13(@babel/core@7.22.5): - resolution: {integrity: sha512-TodpQ29XekIsex2A+YJPj5ax2plkGa8YYY6mFjCohk/IG9IY42Rtuj1FuDeemfg2ipxIFLzPeA83SIBnlhSIow==} + /@babel/plugin-transform-react-jsx-self/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-nTh2ogNUtxbiSbxaT4Ds6aXnXEipHweN9YRgOX/oNXdf0cCrGn/+2LozFa3lnPV5D90MkjhgckCPBrsoSc1a7g==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-dotall-regex@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-6S3jpun1eEbAxq7TdjLotAsl4WpQI9DxfkycRcKrjhQYzU87qpXdknpBg/e+TdcMehqGnLFi7tnFUBR02Vq6wg==} + /@babel/plugin-transform-react-jsx-source/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-yIiRO6yobeEIaI0RTbIr8iAK9FcBHLtZq0S89ZPjDLQXBA4xvghaKqI0etp/tF3htTM0sazJKKLz9oEiGRtu7w==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 - '@babel/helper-create-regexp-features-plugin': 7.18.6(@babel/core@7.18.13) + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-dotall-regex@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-6S3jpun1eEbAxq7TdjLotAsl4WpQI9DxfkycRcKrjhQYzU87qpXdknpBg/e+TdcMehqGnLFi7tnFUBR02Vq6wg==} + /@babel/plugin-transform-react-jsx/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-rog5gZaVbUip5iWDMTYbVM15XQq+RkUKhET/IHR6oizR+JEoN6CAfTTuHcK4vwUyzca30qqHqEpzBOnaRMWYMA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-create-regexp-features-plugin': 7.18.6(@babel/core@7.22.5) + '@babel/core': 7.22.8 + '@babel/helper-annotate-as-pure': 7.22.5 + '@babel/helper-module-imports': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-jsx': 7.22.5_@babel+core@7.22.8 + '@babel/types': 7.22.5 dev: true - /@babel/plugin-transform-duplicate-keys@7.18.9(@babel/core@7.18.13): - resolution: {integrity: sha512-d2bmXCtZXYc59/0SanQKbiWINadaJXqtvIQIzd4+hNwkWBgyCd5F/2t1kXoUdvPMrxzPvhK6EMQRROxsue+mfw==} + /@babel/plugin-transform-react-pure-annotations/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-gP4k85wx09q+brArVinTXhWiyzLl9UpmGva0+mWyKxk6JZequ05x3eUcIUE+FyttPKJFRRVtAvQaJ6YF9h1ZpA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 + '@babel/helper-annotate-as-pure': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-duplicate-keys@7.18.9(@babel/core@7.22.5): - resolution: {integrity: sha512-d2bmXCtZXYc59/0SanQKbiWINadaJXqtvIQIzd4+hNwkWBgyCd5F/2t1kXoUdvPMrxzPvhK6EMQRROxsue+mfw==} + /@babel/plugin-transform-regenerator/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-rR7KePOE7gfEtNTh9Qw+iO3Q/e4DEsoQ+hdvM6QUDH7JRJ5qxq5AA52ZzBWbI5i9lfNuvySgOGP8ZN7LAmaiPw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 + regenerator-transform: 0.15.1 dev: true - /@babel/plugin-transform-exponentiation-operator@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-wzEtc0+2c88FVR34aQmiz56dxEkxr2g8DQb/KfaFa1JYXOFVsbhvAonFN6PwVWj++fKmku8NP80plJ5Et4wqHw==} + /@babel/plugin-transform-reserved-words/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-DTtGKFRQUDm8svigJzZHzb/2xatPc6TzNvAIJ5GqOKDsGFYgAskjRulbR/vGsPKq3OPqtexnz327qYpP57RFyA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 - '@babel/helper-builder-binary-assignment-operator-visitor': 7.18.9 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-exponentiation-operator@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-wzEtc0+2c88FVR34aQmiz56dxEkxr2g8DQb/KfaFa1JYXOFVsbhvAonFN6PwVWj++fKmku8NP80plJ5Et4wqHw==} + /@babel/plugin-transform-shorthand-properties/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-vM4fq9IXHscXVKzDv5itkO1X52SmdFBFcMIBZ2FRn2nqVYqw6dBexUgMvAjHW+KXpPPViD/Yo3GrDEBaRC0QYA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-builder-binary-assignment-operator-visitor': 7.18.9 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-flow-strip-types@7.18.9(@babel/core@7.18.13): - resolution: {integrity: sha512-+G6rp2zRuOAInY5wcggsx4+QVao1qPM0osC9fTUVlAV3zOrzTCnrMAFVnR6+a3T8wz1wFIH7KhYMcMB3u1n80A==} + /@babel/plugin-transform-spread/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-5ZzDQIGyvN4w8+dMmpohL6MBo+l2G7tfC/O2Dg7/hjpgeWvUx8FzfeOKxGog9IimPa4YekaQ9PlDqTLOljkcxg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-flow': 7.18.6(@babel/core@7.18.13) + '@babel/helper-skip-transparent-expression-wrappers': 7.22.5 dev: true - /@babel/plugin-transform-for-of@7.18.8(@babel/core@7.18.13): - resolution: {integrity: sha512-yEfTRnjuskWYo0k1mHUqrVWaZwrdq8AYbfrpqULOJOaucGSp4mNMVps+YtA8byoevxS/urwU75vyhQIxcCgiBQ==} + /@babel/plugin-transform-sticky-regex/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-zf7LuNpHG0iEeiyCNwX4j3gDg1jgt1k3ZdXBKbZSoA3BbGQGvMiSvfbZRR3Dr3aeJe3ooWFZxOOG3IRStYp2Bw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-for-of@7.18.8(@babel/core@7.22.5): - resolution: {integrity: sha512-yEfTRnjuskWYo0k1mHUqrVWaZwrdq8AYbfrpqULOJOaucGSp4mNMVps+YtA8byoevxS/urwU75vyhQIxcCgiBQ==} + /@babel/plugin-transform-template-literals/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-5ciOehRNf+EyUeewo8NkbQiUs4d6ZxiHo6BcBcnFlgiJfu16q0bQUw9Jvo0b0gBKFG1SMhDSjeKXSYuJLeFSMA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-function-name@7.18.9(@babel/core@7.18.13): - resolution: {integrity: sha512-WvIBoRPaJQ5yVHzcnJFor7oS5Ls0PYixlTYE63lCj2RtdQEl15M68FXQlxnG6wdraJIXRdR7KI+hQ7q/9QjrCQ==} + /@babel/plugin-transform-typeof-symbol/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-bYkI5lMzL4kPii4HHEEChkD0rkc+nvnlR6+o/qdqR6zrm0Sv/nodmyLhlq2DO0YKLUNd2VePmPRjJXSBh9OIdA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 - '@babel/helper-compilation-targets': 7.22.5(@babel/core@7.18.13) - '@babel/helper-function-name': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-function-name@7.18.9(@babel/core@7.22.5): - resolution: {integrity: sha512-WvIBoRPaJQ5yVHzcnJFor7oS5Ls0PYixlTYE63lCj2RtdQEl15M68FXQlxnG6wdraJIXRdR7KI+hQ7q/9QjrCQ==} + /@babel/plugin-transform-typescript/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-SMubA9S7Cb5sGSFFUlqxyClTA9zWJ8qGQrppNUm05LtFuN1ELRFNndkix4zUJrC9F+YivWwa1dHMSyo0e0N9dA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-compilation-targets': 7.22.5(@babel/core@7.22.5) - '@babel/helper-function-name': 7.22.5 + '@babel/core': 7.22.8 + '@babel/helper-annotate-as-pure': 7.22.5 + '@babel/helper-create-class-features-plugin': 7.22.6_@babel+core@7.22.8 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-typescript': 7.22.5_@babel+core@7.22.8 + transitivePeerDependencies: + - supports-color dev: true - /@babel/plugin-transform-literals@7.18.9(@babel/core@7.18.13): - resolution: {integrity: sha512-IFQDSRoTPnrAIrI5zoZv73IFeZu2dhu6irxQjY9rNjTT53VmKg9fenjvoiOWOkJ6mm4jKVPtdMzBY98Fp4Z4cg==} + /@babel/plugin-transform-unicode-escapes/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-biEmVg1IYB/raUO5wT1tgfacCef15Fbzhkx493D3urBI++6hpJ+RFG4SrWMn0NEZLfvilqKf3QDrRVZHo08FYg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-literals@7.18.9(@babel/core@7.22.5): - resolution: {integrity: sha512-IFQDSRoTPnrAIrI5zoZv73IFeZu2dhu6irxQjY9rNjTT53VmKg9fenjvoiOWOkJ6mm4jKVPtdMzBY98Fp4Z4cg==} + /@babel/plugin-transform-unicode-property-regex/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-HCCIb+CbJIAE6sXn5CjFQXMwkCClcOfPCzTlilJ8cUatfzwHlWQkbtV0zD338u9dZskwvuOYTuuaMaA8J5EI5A==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 + '@babel/helper-create-regexp-features-plugin': 7.22.6_@babel+core@7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-member-expression-literals@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-qSF1ihLGO3q+/g48k85tUjD033C29TNTVB2paCwZPVmOsjn9pClvYYrM2VeJpBY2bcNkuny0YUyTNRyRxJ54KA==} + /@babel/plugin-transform-unicode-regex/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-028laaOKptN5vHJf9/Arr/HiJekMd41hOEZYvNsrsXqJ7YPYuX2bQxh31fkZzGmq3YqHRJzYFFAVYvKfMPKqyg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 + '@babel/helper-create-regexp-features-plugin': 7.22.6_@babel+core@7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-member-expression-literals@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-qSF1ihLGO3q+/g48k85tUjD033C29TNTVB2paCwZPVmOsjn9pClvYYrM2VeJpBY2bcNkuny0YUyTNRyRxJ54KA==} + /@babel/plugin-transform-unicode-sets-regex/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-lhMfi4FC15j13eKrh3DnYHjpGj6UKQHtNKTbtc1igvAhRy4+kLhV07OpLcsN0VgDEw/MjAvJO4BdMJsHwMhzCg==} engines: {node: '>=6.9.0'} peerDependencies: - '@babel/core': ^7.0.0-0 + '@babel/core': ^7.0.0 dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 + '@babel/helper-create-regexp-features-plugin': 7.22.6_@babel+core@7.22.8 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-modules-amd@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-Pra5aXsmTsOnjM3IajS8rTaLCy++nGM4v3YR4esk5PCsyg9z8NA5oQLwxzMUtDBd8F+UmVza3VxoAaWCbzH1rg==} + /@babel/preset-env/7.22.7_@babel+core@7.22.8: + resolution: {integrity: sha512-1whfDtW+CzhETuzYXfcgZAh8/GFMeEbz0V5dVgya8YeJyCU6Y/P2Gnx4Qb3MylK68Zu9UiwUvbPMPTpFAOJ+sQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 - '@babel/helper-module-transforms': 7.22.5 + '@babel/compat-data': 7.22.6 + '@babel/core': 7.22.8 + '@babel/helper-compilation-targets': 7.22.6_@babel+core@7.22.8 '@babel/helper-plugin-utils': 7.22.5 - babel-plugin-dynamic-import-node: 2.3.3 + '@babel/helper-validator-option': 7.22.5 + '@babel/plugin-bugfix-safari-id-destructuring-collision-in-function-expression': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-bugfix-v8-spread-parameters-in-optional-chaining': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-proposal-private-property-in-object': 7.21.0-placeholder-for-preset-env.2_@babel+core@7.22.8 + '@babel/plugin-syntax-async-generators': 7.8.4_@babel+core@7.22.8 + '@babel/plugin-syntax-class-properties': 7.12.13_@babel+core@7.22.8 + '@babel/plugin-syntax-class-static-block': 7.14.5_@babel+core@7.22.8 + '@babel/plugin-syntax-dynamic-import': 7.8.3_@babel+core@7.22.8 + '@babel/plugin-syntax-export-namespace-from': 7.8.3_@babel+core@7.22.8 + '@babel/plugin-syntax-import-assertions': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-syntax-import-attributes': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-syntax-import-meta': 7.10.4_@babel+core@7.22.8 + '@babel/plugin-syntax-json-strings': 7.8.3_@babel+core@7.22.8 + '@babel/plugin-syntax-logical-assignment-operators': 7.10.4_@babel+core@7.22.8 + '@babel/plugin-syntax-nullish-coalescing-operator': 7.8.3_@babel+core@7.22.8 + '@babel/plugin-syntax-numeric-separator': 7.10.4_@babel+core@7.22.8 + '@babel/plugin-syntax-object-rest-spread': 7.8.3_@babel+core@7.22.8 + '@babel/plugin-syntax-optional-catch-binding': 7.8.3_@babel+core@7.22.8 + '@babel/plugin-syntax-optional-chaining': 7.8.3_@babel+core@7.22.8 + '@babel/plugin-syntax-private-property-in-object': 7.14.5_@babel+core@7.22.8 + '@babel/plugin-syntax-top-level-await': 7.14.5_@babel+core@7.22.8 + '@babel/plugin-syntax-unicode-sets-regex': 7.18.6_@babel+core@7.22.8 + '@babel/plugin-transform-arrow-functions': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-async-generator-functions': 7.22.7_@babel+core@7.22.8 + '@babel/plugin-transform-async-to-generator': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-block-scoped-functions': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-block-scoping': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-class-properties': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-class-static-block': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-classes': 7.22.6_@babel+core@7.22.8 + '@babel/plugin-transform-computed-properties': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-destructuring': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-dotall-regex': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-duplicate-keys': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-dynamic-import': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-exponentiation-operator': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-export-namespace-from': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-for-of': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-function-name': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-json-strings': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-literals': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-logical-assignment-operators': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-member-expression-literals': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-modules-amd': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-modules-commonjs': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-modules-systemjs': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-modules-umd': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-named-capturing-groups-regex': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-new-target': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-nullish-coalescing-operator': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-numeric-separator': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-object-rest-spread': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-object-super': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-optional-catch-binding': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-optional-chaining': 7.22.6_@babel+core@7.22.8 + '@babel/plugin-transform-parameters': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-private-methods': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-private-property-in-object': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-property-literals': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-regenerator': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-reserved-words': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-shorthand-properties': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-spread': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-sticky-regex': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-template-literals': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-typeof-symbol': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-unicode-escapes': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-unicode-property-regex': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-unicode-regex': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-unicode-sets-regex': 7.22.5_@babel+core@7.22.8 + '@babel/preset-modules': 0.1.5_@babel+core@7.22.8 + '@babel/types': 7.22.5 + '@nicolo-ribaudo/semver-v6': 6.3.3 + babel-plugin-polyfill-corejs2: 0.4.4_@babel+core@7.22.8 + babel-plugin-polyfill-corejs3: 0.8.2_@babel+core@7.22.8 + babel-plugin-polyfill-regenerator: 0.5.1_@babel+core@7.22.8 + core-js-compat: 3.31.1 transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-transform-modules-amd@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-Pra5aXsmTsOnjM3IajS8rTaLCy++nGM4v3YR4esk5PCsyg9z8NA5oQLwxzMUtDBd8F+UmVza3VxoAaWCbzH1rg==} + /@babel/preset-flow/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-ta2qZ+LSiGCrP5pgcGt8xMnnkXQrq8Sa4Ulhy06BOlF5QbLw9q5hIx7bn5MrsvyTGAfh6kTOo07Q+Pfld/8Y5Q==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-module-transforms': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - babel-plugin-dynamic-import-node: 2.3.3 - transitivePeerDependencies: - - supports-color + '@babel/helper-validator-option': 7.22.5 + '@babel/plugin-transform-flow-strip-types': 7.22.5_@babel+core@7.22.8 dev: true - /@babel/plugin-transform-modules-commonjs@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-Qfv2ZOWikpvmedXQJDSbxNqy7Xr/j2Y8/KfijM0iJyKkBTmWuvCA1yeH1yDM7NJhBW/2aXxeucLj6i80/LAJ/Q==} - engines: {node: '>=6.9.0'} + /@babel/preset-modules/0.1.5_@babel+core@7.22.8: + resolution: {integrity: sha512-A57th6YRG7oR3cq/yt/Y84MvGgE0eJG2F1JLhKuyG+jFxEgrd/HAMJatiFtmOiZurz+0DkrvbheCLaV5f2JfjA==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 - '@babel/helper-module-transforms': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-simple-access': 7.22.5 - babel-plugin-dynamic-import-node: 2.3.3 - transitivePeerDependencies: - - supports-color + '@babel/plugin-proposal-unicode-property-regex': 7.18.6_@babel+core@7.22.8 + '@babel/plugin-transform-dotall-regex': 7.22.5_@babel+core@7.22.8 + '@babel/types': 7.22.5 + esutils: 2.0.3 dev: true - /@babel/plugin-transform-modules-commonjs@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-Qfv2ZOWikpvmedXQJDSbxNqy7Xr/j2Y8/KfijM0iJyKkBTmWuvCA1yeH1yDM7NJhBW/2aXxeucLj6i80/LAJ/Q==} + /@babel/preset-react/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-M+Is3WikOpEJHgR385HbuCITPTaPRaNkibTEa9oiofmJvIsrceb4yp9RL9Kb+TE8LznmeyZqpP+Lopwcx59xPQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-module-transforms': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-simple-access': 7.22.5 - babel-plugin-dynamic-import-node: 2.3.3 - transitivePeerDependencies: - - supports-color + '@babel/helper-validator-option': 7.22.5 + '@babel/plugin-transform-react-display-name': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-react-jsx': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-react-jsx-development': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-react-pure-annotations': 7.22.5_@babel+core@7.22.8 dev: true - /@babel/plugin-transform-modules-systemjs@7.18.9(@babel/core@7.18.13): - resolution: {integrity: sha512-zY/VSIbbqtoRoJKo2cDTewL364jSlZGvn0LKOf9ntbfxOvjfmyrdtEEOAdswOswhZEb8UH3jDkCKHd1sPgsS0A==} + /@babel/preset-typescript/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-YbPaal9LxztSGhmndR46FmAbkJ/1fAsw293tSU+I5E5h+cnJ3d4GTwyUgGYmOXJYdGA+uNePle4qbaRzj2NISQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 - '@babel/helper-hoist-variables': 7.22.5 - '@babel/helper-module-transforms': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-validator-identifier': 7.22.5 - babel-plugin-dynamic-import-node: 2.3.3 + '@babel/helper-validator-option': 7.22.5 + '@babel/plugin-syntax-jsx': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-modules-commonjs': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-typescript': 7.22.5_@babel+core@7.22.8 transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-transform-modules-systemjs@7.18.9(@babel/core@7.22.5): - resolution: {integrity: sha512-zY/VSIbbqtoRoJKo2cDTewL364jSlZGvn0LKOf9ntbfxOvjfmyrdtEEOAdswOswhZEb8UH3jDkCKHd1sPgsS0A==} + /@babel/register/7.22.5_@babel+core@7.22.8: + resolution: {integrity: sha512-vV6pm/4CijSQ8Y47RH5SopXzursN35RQINfGJkmOlcpAtGuf94miFvIPhCKGQN7WGIcsgG1BHEX2KVdTYwTwUQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-hoist-variables': 7.22.5 - '@babel/helper-module-transforms': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-validator-identifier': 7.22.5 - babel-plugin-dynamic-import-node: 2.3.3 - transitivePeerDependencies: - - supports-color + '@babel/core': 7.22.8 + clone-deep: 4.0.1 + find-cache-dir: 2.1.0 + make-dir: 2.1.0 + pirates: 4.0.6 + source-map-support: 0.5.21 + dev: true + + /@babel/regjsgen/0.8.0: + resolution: {integrity: sha512-x/rqGMdzj+fWZvCOYForTghzbtqPDZ5gPwaoNGHdgDfF2QA/XZbCBp4Moo5scrkAMPhB7z26XM/AaHuIJdgauA==} dev: true - /@babel/plugin-transform-modules-umd@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-dcegErExVeXcRqNtkRU/z8WlBLnvD4MRnHgNs3MytRO1Mn1sHRyhbcpYbVMGclAqOjdW+9cfkdZno9dFdfKLfQ==} + /@babel/runtime/7.22.6: + resolution: {integrity: sha512-wDb5pWm4WDdF6LFUde3Jl8WzPA+3ZbxYqkC6xAXuD3irdEHN1k0NfTRrJD8ZD378SJ61miMLCqIOXYhd8x+AJQ==} engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 - '@babel/helper-module-transforms': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - transitivePeerDependencies: - - supports-color - dev: true + regenerator-runtime: 0.13.11 - /@babel/plugin-transform-modules-umd@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-dcegErExVeXcRqNtkRU/z8WlBLnvD4MRnHgNs3MytRO1Mn1sHRyhbcpYbVMGclAqOjdW+9cfkdZno9dFdfKLfQ==} + /@babel/template/7.22.5: + resolution: {integrity: sha512-X7yV7eiwAxdj9k94NEylvbVHLiVG1nvzCV2EAowhxLTwODV1jl9UzZ48leOC0sH7OnuHrIkllaBgneUykIcZaw==} engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-module-transforms': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 + '@babel/code-frame': 7.22.5 + '@babel/parser': 7.22.7 + '@babel/types': 7.22.5 + + /@babel/traverse/7.22.8: + resolution: {integrity: sha512-y6LPR+wpM2I3qJrsheCTwhIinzkETbplIgPBbwvqPKc+uljeA5gP+3nP8irdYt1mjQaDnlIcG+dw8OjAco4GXw==} + engines: {node: '>=6.9.0'} + dependencies: + '@babel/code-frame': 7.22.5 + '@babel/generator': 7.22.7 + '@babel/helper-environment-visitor': 7.22.5 + '@babel/helper-function-name': 7.22.5 + '@babel/helper-hoist-variables': 7.22.5 + '@babel/helper-split-export-declaration': 7.22.6 + '@babel/parser': 7.22.7 + '@babel/types': 7.22.5 + debug: 4.3.4 + globals: 11.12.0 transitivePeerDependencies: - supports-color - dev: true - /@babel/plugin-transform-named-capturing-groups-regex@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-UmEOGF8XgaIqD74bC8g7iV3RYj8lMf0Bw7NJzvnS9qQhM4mg+1WHKotUIdjxgD2RGrgFLZZPCFPFj3P/kVDYhg==} + /@babel/types/7.22.5: + resolution: {integrity: sha512-zo3MIHGOkPOfoRXitsgHLjEXmlDaD/5KU1Uzuc9GNiZPhSqVxVRtxuPaSBZDsYZ9qV88AjtMtWW7ww98loJ9KA==} engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0 dependencies: - '@babel/core': 7.18.13 - '@babel/helper-create-regexp-features-plugin': 7.18.6(@babel/core@7.18.13) - '@babel/helper-plugin-utils': 7.22.5 + '@babel/helper-string-parser': 7.22.5 + '@babel/helper-validator-identifier': 7.22.5 + to-fast-properties: 2.0.0 + + /@base2/pretty-print-object/1.0.1: + resolution: {integrity: sha512-4iri8i1AqYHJE2DstZYkyEprg6Pq6sKx3xn5FpySk9sNhH7qN2LLlHJCfDTZRILNwQNPD7mATWM0TBui7uC1pA==} dev: true - /@babel/plugin-transform-named-capturing-groups-regex@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-UmEOGF8XgaIqD74bC8g7iV3RYj8lMf0Bw7NJzvnS9qQhM4mg+1WHKotUIdjxgD2RGrgFLZZPCFPFj3P/kVDYhg==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-create-regexp-features-plugin': 7.18.6(@babel/core@7.22.5) - '@babel/helper-plugin-utils': 7.22.5 + /@bcoe/v8-coverage/0.2.3: + resolution: {integrity: sha512-0hYQ8SB4Db5zvZB4axdMHGwEaQjkZzFjQiN9LVYvIFB2nSUHW9tYpxWriPrWDASIxiaXax83REcLxuSdnGPZtw==} + + /@canvas/image-data/1.0.0: + resolution: {integrity: sha512-BxOqI5LgsIQP1odU5KMwV9yoijleOPzHL18/YvNqF9KFSGF2K/DLlYAbDQsWqd/1nbaFuSkYD/191dpMtNh4vw==} dev: true - /@babel/plugin-transform-new-target@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-DjwFA/9Iu3Z+vrAn+8pBUGcjhxKguSMlsFqeCKbhb9BAV756v0krzVK04CRDi/4aqmk8BsHb4a/gFcaA5joXRw==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 + /@cnakazawa/watch/1.0.4: + resolution: {integrity: sha512-v9kIhKwjeZThiWrLmj0y17CWoyddASLj9O2yvbZkbvw/N3rWOYy9zkV66ursAoVr0mV15bL8g0c4QZUE6cdDoQ==} + engines: {node: '>=0.1.95'} + hasBin: true dependencies: - '@babel/core': 7.18.13 - '@babel/helper-plugin-utils': 7.22.5 + exec-sh: 0.3.6 + minimist: 1.2.8 dev: true - /@babel/plugin-transform-new-target@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-DjwFA/9Iu3Z+vrAn+8pBUGcjhxKguSMlsFqeCKbhb9BAV756v0krzVK04CRDi/4aqmk8BsHb4a/gFcaA5joXRw==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 + /@colors/colors/1.5.0: + resolution: {integrity: sha512-ooWCrlZP11i8GImSjTHYHLkvFDP48nS4+204nGb1RiX/WXYHmJA2III9/e2DWVabCESdW7hBAEzHRqUn9OUVvQ==} + engines: {node: '>=0.1.90'} + requiresBuild: true dev: true + optional: true - /@babel/plugin-transform-object-super@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-uvGz6zk+pZoS1aTZrOvrbj6Pp/kK2mp45t2B+bTDre2UgsZZ8EZLSJtUg7m/no0zOJUWgFONpB7Zv9W2tSaFlA==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 + /@cspotcode/source-map-support/0.8.1: + resolution: {integrity: sha512-IchNf6dN4tHoMFIn/7OE8LWZ19Y6q/67Bmf6vnGREv8RSbBVb9LPJxEcnwrcwX6ixSvaiGoomAUvu4YSxXrVgw==} + engines: {node: '>=12'} dependencies: - '@babel/core': 7.18.13 - '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-replace-supers': 7.20.7 - transitivePeerDependencies: - - supports-color + '@jridgewell/trace-mapping': 0.3.9 dev: true - /@babel/plugin-transform-object-super@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-uvGz6zk+pZoS1aTZrOvrbj6Pp/kK2mp45t2B+bTDre2UgsZZ8EZLSJtUg7m/no0zOJUWgFONpB7Zv9W2tSaFlA==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-replace-supers': 7.20.7 - transitivePeerDependencies: - - supports-color - dev: true - - /@babel/plugin-transform-parameters@7.18.8(@babel/core@7.12.9): - resolution: {integrity: sha512-ivfbE3X2Ss+Fj8nnXvKJS6sjRG4gzwPMsP+taZC+ZzEGjAYlvENixmt1sZ5Ca6tWls+BlKSGKPJ6OOXvXCbkFg==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.12.9 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-transform-parameters@7.18.8(@babel/core@7.18.13): - resolution: {integrity: sha512-ivfbE3X2Ss+Fj8nnXvKJS6sjRG4gzwPMsP+taZC+ZzEGjAYlvENixmt1sZ5Ca6tWls+BlKSGKPJ6OOXvXCbkFg==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-transform-parameters@7.18.8(@babel/core@7.22.5): - resolution: {integrity: sha512-ivfbE3X2Ss+Fj8nnXvKJS6sjRG4gzwPMsP+taZC+ZzEGjAYlvENixmt1sZ5Ca6tWls+BlKSGKPJ6OOXvXCbkFg==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-transform-property-literals@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-cYcs6qlgafTud3PAzrrRNbQtfpQ8+y/+M5tKmksS9+M1ckbH6kzY8MrexEM9mcA6JDsukE19iIRvAyYl463sMg==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-transform-property-literals@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-cYcs6qlgafTud3PAzrrRNbQtfpQ8+y/+M5tKmksS9+M1ckbH6kzY8MrexEM9mcA6JDsukE19iIRvAyYl463sMg==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-transform-react-display-name@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-TV4sQ+T013n61uMoygyMRm+xf04Bd5oqFpv2jAEQwSZ8NwQA7zeRPg1LMVg2PWi3zWBz+CLKD+v5bcpZ/BS0aA==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-transform-react-display-name@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-TV4sQ+T013n61uMoygyMRm+xf04Bd5oqFpv2jAEQwSZ8NwQA7zeRPg1LMVg2PWi3zWBz+CLKD+v5bcpZ/BS0aA==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-transform-react-jsx-development@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-SA6HEjwYFKF7WDjWcMcMGUimmw/nhNRDWxr+KaLSCrkD/LMDBvWRmHAYgE1HDeF8KUuI8OAu+RT6EOtKxSW2qA==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/plugin-transform-react-jsx': 7.19.0(@babel/core@7.18.13) - dev: true - - /@babel/plugin-transform-react-jsx-development@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-SA6HEjwYFKF7WDjWcMcMGUimmw/nhNRDWxr+KaLSCrkD/LMDBvWRmHAYgE1HDeF8KUuI8OAu+RT6EOtKxSW2qA==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/plugin-transform-react-jsx': 7.19.0(@babel/core@7.22.5) - dev: true - - /@babel/plugin-transform-react-jsx-self@7.22.5(@babel/core@7.22.5): - resolution: {integrity: sha512-nTh2ogNUtxbiSbxaT4Ds6aXnXEipHweN9YRgOX/oNXdf0cCrGn/+2LozFa3lnPV5D90MkjhgckCPBrsoSc1a7g==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-transform-react-jsx-source@7.22.5(@babel/core@7.22.5): - resolution: {integrity: sha512-yIiRO6yobeEIaI0RTbIr8iAK9FcBHLtZq0S89ZPjDLQXBA4xvghaKqI0etp/tF3htTM0sazJKKLz9oEiGRtu7w==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-transform-react-jsx@7.18.10(@babel/core@7.22.5): - resolution: {integrity: sha512-gCy7Iikrpu3IZjYZolFE4M1Sm+nrh1/6za2Ewj77Z+XirT4TsbJcvOFOyF+fRPwU6AKKK136CZxx6L8AbSFG6A==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-annotate-as-pure': 7.18.6 - '@babel/helper-module-imports': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-jsx': 7.18.6(@babel/core@7.22.5) - '@babel/types': 7.22.5 - dev: true - - /@babel/plugin-transform-react-jsx@7.19.0(@babel/core@7.18.13): - resolution: {integrity: sha512-UVEvX3tXie3Szm3emi1+G63jyw1w5IcMY0FSKM+CRnKRI5Mr1YbCNgsSTwoTwKphQEG9P+QqmuRFneJPZuHNhg==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-annotate-as-pure': 7.18.6 - '@babel/helper-module-imports': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-jsx': 7.18.6(@babel/core@7.18.13) - '@babel/types': 7.22.5 - dev: true - - /@babel/plugin-transform-react-jsx@7.19.0(@babel/core@7.22.5): - resolution: {integrity: sha512-UVEvX3tXie3Szm3emi1+G63jyw1w5IcMY0FSKM+CRnKRI5Mr1YbCNgsSTwoTwKphQEG9P+QqmuRFneJPZuHNhg==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-annotate-as-pure': 7.18.6 - '@babel/helper-module-imports': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-jsx': 7.18.6(@babel/core@7.22.5) - '@babel/types': 7.22.5 - dev: true - - /@babel/plugin-transform-react-pure-annotations@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-I8VfEPg9r2TRDdvnHgPepTKvuRomzA8+u+nhY7qSI1fR2hRNebasZEETLyM5mAUr0Ku56OkXJ0I7NHJnO6cJiQ==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-annotate-as-pure': 7.18.6 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-transform-react-pure-annotations@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-I8VfEPg9r2TRDdvnHgPepTKvuRomzA8+u+nhY7qSI1fR2hRNebasZEETLyM5mAUr0Ku56OkXJ0I7NHJnO6cJiQ==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-annotate-as-pure': 7.18.6 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-transform-regenerator@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-poqRI2+qiSdeldcz4wTSTXBRryoq3Gc70ye7m7UD5Ww0nE29IXqMl6r7Nd15WBgRd74vloEMlShtH6CKxVzfmQ==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-plugin-utils': 7.22.5 - regenerator-transform: 0.15.0 - dev: true - - /@babel/plugin-transform-regenerator@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-poqRI2+qiSdeldcz4wTSTXBRryoq3Gc70ye7m7UD5Ww0nE29IXqMl6r7Nd15WBgRd74vloEMlShtH6CKxVzfmQ==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - regenerator-transform: 0.15.0 - dev: true - - /@babel/plugin-transform-reserved-words@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-oX/4MyMoypzHjFrT1CdivfKZ+XvIPMFXwwxHp/r0Ddy2Vuomt4HDFGmft1TAY2yiTKiNSsh3kjBAzcM8kSdsjA==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-transform-reserved-words@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-oX/4MyMoypzHjFrT1CdivfKZ+XvIPMFXwwxHp/r0Ddy2Vuomt4HDFGmft1TAY2yiTKiNSsh3kjBAzcM8kSdsjA==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-transform-shorthand-properties@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-eCLXXJqv8okzg86ywZJbRn19YJHU4XUa55oz2wbHhaQVn/MM+XhukiT7SYqp/7o00dg52Rj51Ny+Ecw4oyoygw==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-transform-shorthand-properties@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-eCLXXJqv8okzg86ywZJbRn19YJHU4XUa55oz2wbHhaQVn/MM+XhukiT7SYqp/7o00dg52Rj51Ny+Ecw4oyoygw==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-transform-spread@7.18.9(@babel/core@7.18.13): - resolution: {integrity: sha512-39Q814wyoOPtIB/qGopNIL9xDChOE1pNU0ZY5dO0owhiVt/5kFm4li+/bBtwc7QotG0u5EPzqhZdjMtmqBqyQA==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-skip-transparent-expression-wrappers': 7.20.0 - dev: true - - /@babel/plugin-transform-spread@7.18.9(@babel/core@7.22.5): - resolution: {integrity: sha512-39Q814wyoOPtIB/qGopNIL9xDChOE1pNU0ZY5dO0owhiVt/5kFm4li+/bBtwc7QotG0u5EPzqhZdjMtmqBqyQA==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-skip-transparent-expression-wrappers': 7.20.0 - dev: true - - /@babel/plugin-transform-sticky-regex@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-kfiDrDQ+PBsQDO85yj1icueWMfGfJFKN1KCkndygtu/C9+XUfydLC8Iv5UYJqRwy4zk8EcplRxEOeLyjq1gm6Q==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-transform-sticky-regex@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-kfiDrDQ+PBsQDO85yj1icueWMfGfJFKN1KCkndygtu/C9+XUfydLC8Iv5UYJqRwy4zk8EcplRxEOeLyjq1gm6Q==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-transform-template-literals@7.18.9(@babel/core@7.18.13): - resolution: {integrity: sha512-S8cOWfT82gTezpYOiVaGHrCbhlHgKhQt8XH5ES46P2XWmX92yisoZywf5km75wv5sYcXDUCLMmMxOLCtthDgMA==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-transform-template-literals@7.18.9(@babel/core@7.22.5): - resolution: {integrity: sha512-S8cOWfT82gTezpYOiVaGHrCbhlHgKhQt8XH5ES46P2XWmX92yisoZywf5km75wv5sYcXDUCLMmMxOLCtthDgMA==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-transform-typeof-symbol@7.18.9(@babel/core@7.18.13): - resolution: {integrity: sha512-SRfwTtF11G2aemAZWivL7PD+C9z52v9EvMqH9BuYbabyPuKUvSWks3oCg6041pT925L4zVFqaVBeECwsmlguEw==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-transform-typeof-symbol@7.18.9(@babel/core@7.22.5): - resolution: {integrity: sha512-SRfwTtF11G2aemAZWivL7PD+C9z52v9EvMqH9BuYbabyPuKUvSWks3oCg6041pT925L4zVFqaVBeECwsmlguEw==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-transform-typescript@7.21.3(@babel/core@7.20.5): - resolution: {integrity: sha512-RQxPz6Iqt8T0uw/WsJNReuBpWpBqs/n7mNo18sKLoTbMp+UrEekhH+pKSVC7gWz+DNjo9gryfV8YzCiT45RgMw==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.20.5 - '@babel/helper-annotate-as-pure': 7.18.6 - '@babel/helper-create-class-features-plugin': 7.21.0(@babel/core@7.20.5) - '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-typescript': 7.20.0(@babel/core@7.20.5) - transitivePeerDependencies: - - supports-color - dev: true - - /@babel/plugin-transform-typescript@7.21.3(@babel/core@7.22.5): - resolution: {integrity: sha512-RQxPz6Iqt8T0uw/WsJNReuBpWpBqs/n7mNo18sKLoTbMp+UrEekhH+pKSVC7gWz+DNjo9gryfV8YzCiT45RgMw==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-annotate-as-pure': 7.18.6 - '@babel/helper-create-class-features-plugin': 7.21.0(@babel/core@7.22.5) - '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-typescript': 7.20.0(@babel/core@7.22.5) - transitivePeerDependencies: - - supports-color - dev: true - - /@babel/plugin-transform-unicode-escapes@7.18.10(@babel/core@7.18.13): - resolution: {integrity: sha512-kKAdAI+YzPgGY/ftStBFXTI1LZFju38rYThnfMykS+IXy8BVx+res7s2fxf1l8I35DV2T97ezo6+SGrXz6B3iQ==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-transform-unicode-escapes@7.18.10(@babel/core@7.22.5): - resolution: {integrity: sha512-kKAdAI+YzPgGY/ftStBFXTI1LZFju38rYThnfMykS+IXy8BVx+res7s2fxf1l8I35DV2T97ezo6+SGrXz6B3iQ==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-transform-unicode-regex@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-gE7A6Lt7YLnNOL3Pb9BNeZvi+d8l7tcRrG4+pwJjK9hD2xX4mEvjlQW60G9EEmfXVYRPv9VRQcyegIVHCql/AA==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-create-regexp-features-plugin': 7.18.6(@babel/core@7.18.13) - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/plugin-transform-unicode-regex@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-gE7A6Lt7YLnNOL3Pb9BNeZvi+d8l7tcRrG4+pwJjK9hD2xX4mEvjlQW60G9EEmfXVYRPv9VRQcyegIVHCql/AA==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-create-regexp-features-plugin': 7.18.6(@babel/core@7.22.5) - '@babel/helper-plugin-utils': 7.22.5 - dev: true - - /@babel/preset-env@7.18.10(@babel/core@7.18.13): - resolution: {integrity: sha512-wVxs1yjFdW3Z/XkNfXKoblxoHgbtUF7/l3PvvP4m02Qz9TZ6uZGxRVYjSQeR87oQmHco9zWitW5J82DJ7sCjvA==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/compat-data': 7.22.5 - '@babel/core': 7.18.13 - '@babel/helper-compilation-targets': 7.22.5(@babel/core@7.18.13) - '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-validator-option': 7.22.5 - '@babel/plugin-bugfix-safari-id-destructuring-collision-in-function-expression': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-bugfix-v8-spread-parameters-in-optional-chaining': 7.18.9(@babel/core@7.18.13) - '@babel/plugin-proposal-async-generator-functions': 7.18.10(@babel/core@7.18.13) - '@babel/plugin-proposal-class-properties': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-proposal-class-static-block': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-proposal-dynamic-import': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-proposal-export-namespace-from': 7.18.9(@babel/core@7.18.13) - '@babel/plugin-proposal-json-strings': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-proposal-logical-assignment-operators': 7.18.9(@babel/core@7.18.13) - '@babel/plugin-proposal-nullish-coalescing-operator': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-proposal-numeric-separator': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-proposal-object-rest-spread': 7.18.9(@babel/core@7.18.13) - '@babel/plugin-proposal-optional-catch-binding': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-proposal-optional-chaining': 7.18.9(@babel/core@7.18.13) - '@babel/plugin-proposal-private-methods': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-proposal-private-property-in-object': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-proposal-unicode-property-regex': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-syntax-async-generators': 7.8.4(@babel/core@7.18.13) - '@babel/plugin-syntax-class-properties': 7.12.13(@babel/core@7.18.13) - '@babel/plugin-syntax-class-static-block': 7.14.5(@babel/core@7.18.13) - '@babel/plugin-syntax-dynamic-import': 7.8.3(@babel/core@7.18.13) - '@babel/plugin-syntax-export-namespace-from': 7.8.3(@babel/core@7.18.13) - '@babel/plugin-syntax-import-assertions': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-syntax-json-strings': 7.8.3(@babel/core@7.18.13) - '@babel/plugin-syntax-logical-assignment-operators': 7.10.4(@babel/core@7.18.13) - '@babel/plugin-syntax-nullish-coalescing-operator': 7.8.3(@babel/core@7.18.13) - '@babel/plugin-syntax-numeric-separator': 7.10.4(@babel/core@7.18.13) - '@babel/plugin-syntax-object-rest-spread': 7.8.3(@babel/core@7.18.13) - '@babel/plugin-syntax-optional-catch-binding': 7.8.3(@babel/core@7.18.13) - '@babel/plugin-syntax-optional-chaining': 7.8.3(@babel/core@7.18.13) - '@babel/plugin-syntax-private-property-in-object': 7.14.5(@babel/core@7.18.13) - '@babel/plugin-syntax-top-level-await': 7.14.5(@babel/core@7.18.13) - '@babel/plugin-transform-arrow-functions': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-transform-async-to-generator': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-transform-block-scoped-functions': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-transform-block-scoping': 7.18.9(@babel/core@7.18.13) - '@babel/plugin-transform-classes': 7.18.9(@babel/core@7.18.13) - '@babel/plugin-transform-computed-properties': 7.18.9(@babel/core@7.18.13) - '@babel/plugin-transform-destructuring': 7.18.13(@babel/core@7.18.13) - '@babel/plugin-transform-dotall-regex': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-transform-duplicate-keys': 7.18.9(@babel/core@7.18.13) - '@babel/plugin-transform-exponentiation-operator': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-transform-for-of': 7.18.8(@babel/core@7.18.13) - '@babel/plugin-transform-function-name': 7.18.9(@babel/core@7.18.13) - '@babel/plugin-transform-literals': 7.18.9(@babel/core@7.18.13) - '@babel/plugin-transform-member-expression-literals': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-transform-modules-amd': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-transform-modules-commonjs': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-transform-modules-systemjs': 7.18.9(@babel/core@7.18.13) - '@babel/plugin-transform-modules-umd': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-transform-named-capturing-groups-regex': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-transform-new-target': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-transform-object-super': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-transform-parameters': 7.18.8(@babel/core@7.18.13) - '@babel/plugin-transform-property-literals': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-transform-regenerator': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-transform-reserved-words': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-transform-shorthand-properties': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-transform-spread': 7.18.9(@babel/core@7.18.13) - '@babel/plugin-transform-sticky-regex': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-transform-template-literals': 7.18.9(@babel/core@7.18.13) - '@babel/plugin-transform-typeof-symbol': 7.18.9(@babel/core@7.18.13) - '@babel/plugin-transform-unicode-escapes': 7.18.10(@babel/core@7.18.13) - '@babel/plugin-transform-unicode-regex': 7.18.6(@babel/core@7.18.13) - '@babel/preset-modules': 0.1.5(@babel/core@7.18.13) - '@babel/types': 7.22.5 - babel-plugin-polyfill-corejs2: 0.3.2(@babel/core@7.18.13) - babel-plugin-polyfill-corejs3: 0.5.3(@babel/core@7.18.13) - babel-plugin-polyfill-regenerator: 0.4.0(@babel/core@7.18.13) - core-js-compat: 3.25.0 - semver: 6.3.0 - transitivePeerDependencies: - - supports-color - dev: true - - /@babel/preset-env@7.18.10(@babel/core@7.22.5): - resolution: {integrity: sha512-wVxs1yjFdW3Z/XkNfXKoblxoHgbtUF7/l3PvvP4m02Qz9TZ6uZGxRVYjSQeR87oQmHco9zWitW5J82DJ7sCjvA==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/compat-data': 7.22.5 - '@babel/core': 7.22.5 - '@babel/helper-compilation-targets': 7.22.5(@babel/core@7.22.5) - '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-validator-option': 7.22.5 - '@babel/plugin-bugfix-safari-id-destructuring-collision-in-function-expression': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-bugfix-v8-spread-parameters-in-optional-chaining': 7.18.9(@babel/core@7.22.5) - '@babel/plugin-proposal-async-generator-functions': 7.18.10(@babel/core@7.22.5) - '@babel/plugin-proposal-class-properties': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-proposal-class-static-block': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-proposal-dynamic-import': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-proposal-export-namespace-from': 7.18.9(@babel/core@7.22.5) - '@babel/plugin-proposal-json-strings': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-proposal-logical-assignment-operators': 7.18.9(@babel/core@7.22.5) - '@babel/plugin-proposal-nullish-coalescing-operator': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-proposal-numeric-separator': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-proposal-object-rest-spread': 7.18.9(@babel/core@7.22.5) - '@babel/plugin-proposal-optional-catch-binding': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-proposal-optional-chaining': 7.18.9(@babel/core@7.22.5) - '@babel/plugin-proposal-private-methods': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-proposal-private-property-in-object': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-proposal-unicode-property-regex': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-syntax-async-generators': 7.8.4(@babel/core@7.22.5) - '@babel/plugin-syntax-class-properties': 7.12.13(@babel/core@7.22.5) - '@babel/plugin-syntax-class-static-block': 7.14.5(@babel/core@7.22.5) - '@babel/plugin-syntax-dynamic-import': 7.8.3(@babel/core@7.22.5) - '@babel/plugin-syntax-export-namespace-from': 7.8.3(@babel/core@7.22.5) - '@babel/plugin-syntax-import-assertions': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-syntax-json-strings': 7.8.3(@babel/core@7.22.5) - '@babel/plugin-syntax-logical-assignment-operators': 7.10.4(@babel/core@7.22.5) - '@babel/plugin-syntax-nullish-coalescing-operator': 7.8.3(@babel/core@7.22.5) - '@babel/plugin-syntax-numeric-separator': 7.10.4(@babel/core@7.22.5) - '@babel/plugin-syntax-object-rest-spread': 7.8.3(@babel/core@7.22.5) - '@babel/plugin-syntax-optional-catch-binding': 7.8.3(@babel/core@7.22.5) - '@babel/plugin-syntax-optional-chaining': 7.8.3(@babel/core@7.22.5) - '@babel/plugin-syntax-private-property-in-object': 7.14.5(@babel/core@7.22.5) - '@babel/plugin-syntax-top-level-await': 7.14.5(@babel/core@7.22.5) - '@babel/plugin-transform-arrow-functions': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-transform-async-to-generator': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-transform-block-scoped-functions': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-transform-block-scoping': 7.18.9(@babel/core@7.22.5) - '@babel/plugin-transform-classes': 7.18.9(@babel/core@7.22.5) - '@babel/plugin-transform-computed-properties': 7.18.9(@babel/core@7.22.5) - '@babel/plugin-transform-destructuring': 7.18.13(@babel/core@7.22.5) - '@babel/plugin-transform-dotall-regex': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-transform-duplicate-keys': 7.18.9(@babel/core@7.22.5) - '@babel/plugin-transform-exponentiation-operator': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-transform-for-of': 7.18.8(@babel/core@7.22.5) - '@babel/plugin-transform-function-name': 7.18.9(@babel/core@7.22.5) - '@babel/plugin-transform-literals': 7.18.9(@babel/core@7.22.5) - '@babel/plugin-transform-member-expression-literals': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-transform-modules-amd': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-transform-modules-commonjs': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-transform-modules-systemjs': 7.18.9(@babel/core@7.22.5) - '@babel/plugin-transform-modules-umd': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-transform-named-capturing-groups-regex': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-transform-new-target': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-transform-object-super': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-transform-parameters': 7.18.8(@babel/core@7.22.5) - '@babel/plugin-transform-property-literals': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-transform-regenerator': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-transform-reserved-words': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-transform-shorthand-properties': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-transform-spread': 7.18.9(@babel/core@7.22.5) - '@babel/plugin-transform-sticky-regex': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-transform-template-literals': 7.18.9(@babel/core@7.22.5) - '@babel/plugin-transform-typeof-symbol': 7.18.9(@babel/core@7.22.5) - '@babel/plugin-transform-unicode-escapes': 7.18.10(@babel/core@7.22.5) - '@babel/plugin-transform-unicode-regex': 7.18.6(@babel/core@7.22.5) - '@babel/preset-modules': 0.1.5(@babel/core@7.22.5) - '@babel/types': 7.22.5 - babel-plugin-polyfill-corejs2: 0.3.2(@babel/core@7.22.5) - babel-plugin-polyfill-corejs3: 0.5.3(@babel/core@7.22.5) - babel-plugin-polyfill-regenerator: 0.4.0(@babel/core@7.22.5) - core-js-compat: 3.25.0 - semver: 6.3.0 - transitivePeerDependencies: - - supports-color - dev: true - - /@babel/preset-flow@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-E7BDhL64W6OUqpuyHnSroLnqyRTcG6ZdOBl1OKI/QK/HJfplqK/S3sq1Cckx7oTodJ5yOXyfw7rEADJ6UjoQDQ==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-validator-option': 7.22.5 - '@babel/plugin-transform-flow-strip-types': 7.18.9(@babel/core@7.18.13) - dev: true - - /@babel/preset-modules@0.1.5(@babel/core@7.18.13): - resolution: {integrity: sha512-A57th6YRG7oR3cq/yt/Y84MvGgE0eJG2F1JLhKuyG+jFxEgrd/HAMJatiFtmOiZurz+0DkrvbheCLaV5f2JfjA==} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-proposal-unicode-property-regex': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-transform-dotall-regex': 7.18.6(@babel/core@7.18.13) - '@babel/types': 7.22.5 - esutils: 2.0.3 - dev: true - - /@babel/preset-modules@0.1.5(@babel/core@7.22.5): - resolution: {integrity: sha512-A57th6YRG7oR3cq/yt/Y84MvGgE0eJG2F1JLhKuyG+jFxEgrd/HAMJatiFtmOiZurz+0DkrvbheCLaV5f2JfjA==} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-proposal-unicode-property-regex': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-transform-dotall-regex': 7.18.6(@babel/core@7.22.5) - '@babel/types': 7.22.5 - esutils: 2.0.3 - dev: true - - /@babel/preset-react@7.18.6(@babel/core@7.18.13): - resolution: {integrity: sha512-zXr6atUmyYdiWRVLOZahakYmOBHtWc2WGCkP8PYTgZi0iJXDY2CN180TdrIW4OGOAdLc7TifzDIvtx6izaRIzg==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-validator-option': 7.22.5 - '@babel/plugin-transform-react-display-name': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-transform-react-jsx': 7.19.0(@babel/core@7.18.13) - '@babel/plugin-transform-react-jsx-development': 7.18.6(@babel/core@7.18.13) - '@babel/plugin-transform-react-pure-annotations': 7.18.6(@babel/core@7.18.13) - dev: true - - /@babel/preset-react@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-zXr6atUmyYdiWRVLOZahakYmOBHtWc2WGCkP8PYTgZi0iJXDY2CN180TdrIW4OGOAdLc7TifzDIvtx6izaRIzg==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-validator-option': 7.22.5 - '@babel/plugin-transform-react-display-name': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-transform-react-jsx': 7.19.0(@babel/core@7.22.5) - '@babel/plugin-transform-react-jsx-development': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-transform-react-pure-annotations': 7.18.6(@babel/core@7.22.5) - dev: true - - /@babel/preset-typescript@7.18.6(@babel/core@7.20.5): - resolution: {integrity: sha512-s9ik86kXBAnD760aybBucdpnLsAt0jK1xqJn2juOn9lkOvSHV60os5hxoVJsPzMQxvnUJFAlkont2DvvaYEBtQ==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.20.5 - '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-validator-option': 7.22.5 - '@babel/plugin-transform-typescript': 7.21.3(@babel/core@7.20.5) - transitivePeerDependencies: - - supports-color - dev: true - - /@babel/preset-typescript@7.18.6(@babel/core@7.22.5): - resolution: {integrity: sha512-s9ik86kXBAnD760aybBucdpnLsAt0jK1xqJn2juOn9lkOvSHV60os5hxoVJsPzMQxvnUJFAlkont2DvvaYEBtQ==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-validator-option': 7.22.5 - '@babel/plugin-transform-typescript': 7.21.3(@babel/core@7.22.5) - transitivePeerDependencies: - - supports-color - dev: true - - /@babel/register@7.18.9(@babel/core@7.22.5): - resolution: {integrity: sha512-ZlbnXDcNYHMR25ITwwNKT88JiaukkdVj/nG7r3wnuXkOTHc60Uy05PwMCPre0hSkY68E6zK3xz+vUJSP2jWmcw==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - clone-deep: 4.0.1 - find-cache-dir: 2.1.0 - make-dir: 2.1.0 - pirates: 4.0.5 - source-map-support: 0.5.21 - dev: true - - /@babel/runtime@7.18.9: - resolution: {integrity: sha512-lkqXDcvlFT5rvEjiu6+QYO+1GXrEHRo2LOtS7E4GtX5ESIZOgepqsZBVIj6Pv+a6zqsya9VCgiK1KAK4BvJDAw==} - engines: {node: '>=6.9.0'} - dependencies: - regenerator-runtime: 0.13.11 - - /@babel/template@7.18.10: - resolution: {integrity: sha512-TI+rCtooWHr3QJ27kJxfjutghu44DLnasDMwpDqCXVTal9RLp3RSYNh4NdBrRP2cQAoG9A8juOQl6P6oZG4JxA==} - engines: {node: '>=6.9.0'} - dependencies: - '@babel/code-frame': 7.22.5 - '@babel/parser': 7.22.5 - '@babel/types': 7.22.5 - - /@babel/template@7.22.5: - resolution: {integrity: sha512-X7yV7eiwAxdj9k94NEylvbVHLiVG1nvzCV2EAowhxLTwODV1jl9UzZ48leOC0sH7OnuHrIkllaBgneUykIcZaw==} - engines: {node: '>=6.9.0'} - dependencies: - '@babel/code-frame': 7.22.5 - '@babel/parser': 7.22.5 - '@babel/types': 7.22.5 - - /@babel/traverse@7.18.13: - resolution: {integrity: sha512-N6kt9X1jRMLPxxxPYWi7tgvJRH/rtoU+dbKAPDM44RFHiMH8igdsaSBgFeskhSl/kLWLDUvIh1RXCrTmg0/zvA==} - engines: {node: '>=6.9.0'} - dependencies: - '@babel/code-frame': 7.22.5 - '@babel/generator': 7.22.5 - '@babel/helper-environment-visitor': 7.22.5 - '@babel/helper-function-name': 7.22.5 - '@babel/helper-hoist-variables': 7.22.5 - '@babel/helper-split-export-declaration': 7.22.5 - '@babel/parser': 7.22.5 - '@babel/types': 7.22.5 - debug: 4.3.4(supports-color@8.1.1) - globals: 11.12.0 - transitivePeerDependencies: - - supports-color - - /@babel/traverse@7.22.5: - resolution: {integrity: sha512-7DuIjPgERaNo6r+PZwItpjCZEa5vyw4eJGufeLxrPdBXBoLcCJCIasvK6pK/9DVNrLZTLFhUGqaC6X/PA007TQ==} - engines: {node: '>=6.9.0'} - dependencies: - '@babel/code-frame': 7.22.5 - '@babel/generator': 7.22.5 - '@babel/helper-environment-visitor': 7.22.5 - '@babel/helper-function-name': 7.22.5 - '@babel/helper-hoist-variables': 7.22.5 - '@babel/helper-split-export-declaration': 7.22.5 - '@babel/parser': 7.22.5 - '@babel/types': 7.22.5 - debug: 4.3.4(supports-color@8.1.1) - globals: 11.12.0 - transitivePeerDependencies: - - supports-color - - /@babel/types@7.18.13: - resolution: {integrity: sha512-ePqfTihzW0W6XAU+aMw2ykilisStJfDnsejDCXRchCcMJ4O0+8DhPXf2YUbZ6wjBlsEmZwLK/sPweWtu8hcJYQ==} - engines: {node: '>=6.9.0'} - dependencies: - '@babel/helper-string-parser': 7.22.5 - '@babel/helper-validator-identifier': 7.22.5 - to-fast-properties: 2.0.0 - - /@babel/types@7.22.5: - resolution: {integrity: sha512-zo3MIHGOkPOfoRXitsgHLjEXmlDaD/5KU1Uzuc9GNiZPhSqVxVRtxuPaSBZDsYZ9qV88AjtMtWW7ww98loJ9KA==} - engines: {node: '>=6.9.0'} - dependencies: - '@babel/helper-string-parser': 7.22.5 - '@babel/helper-validator-identifier': 7.22.5 - to-fast-properties: 2.0.0 - - /@base2/pretty-print-object@1.0.1: - resolution: {integrity: sha512-4iri8i1AqYHJE2DstZYkyEprg6Pq6sKx3xn5FpySk9sNhH7qN2LLlHJCfDTZRILNwQNPD7mATWM0TBui7uC1pA==} - dev: true - - /@bcoe/v8-coverage@0.2.3: - resolution: {integrity: sha512-0hYQ8SB4Db5zvZB4axdMHGwEaQjkZzFjQiN9LVYvIFB2nSUHW9tYpxWriPrWDASIxiaXax83REcLxuSdnGPZtw==} - - /@canvas/image-data@1.0.0: - resolution: {integrity: sha512-BxOqI5LgsIQP1odU5KMwV9yoijleOPzHL18/YvNqF9KFSGF2K/DLlYAbDQsWqd/1nbaFuSkYD/191dpMtNh4vw==} - dev: true - - /@cnakazawa/watch@1.0.4: - resolution: {integrity: sha512-v9kIhKwjeZThiWrLmj0y17CWoyddASLj9O2yvbZkbvw/N3rWOYy9zkV66ursAoVr0mV15bL8g0c4QZUE6cdDoQ==} - engines: {node: '>=0.1.95'} - hasBin: true - dependencies: - exec-sh: 0.3.6 - minimist: 1.2.8 - dev: true - - /@colors/colors@1.5.0: - resolution: {integrity: sha512-ooWCrlZP11i8GImSjTHYHLkvFDP48nS4+204nGb1RiX/WXYHmJA2III9/e2DWVabCESdW7hBAEzHRqUn9OUVvQ==} - engines: {node: '>=0.1.90'} - requiresBuild: true - dev: true - optional: true - - /@cspotcode/source-map-support@0.8.1: - resolution: {integrity: sha512-IchNf6dN4tHoMFIn/7OE8LWZ19Y6q/67Bmf6vnGREv8RSbBVb9LPJxEcnwrcwX6ixSvaiGoomAUvu4YSxXrVgw==} - engines: {node: '>=12'} - dependencies: - '@jridgewell/trace-mapping': 0.3.9 - dev: true - - /@cypress/request@2.88.10: - resolution: {integrity: sha512-Zp7F+R93N0yZyG34GutyTNr+okam7s/Fzc1+i3kcqOP8vk6OuajuE9qZJ6Rs+10/1JFtXFYMdyarnU1rZuJesg==} + /@cypress/request/2.88.11: + resolution: {integrity: sha512-M83/wfQ1EkspjkE2lNWNV5ui2Cv7UCv1swW1DqljahbzLVWltcsexQh8jYtuS/vzFXP+HySntGM83ZXA9fn17w==} engines: {node: '>= 6'} dependencies: aws-sign2: 0.7.0 - aws4: 1.11.0 + aws4: 1.12.0 caseless: 0.12.0 combined-stream: 1.0.8 extend: 3.0.2 @@ -4967,85 +3411,85 @@ packages: json-stringify-safe: 5.0.1 mime-types: 2.1.35 performance-now: 2.1.0 - qs: 6.5.3 + qs: 6.10.4 safe-buffer: 5.2.1 tough-cookie: 2.5.0 tunnel-agent: 0.6.0 uuid: 8.3.2 dev: true - /@cypress/xvfb@1.2.4(supports-color@8.1.1): + /@cypress/xvfb/1.2.4_supports-color@8.1.1: resolution: {integrity: sha512-skbBzPggOVYCbnGgV+0dmBdW/s77ZkAOXIC1knS8NagwDjBrNC1LuXtQJeiN6l+m7lzmHtaoUw/ctJKdqkG57Q==} dependencies: - debug: 3.2.7(supports-color@8.1.1) + debug: 3.2.7_supports-color@8.1.1 lodash.once: 4.1.1 transitivePeerDependencies: - supports-color dev: true - /@date-io/core@2.15.0: - resolution: {integrity: sha512-3CRvQUEK7aF87NUOwcTtmJ2Rc1kN0D4jFQUfRoanuAnE4o5HzHx4E2YenjaKjSPWeZYiWG6ZhDomx5hp1AaCJA==} + /@date-io/core/2.16.0: + resolution: {integrity: sha512-DYmSzkr+jToahwWrsiRA2/pzMEtz9Bq1euJwoOuYwuwIYXnZFtHajY2E6a1VNVDc9jP8YUXK1BvnZH9mmT19Zg==} dev: false - /@date-io/date-fns@2.15.0(date-fns@2.29.2): - resolution: {integrity: sha512-hkVeLm0jijHS2F9YVQcf0LSlD55w9xPvvIfuxDE0XWNXOTcRAAhqw2aqOxyeGbmHxc5U4HqyPZaqs9tfeTsomQ==} + /@date-io/date-fns/2.16.0_date-fns@2.30.0: + resolution: {integrity: sha512-bfm5FJjucqlrnQcXDVU5RD+nlGmL3iWgkHTq3uAZWVIuBu6dDmGa3m8a6zo2VQQpu8ambq9H22UyUpn7590joA==} peerDependencies: date-fns: ^2.0.0 peerDependenciesMeta: date-fns: optional: true dependencies: - '@date-io/core': 2.15.0 - date-fns: 2.29.2 + '@date-io/core': 2.16.0 + date-fns: 2.30.0 dev: false - /@date-io/dayjs@2.15.0: - resolution: {integrity: sha512-wgYzwaXr9KxkHNYxrOb1t8fYLfAdjIf0Q86qdVCwANObcvyGcPBm0uFtpPK7ApeE4DJUlbuG0IX75TtO+uITwQ==} + /@date-io/dayjs/2.16.0: + resolution: {integrity: sha512-y5qKyX2j/HG3zMvIxTobYZRGnd1FUW2olZLS0vTj7bEkBQkjd2RO7/FEwDY03Z1geVGlXKnzIATEVBVaGzV4Iw==} peerDependencies: dayjs: ^1.8.17 peerDependenciesMeta: dayjs: optional: true dependencies: - '@date-io/core': 2.15.0 + '@date-io/core': 2.16.0 dev: false - /@date-io/luxon@2.15.0: - resolution: {integrity: sha512-CxTRCo5AM96ainnYaTpe1NS9GiA78SIgXBScgeAresCS20AvMcOd5XKerDj+y/KLhbSQbU6WUDqG9QcsrImXyQ==} + /@date-io/luxon/2.16.1: + resolution: {integrity: sha512-aeYp5K9PSHV28946pC+9UKUi/xMMYoaGelrpDibZSgHu2VWHXrr7zWLEr+pMPThSs5vt8Ei365PO+84pCm37WQ==} peerDependencies: - luxon: ^1.21.3 || ^2.x + luxon: ^1.21.3 || ^2.x || ^3.x peerDependenciesMeta: luxon: optional: true dependencies: - '@date-io/core': 2.15.0 + '@date-io/core': 2.16.0 dev: false - /@date-io/moment@2.15.0: - resolution: {integrity: sha512-AcYBjl3EnEGsByaM5ir644CKbhgJsgc1iWFa9EXfdb4fQexxOC8oCdPAurK2ZDTwg62odyyKa/05YE7ElYh5ag==} + /@date-io/moment/2.16.1: + resolution: {integrity: sha512-JkxldQxUqZBfZtsaCcCMkm/dmytdyq5pS1RxshCQ4fHhsvP5A7gSqPD22QbVXMcJydi3d3v1Y8BQdUKEuGACZQ==} peerDependencies: moment: ^2.24.0 peerDependenciesMeta: moment: optional: true dependencies: - '@date-io/core': 2.15.0 + '@date-io/core': 2.16.0 dev: false - /@discoveryjs/json-ext@0.5.7: + /@discoveryjs/json-ext/0.5.7: resolution: {integrity: sha512-dBVuXR082gk3jsFp7Rd/JI4kytwGHecnCoTtXFb7DB6CNHp4rg5k1bhg0nWdLGLnOV71lmDzGQaLMy8iPLY0pw==} engines: {node: '>=10.0.0'} dev: true - /@docsearch/css@3.5.1: + /@docsearch/css/3.5.1: resolution: {integrity: sha512-2Pu9HDg/uP/IT10rbQ+4OrTQuxIWdKVUEdcw9/w7kZJv9NeHS6skJx1xuRiFyoGKwAzcHXnLp7csE99sj+O1YA==} dev: true - /@docsearch/js@3.5.1(search-insights@2.6.0): + /@docsearch/js/3.5.1: resolution: {integrity: sha512-EXi8de5njxgP6TV3N9ytnGRLG9zmBNTEZjR4VzwPcpPLbZxxTLG2gaFyJyKiFVQxHW/DPlMrDJA3qoRRGEkgZw==} dependencies: - '@docsearch/react': 3.5.1(search-insights@2.6.0) - preact: 10.10.6 + '@docsearch/react': 3.5.1 + preact: 10.16.0 transitivePeerDependencies: - '@algolia/client-search' - '@types/react' @@ -5054,7 +3498,7 @@ packages: - search-insights dev: true - /@docsearch/react@3.5.1(search-insights@2.6.0): + /@docsearch/react/3.5.1: resolution: {integrity: sha512-t5mEODdLzZq4PTFAm/dvqcvZFdPDMdfPE5rJS5SC8OUq9mPzxEy6b+9THIqNM9P0ocCb4UC5jqBrxKclnuIbzQ==} peerDependencies: '@types/react': '>= 16.8.0 < 19.0.0' @@ -5068,326 +3512,276 @@ packages: react-dom: optional: true dependencies: - '@algolia/autocomplete-core': 1.9.3(algoliasearch@4.14.2)(search-insights@2.6.0) - '@algolia/autocomplete-preset-algolia': 1.9.3(algoliasearch@4.14.2) + '@algolia/autocomplete-core': 1.9.3_algoliasearch@4.18.0 + '@algolia/autocomplete-preset-algolia': 1.9.3_algoliasearch@4.18.0 '@docsearch/css': 3.5.1 - algoliasearch: 4.14.2 + algoliasearch: 4.18.0 transitivePeerDependencies: - '@algolia/client-search' - search-insights dev: true - /@edge-runtime/primitives@1.1.0-beta.31: - resolution: {integrity: sha512-OO1x32aJoxgME1k77RVxVNsazs5NY/SNwYEN8ptlZ6DKUXn0eesXftDsmlypX/OU0ZeJc61/xNVUuoeyDGJDVA==} + /@edge-runtime/primitives/1.1.0: + resolution: {integrity: sha512-MpL5fKlOs9mz5DMRuFchLe3Il84t7XpfbPq4qtaEK37uNMCRx1MzA3d7A4aTsR/guXSZvV/AtEbKVqBWjuSThA==} dev: true - /@edge-runtime/primitives@3.0.3: + /@edge-runtime/primitives/3.0.3: resolution: {integrity: sha512-YnfMWMRQABAH8IsnFMJWMW+SyB4ZeYBPnR7V0aqdnew7Pq60cbH5DyFjS/FhiLwvHQk9wBREmXD7PP0HooEQ1A==} engines: {node: '>=14'} dev: true - /@edge-runtime/vm@1.1.0-beta.26: + /@edge-runtime/vm/1.1.0-beta.26: resolution: {integrity: sha512-hxWtmuO13zgNkM3zHvRENfMeavM+PAKSoHhvzt+sHjSothxGlA06XXN38t/NT6LD4ND8p8FmPJ70+fTptL4a/A==} dependencies: - '@edge-runtime/primitives': 1.1.0-beta.31 + '@edge-runtime/primitives': 1.1.0 dev: true - /@edge-runtime/vm@3.0.3: + /@edge-runtime/vm/3.0.3: resolution: {integrity: sha512-SPfI1JeIRNs/4EEE2Oc0X6gG3RqjD1TnKu2lwmwFXq0435xgZGKhc3UiKkYAdoMn2dNFD73nlabMKHBRoMRpxg==} engines: {node: '>=14'} dependencies: '@edge-runtime/primitives': 3.0.3 dev: true - /@emotion/babel-plugin@11.10.2(@babel/core@7.22.5): - resolution: {integrity: sha512-xNQ57njWTFVfPAc3cjfuaPdsgLp5QOSuRsj9MA6ndEhH/AzuZM86qIQzt6rq+aGBwj3n5/TkLmU5lhAfdRmogA==} - peerDependencies: - '@babel/core': ^7.0.0 + /@emotion/babel-plugin/11.11.0: + resolution: {integrity: sha512-m4HEDZleaaCH+XgDDsPF15Ht6wTLsgDTeR3WYj9Q/k76JtWhrJjcP4+/XlG8LGT/Rol9qUfOIztXeA84ATpqPQ==} dependencies: - '@babel/core': 7.22.5 '@babel/helper-module-imports': 7.22.5 - '@babel/plugin-syntax-jsx': 7.18.6(@babel/core@7.22.5) - '@babel/runtime': 7.18.9 - '@emotion/hash': 0.9.0 - '@emotion/memoize': 0.8.0 - '@emotion/serialize': 1.1.0 + '@babel/runtime': 7.22.6 + '@emotion/hash': 0.9.1 + '@emotion/memoize': 0.8.1 + '@emotion/serialize': 1.1.2 babel-plugin-macros: 3.1.0 convert-source-map: 1.9.0 escape-string-regexp: 4.0.0 find-root: 1.1.0 source-map: 0.5.7 - stylis: 4.0.13 + stylis: 4.2.0 dev: false - /@emotion/cache@11.10.3: - resolution: {integrity: sha512-Psmp/7ovAa8appWh3g51goxu/z3iVms7JXOreq136D8Bbn6dYraPnmL6mdM8GThEx9vwSn92Fz+mGSjBzN8UPQ==} + /@emotion/cache/11.11.0: + resolution: {integrity: sha512-P34z9ssTCBi3e9EI1ZsWpNHcfY1r09ZO0rZbRO2ob3ZQMnFI35jB536qoXbkdesr5EUhYi22anuEJuyxifaqAQ==} dependencies: - '@emotion/memoize': 0.8.0 - '@emotion/sheet': 1.2.0 - '@emotion/utils': 1.2.0 - '@emotion/weak-memoize': 0.3.0 - stylis: 4.0.13 + '@emotion/memoize': 0.8.1 + '@emotion/sheet': 1.2.2 + '@emotion/utils': 1.2.1 + '@emotion/weak-memoize': 0.3.1 + stylis: 4.2.0 dev: false - /@emotion/hash@0.9.0: - resolution: {integrity: sha512-14FtKiHhy2QoPIzdTcvh//8OyBlknNs2nXRwIhG904opCby3l+9Xaf/wuPvICBF0rc1ZCNBd3nKe9cd2mecVkQ==} + /@emotion/hash/0.9.1: + resolution: {integrity: sha512-gJB6HLm5rYwSLI6PQa+X1t5CFGrv1J1TWG+sOyMCeKz2ojaj6Fnl/rZEspogG+cvqbt4AE/2eIyD2QfLKTBNlQ==} dev: false - /@emotion/is-prop-valid@1.2.0: - resolution: {integrity: sha512-3aDpDprjM0AwaxGE09bOPkNxHpBd+kA6jty3RnaEXdweX1DF1U3VQpPYb0g1IStAuK7SVQ1cy+bNBBKp4W3Fjg==} + /@emotion/is-prop-valid/1.2.1: + resolution: {integrity: sha512-61Mf7Ufx4aDxx1xlDeOm8aFFigGHE4z+0sKCa+IHCeZKiyP9RLD0Mmx7m8b9/Cf37f7NAvQOOJAbQQGVr5uERw==} dependencies: - '@emotion/memoize': 0.8.0 + '@emotion/memoize': 0.8.1 dev: false - /@emotion/memoize@0.8.0: - resolution: {integrity: sha512-G/YwXTkv7Den9mXDO7AhLWkE3q+I92B+VqAE+dYG4NGPaHZGvt3G8Q0p9vmE+sq7rTGphUbAvmQ9YpbfMQGGlA==} + /@emotion/memoize/0.8.1: + resolution: {integrity: sha512-W2P2c/VRW1/1tLox0mVUalvnWXxavmv/Oum2aPsRcoDJuob75FC3Y8FbpfLwUegRcxINtGUMPq0tFCvYNTBXNA==} dev: false - /@emotion/react@11.10.4(@babel/core@7.22.5)(react@18.2.0): - resolution: {integrity: sha512-j0AkMpr6BL8gldJZ6XQsQ8DnS9TxEQu1R+OGmDZiWjBAJtCcbt0tS3I/YffoqHXxH6MjgI7KdMbYKw3MEiU9eA==} + /@emotion/react/11.11.1_react@18.2.0: + resolution: {integrity: sha512-5mlW1DquU5HaxjLkfkGN1GA/fvVGdyHURRiX/0FHl2cfIfRxSOfmxEH5YS43edp0OldZrZ+dkBKbngxcNCdZvA==} peerDependencies: - '@babel/core': ^7.0.0 '@types/react': '*' react: '>=16.8.0' peerDependenciesMeta: - '@babel/core': - optional: true '@types/react': optional: true dependencies: - '@babel/core': 7.22.5 - '@babel/runtime': 7.18.9 - '@emotion/babel-plugin': 11.10.2(@babel/core@7.22.5) - '@emotion/cache': 11.10.3 - '@emotion/serialize': 1.1.0 - '@emotion/use-insertion-effect-with-fallbacks': 1.0.0(react@18.2.0) - '@emotion/utils': 1.2.0 - '@emotion/weak-memoize': 0.3.0 + '@babel/runtime': 7.22.6 + '@emotion/babel-plugin': 11.11.0 + '@emotion/cache': 11.11.0 + '@emotion/serialize': 1.1.2 + '@emotion/use-insertion-effect-with-fallbacks': 1.0.1_react@18.2.0 + '@emotion/utils': 1.2.1 + '@emotion/weak-memoize': 0.3.1 hoist-non-react-statics: 3.3.2 react: 18.2.0 dev: false - /@emotion/serialize@1.1.0: - resolution: {integrity: sha512-F1ZZZW51T/fx+wKbVlwsfchr5q97iW8brAnXmsskz4d0hVB4O3M/SiA3SaeH06x02lSNzkkQv+n3AX3kCXKSFA==} + /@emotion/serialize/1.1.2: + resolution: {integrity: sha512-zR6a/fkFP4EAcCMQtLOhIgpprZOwNmCldtpaISpvz348+DP4Mz8ZoKaGGCQpbzepNIUWbq4w6hNZkwDyKoS+HA==} dependencies: - '@emotion/hash': 0.9.0 - '@emotion/memoize': 0.8.0 - '@emotion/unitless': 0.8.0 - '@emotion/utils': 1.2.0 + '@emotion/hash': 0.9.1 + '@emotion/memoize': 0.8.1 + '@emotion/unitless': 0.8.1 + '@emotion/utils': 1.2.1 csstype: 3.1.2 dev: false - /@emotion/sheet@1.2.0: - resolution: {integrity: sha512-OiTkRgpxescko+M51tZsMq7Puu/KP55wMT8BgpcXVG2hqXc0Vo0mfymJ/Uj24Hp0i083ji/o0aLddh08UEjq8w==} + /@emotion/sheet/1.2.2: + resolution: {integrity: sha512-0QBtGvaqtWi+nx6doRwDdBIzhNdZrXUppvTM4dtZZWEGTXL/XE/yJxLMGlDT1Gt+UHH5IX1n+jkXyytE/av7OA==} dev: false - /@emotion/styled@11.10.4(@babel/core@7.22.5)(@emotion/react@11.10.4)(react@18.2.0): - resolution: {integrity: sha512-pRl4R8Ez3UXvOPfc2bzIoV8u9P97UedgHS4FPX594ntwEuAMA114wlaHvOK24HB48uqfXiGlYIZYCxVJ1R1ttQ==} + /@emotion/styled/11.11.0_xo5t6f4ryb2nvjgwj2cxjowrye: + resolution: {integrity: sha512-hM5Nnvu9P3midq5aaXj4I+lnSfNi7Pmd4EWk1fOZ3pxookaQTNew6bp4JaCBYM4HVFZF9g7UjJmsUmC2JlxOng==} peerDependencies: - '@babel/core': ^7.0.0 '@emotion/react': ^11.0.0-rc.0 '@types/react': '*' react: '>=16.8.0' peerDependenciesMeta: - '@babel/core': - optional: true '@types/react': optional: true dependencies: - '@babel/core': 7.22.5 - '@babel/runtime': 7.18.9 - '@emotion/babel-plugin': 11.10.2(@babel/core@7.22.5) - '@emotion/is-prop-valid': 1.2.0 - '@emotion/react': 11.10.4(@babel/core@7.22.5)(react@18.2.0) - '@emotion/serialize': 1.1.0 - '@emotion/use-insertion-effect-with-fallbacks': 1.0.0(react@18.2.0) - '@emotion/utils': 1.2.0 + '@babel/runtime': 7.22.6 + '@emotion/babel-plugin': 11.11.0 + '@emotion/is-prop-valid': 1.2.1 + '@emotion/react': 11.11.1_react@18.2.0 + '@emotion/serialize': 1.1.2 + '@emotion/use-insertion-effect-with-fallbacks': 1.0.1_react@18.2.0 + '@emotion/utils': 1.2.1 react: 18.2.0 dev: false - /@emotion/unitless@0.8.0: - resolution: {integrity: sha512-VINS5vEYAscRl2ZUDiT3uMPlrFQupiKgHz5AA4bCH1miKBg4qtwkim1qPmJj/4WG6TreYMY111rEFsjupcOKHw==} + /@emotion/unitless/0.8.1: + resolution: {integrity: sha512-KOEGMu6dmJZtpadb476IsZBclKvILjopjUii3V+7MnXIQCYh8W3NgNcgwo21n9LXZX6EDIKvqfjYxXebDwxKmQ==} dev: false - /@emotion/use-insertion-effect-with-fallbacks@1.0.0(react@18.2.0): - resolution: {integrity: sha512-1eEgUGmkaljiBnRMTdksDV1W4kUnmwgp7X9G8B++9GYwl1lUdqSndSriIrTJ0N7LQaoauY9JJ2yhiOYK5+NI4A==} + /@emotion/use-insertion-effect-with-fallbacks/1.0.1_react@18.2.0: + resolution: {integrity: sha512-jT/qyKZ9rzLErtrjGgdkMBn2OP8wl0G3sQlBb3YPryvKHsjvINUhVaPFfP+fpBcOkmrVOVEEHQFJ7nbj2TH2gw==} peerDependencies: react: '>=16.8.0' dependencies: react: 18.2.0 dev: false - /@emotion/utils@1.2.0: - resolution: {integrity: sha512-sn3WH53Kzpw8oQ5mgMmIzzyAaH2ZqFEbozVVBSYp538E06OSE6ytOp7pRAjNQR+Q/orwqdQYJSe2m3hCOeznkw==} + /@emotion/utils/1.2.1: + resolution: {integrity: sha512-Y2tGf3I+XVnajdItskUCn6LX+VUDmP6lTL4fcqsXAv43dnlbZiuW4MWQW38rW/BVWSE7Q/7+XQocmpnRYILUmg==} dev: false - /@emotion/weak-memoize@0.3.0: - resolution: {integrity: sha512-AHPmaAx+RYfZz0eYu6Gviiagpmiyw98ySSlQvCUhVGDRtDFe4DBS0x1bSjdF3gqUDYOczB+yYvBTtEylYSdRhg==} + /@emotion/weak-memoize/0.3.1: + resolution: {integrity: sha512-EsBwpc7hBUJWAsNPBmJy4hxWx12v6bshQsldrVmjxJoc3isbxhOrF2IcCpaXxfvq03NwkI7sbsOLXbYuqF/8Ww==} dev: false - /@esbuild-kit/cjs-loader@2.3.3: - resolution: {integrity: sha512-Rt4O1mXlPEDVxvjsHLgbtHVdUXYK9C1/6ThpQnt7FaXIjUOsI6qhHYMgALhNnlIMZffag44lXd6Dqgx3xALbpQ==} + /@esbuild-kit/cjs-loader/2.4.2: + resolution: {integrity: sha512-BDXFbYOJzT/NBEtp71cvsrGPwGAMGRB/349rwKuoxNSiKjPraNNnlK6MIIabViCjqZugu6j+xeMDlEkWdHHJSg==} dependencies: - '@esbuild-kit/core-utils': 2.3.0 + '@esbuild-kit/core-utils': 3.1.0 get-tsconfig: 4.6.2 dev: true - /@esbuild-kit/cjs-loader@2.4.0: - resolution: {integrity: sha512-DBBCiHPgL2B/elUpvCDhNHXnlZQ9sfO2uyt1OJyAXKT41beQEFY4OxZ6gwS+ZesRCbZ6JV8M7GEyOPkjv8kdIw==} + /@esbuild-kit/core-utils/3.1.0: + resolution: {integrity: sha512-Uuk8RpCg/7fdHSceR1M6XbSZFSuMrxcePFuGgyvsBn+u339dk5OeL4jv2EojwTN2st/unJGsVm4qHWjWNmJ/tw==} dependencies: - '@esbuild-kit/core-utils': 3.0.0 - get-tsconfig: 4.6.2 - dev: true - - /@esbuild-kit/core-utils@2.3.0: - resolution: {integrity: sha512-JL73zt/LN/qqziHuod4/bM2xBNNofDZu1cbwT6KIn6B11lA4cgDXkoSHOfNCbZMZOnh0Aqf0vW/gNQC+Z18hKQ==} - dependencies: - esbuild: 0.15.18 - source-map-support: 0.5.21 - dev: true - - /@esbuild-kit/core-utils@3.0.0: - resolution: {integrity: sha512-TXmwH9EFS3DC2sI2YJWJBgHGhlteK0Xyu1VabwetMULfm3oYhbrsWV5yaSr2NTWZIgDGVLHbRf0inxbjXqAcmQ==} - dependencies: - esbuild: 0.15.18 + esbuild: 0.17.19 source-map-support: 0.5.21 dev: true - /@esbuild-kit/esm-loader@2.4.2: - resolution: {integrity: sha512-N9dPKAj8WOx6djVnStgILWXip4fjDcBk9L7azO0/uQDpu8Ee0eaL78mkN4Acid9BzvNAKWwdYXFJZnsVahNEew==} + /@esbuild-kit/esm-loader/2.5.5: + resolution: {integrity: sha512-Qwfvj/qoPbClxCRNuac1Du01r9gvNOT+pMYtJDapfB1eoGN1YlJ1BixLyL9WVENRx5RXgNLdfYdx/CuswlGhMw==} dependencies: - '@esbuild-kit/core-utils': 2.3.0 + '@esbuild-kit/core-utils': 3.1.0 get-tsconfig: 4.6.2 dev: true - /@esbuild-kit/esm-loader@2.5.0: - resolution: {integrity: sha512-ySs0qOsiwj+hsgZM9/MniGdvfa9/WzqfFuIia8/5gSUPeIQIX2/tG91QakxPFOR35VFiwTB7wCiHtiS6dc6SkA==} - dependencies: - '@esbuild-kit/core-utils': 3.0.0 - get-tsconfig: 4.6.2 - dev: true - - /@esbuild/android-arm64@0.17.18: - resolution: {integrity: sha512-/iq0aK0eeHgSC3z55ucMAHO05OIqmQehiGay8eP5l/5l+iEr4EIbh4/MI8xD9qRFjqzgkc0JkX0LculNC9mXBw==} - engines: {node: '>=12'} - cpu: [arm64] - os: [android] - requiresBuild: true - optional: true - - /@esbuild/android-arm64@0.18.11: - resolution: {integrity: sha512-snieiq75Z1z5LJX9cduSAjUr7vEI1OdlzFPMw0HH5YI7qQHDd3qs+WZoMrWYDsfRJSq36lIA6mfZBkvL46KoIw==} + /@esbuild/android-arm/0.17.19: + resolution: {integrity: sha512-rIKddzqhmav7MSmoFCmDIb6e2W57geRsM94gV2l38fzhXMwq7hZoClug9USI2pFRGL06f4IOPHHpFNOkWieR8A==} engines: {node: '>=12'} - cpu: [arm64] + cpu: [arm] os: [android] requiresBuild: true dev: true optional: true - /@esbuild/android-arm@0.15.18: - resolution: {integrity: sha512-5GT+kcs2WVGjVs7+boataCkO5Fg0y4kCjzkB5bAip7H4jfnOS3dA6KPiww9W1OEKTKeAcUVhdZGvgI65OXmUnw==} + /@esbuild/android-arm/0.18.11: + resolution: {integrity: sha512-q4qlUf5ucwbUJZXF5tEQ8LF7y0Nk4P58hOsGk3ucY0oCwgQqAnqXVbUuahCddVHfrxmpyewRpiTHwVHIETYu7Q==} engines: {node: '>=12'} cpu: [arm] os: [android] requiresBuild: true - dev: true optional: true - /@esbuild/android-arm@0.17.18: - resolution: {integrity: sha512-EmwL+vUBZJ7mhFCs5lA4ZimpUH3WMAoqvOIYhVQwdIgSpHC8ImHdsRyhHAVxpDYUSm0lWvd63z0XH1IlImS2Qw==} + /@esbuild/android-arm64/0.17.19: + resolution: {integrity: sha512-KBMWvEZooR7+kzY0BtbTQn0OAYY7CsiydT63pVEaPtVYF0hXbUaOyZog37DKxK7NF3XacBJOpYT4adIJh+avxA==} engines: {node: '>=12'} - cpu: [arm] + cpu: [arm64] os: [android] requiresBuild: true + dev: true optional: true - /@esbuild/android-arm@0.18.11: - resolution: {integrity: sha512-q4qlUf5ucwbUJZXF5tEQ8LF7y0Nk4P58hOsGk3ucY0oCwgQqAnqXVbUuahCddVHfrxmpyewRpiTHwVHIETYu7Q==} + /@esbuild/android-arm64/0.18.11: + resolution: {integrity: sha512-snieiq75Z1z5LJX9cduSAjUr7vEI1OdlzFPMw0HH5YI7qQHDd3qs+WZoMrWYDsfRJSq36lIA6mfZBkvL46KoIw==} engines: {node: '>=12'} - cpu: [arm] + cpu: [arm64] os: [android] requiresBuild: true - dev: true optional: true - /@esbuild/android-x64@0.17.18: - resolution: {integrity: sha512-x+0efYNBF3NPW2Xc5bFOSFW7tTXdAcpfEg2nXmxegm4mJuVeS+i109m/7HMiOQ6M12aVGGFlqJX3RhNdYM2lWg==} + /@esbuild/android-x64/0.17.19: + resolution: {integrity: sha512-uUTTc4xGNDT7YSArp/zbtmbhO0uEEK9/ETW29Wk1thYUJBz3IVnvgEiEwEa9IeLyvnpKrWK64Utw2bgUmDveww==} engines: {node: '>=12'} cpu: [x64] os: [android] requiresBuild: true + dev: true optional: true - /@esbuild/android-x64@0.18.11: + /@esbuild/android-x64/0.18.11: resolution: {integrity: sha512-iPuoxQEV34+hTF6FT7om+Qwziv1U519lEOvekXO9zaMMlT9+XneAhKL32DW3H7okrCOBQ44BMihE8dclbZtTuw==} engines: {node: '>=12'} cpu: [x64] os: [android] requiresBuild: true - dev: true optional: true - /@esbuild/darwin-arm64@0.17.18: - resolution: {integrity: sha512-6tY+djEAdF48M1ONWnQb1C+6LiXrKjmqjzPNPWXhu/GzOHTHX2nh8Mo2ZAmBFg0kIodHhciEgUBtcYCAIjGbjQ==} + /@esbuild/darwin-arm64/0.17.19: + resolution: {integrity: sha512-80wEoCfF/hFKM6WE1FyBHc9SfUblloAWx6FJkFWTWiCoht9Mc0ARGEM47e67W9rI09YoUxJL68WHfDRYEAvOhg==} engines: {node: '>=12'} cpu: [arm64] os: [darwin] requiresBuild: true + dev: true optional: true - /@esbuild/darwin-arm64@0.18.11: + /@esbuild/darwin-arm64/0.18.11: resolution: {integrity: sha512-Gm0QkI3k402OpfMKyQEEMG0RuW2LQsSmI6OeO4El2ojJMoF5NLYb3qMIjvbG/lbMeLOGiW6ooU8xqc+S0fgz2w==} engines: {node: '>=12'} cpu: [arm64] os: [darwin] requiresBuild: true - dev: true optional: true - /@esbuild/darwin-x64@0.17.18: - resolution: {integrity: sha512-Qq84ykvLvya3dO49wVC9FFCNUfSrQJLbxhoQk/TE1r6MjHo3sFF2tlJCwMjhkBVq3/ahUisj7+EpRSz0/+8+9A==} + /@esbuild/darwin-x64/0.17.19: + resolution: {integrity: sha512-IJM4JJsLhRYr9xdtLytPLSH9k/oxR3boaUIYiHkAawtwNOXKE8KoU8tMvryogdcT8AU+Bflmh81Xn6Q0vTZbQw==} engines: {node: '>=12'} cpu: [x64] os: [darwin] requiresBuild: true + dev: true optional: true - /@esbuild/darwin-x64@0.18.11: + /@esbuild/darwin-x64/0.18.11: resolution: {integrity: sha512-N15Vzy0YNHu6cfyDOjiyfJlRJCB/ngKOAvoBf1qybG3eOq0SL2Lutzz9N7DYUbb7Q23XtHPn6lMDF6uWbGv9Fw==} engines: {node: '>=12'} cpu: [x64] os: [darwin] requiresBuild: true - dev: true optional: true - /@esbuild/freebsd-arm64@0.17.18: - resolution: {integrity: sha512-fw/ZfxfAzuHfaQeMDhbzxp9mc+mHn1Y94VDHFHjGvt2Uxl10mT4CDavHm+/L9KG441t1QdABqkVYwakMUeyLRA==} + /@esbuild/freebsd-arm64/0.17.19: + resolution: {integrity: sha512-pBwbc7DufluUeGdjSU5Si+P3SoMF5DQ/F/UmTSb8HXO80ZEAJmrykPyzo1IfNbAoaqw48YRpv8shwd1NoI0jcQ==} engines: {node: '>=12'} cpu: [arm64] os: [freebsd] requiresBuild: true + dev: true optional: true - /@esbuild/freebsd-arm64@0.18.11: + /@esbuild/freebsd-arm64/0.18.11: resolution: {integrity: sha512-atEyuq6a3omEY5qAh5jIORWk8MzFnCpSTUruBgeyN9jZq1K/QI9uke0ATi3MHu4L8c59CnIi4+1jDKMuqmR71A==} engines: {node: '>=12'} cpu: [arm64] os: [freebsd] requiresBuild: true - dev: true optional: true - /@esbuild/freebsd-x64@0.17.18: - resolution: {integrity: sha512-FQFbRtTaEi8ZBi/A6kxOC0V0E9B/97vPdYjY9NdawyLd4Qk5VD5g2pbWN2VR1c0xhzcJm74HWpObPszWC+qTew==} - engines: {node: '>=12'} - cpu: [x64] - os: [freebsd] - requiresBuild: true - optional: true - - /@esbuild/freebsd-x64@0.18.11: - resolution: {integrity: sha512-XtuPrEfBj/YYYnAAB7KcorzzpGTvOr/dTtXPGesRfmflqhA4LMF0Gh/n5+a9JBzPuJ+CGk17CA++Hmr1F/gI0Q==} + /@esbuild/freebsd-x64/0.17.19: + resolution: {integrity: sha512-4lu+n8Wk0XlajEhbEffdy2xy53dpR06SlzvhGByyg36qJw6Kpfk7cp45DR/62aPH9mtJRmIyrXAS5UWBrJT6TQ==} engines: {node: '>=12'} cpu: [x64] os: [freebsd] @@ -5395,50 +3789,50 @@ packages: dev: true optional: true - /@esbuild/linux-arm64@0.17.18: - resolution: {integrity: sha512-R7pZvQZFOY2sxUG8P6A21eq6q+eBv7JPQYIybHVf1XkQYC+lT7nDBdC7wWKTrbvMXKRaGudp/dzZCwL/863mZQ==} + /@esbuild/freebsd-x64/0.18.11: + resolution: {integrity: sha512-XtuPrEfBj/YYYnAAB7KcorzzpGTvOr/dTtXPGesRfmflqhA4LMF0Gh/n5+a9JBzPuJ+CGk17CA++Hmr1F/gI0Q==} engines: {node: '>=12'} - cpu: [arm64] - os: [linux] + cpu: [x64] + os: [freebsd] requiresBuild: true optional: true - /@esbuild/linux-arm64@0.18.11: - resolution: {integrity: sha512-c6Vh2WS9VFKxKZ2TvJdA7gdy0n6eSy+yunBvv4aqNCEhSWVor1TU43wNRp2YLO9Vng2G+W94aRz+ILDSwAiYog==} + /@esbuild/linux-arm/0.17.19: + resolution: {integrity: sha512-cdmT3KxjlOQ/gZ2cjfrQOtmhG4HJs6hhvm3mWSRDPtZ/lP5oe8FWceS10JaSJC13GBd4eH/haHnqf7hhGNLerA==} engines: {node: '>=12'} - cpu: [arm64] + cpu: [arm] os: [linux] requiresBuild: true dev: true optional: true - /@esbuild/linux-arm@0.17.18: - resolution: {integrity: sha512-jW+UCM40LzHcouIaqv3e/oRs0JM76JfhHjCavPxMUti7VAPh8CaGSlS7cmyrdpzSk7A+8f0hiedHqr/LMnfijg==} + /@esbuild/linux-arm/0.18.11: + resolution: {integrity: sha512-Idipz+Taso/toi2ETugShXjQ3S59b6m62KmLHkJlSq/cBejixmIydqrtM2XTvNCywFl3VC7SreSf6NV0i6sRyg==} engines: {node: '>=12'} cpu: [arm] os: [linux] requiresBuild: true optional: true - /@esbuild/linux-arm@0.18.11: - resolution: {integrity: sha512-Idipz+Taso/toi2ETugShXjQ3S59b6m62KmLHkJlSq/cBejixmIydqrtM2XTvNCywFl3VC7SreSf6NV0i6sRyg==} + /@esbuild/linux-arm64/0.17.19: + resolution: {integrity: sha512-ct1Tg3WGwd3P+oZYqic+YZF4snNl2bsnMKRkb3ozHmnM0dGWuxcPTTntAF6bOP0Sp4x0PjSF+4uHQ1xvxfRKqg==} engines: {node: '>=12'} - cpu: [arm] + cpu: [arm64] os: [linux] requiresBuild: true dev: true optional: true - /@esbuild/linux-ia32@0.17.18: - resolution: {integrity: sha512-ygIMc3I7wxgXIxk6j3V00VlABIjq260i967Cp9BNAk5pOOpIXmd1RFQJQX9Io7KRsthDrQYrtcx7QCof4o3ZoQ==} + /@esbuild/linux-arm64/0.18.11: + resolution: {integrity: sha512-c6Vh2WS9VFKxKZ2TvJdA7gdy0n6eSy+yunBvv4aqNCEhSWVor1TU43wNRp2YLO9Vng2G+W94aRz+ILDSwAiYog==} engines: {node: '>=12'} - cpu: [ia32] + cpu: [arm64] os: [linux] requiresBuild: true optional: true - /@esbuild/linux-ia32@0.18.11: - resolution: {integrity: sha512-S3hkIF6KUqRh9n1Q0dSyYcWmcVa9Cg+mSoZEfFuzoYXXsk6196qndrM+ZiHNwpZKi3XOXpShZZ+9dfN5ykqjjw==} + /@esbuild/linux-ia32/0.17.19: + resolution: {integrity: sha512-w4IRhSy1VbsNxHRQpeGCHEmibqdTUx61Vc38APcsRbuVgK0OPEnQ0YD39Brymn96mOx48Y2laBQGqgZ0j9w6SQ==} engines: {node: '>=12'} cpu: [ia32] os: [linux] @@ -5446,229 +3840,228 @@ packages: dev: true optional: true - /@esbuild/linux-loong64@0.14.54: - resolution: {integrity: sha512-bZBrLAIX1kpWelV0XemxBZllyRmM6vgFQQG2GdNb+r3Fkp0FOh1NJSvekXDs7jq70k4euu1cryLMfU+mTXlEpw==} + /@esbuild/linux-ia32/0.18.11: + resolution: {integrity: sha512-S3hkIF6KUqRh9n1Q0dSyYcWmcVa9Cg+mSoZEfFuzoYXXsk6196qndrM+ZiHNwpZKi3XOXpShZZ+9dfN5ykqjjw==} engines: {node: '>=12'} - cpu: [loong64] + cpu: [ia32] os: [linux] requiresBuild: true - dev: false optional: true - /@esbuild/linux-loong64@0.15.18: - resolution: {integrity: sha512-L4jVKS82XVhw2nvzLg/19ClLWg0y27ulRwuP7lcyL6AbUWB5aPglXY3M21mauDQMDfRLs8cQmeT03r/+X3cZYQ==} + /@esbuild/linux-loong64/0.14.54: + resolution: {integrity: sha512-bZBrLAIX1kpWelV0XemxBZllyRmM6vgFQQG2GdNb+r3Fkp0FOh1NJSvekXDs7jq70k4euu1cryLMfU+mTXlEpw==} engines: {node: '>=12'} cpu: [loong64] os: [linux] requiresBuild: true - dev: true + dev: false optional: true - /@esbuild/linux-loong64@0.17.18: - resolution: {integrity: sha512-bvPG+MyFs5ZlwYclCG1D744oHk1Pv7j8psF5TfYx7otCVmcJsEXgFEhQkbhNW8otDHL1a2KDINW20cfCgnzgMQ==} + /@esbuild/linux-loong64/0.17.19: + resolution: {integrity: sha512-2iAngUbBPMq439a+z//gE+9WBldoMp1s5GWsUSgqHLzLJ9WoZLZhpwWuym0u0u/4XmZ3gpHmzV84PonE+9IIdQ==} engines: {node: '>=12'} cpu: [loong64] os: [linux] requiresBuild: true + dev: true optional: true - /@esbuild/linux-loong64@0.18.11: + /@esbuild/linux-loong64/0.18.11: resolution: {integrity: sha512-MRESANOoObQINBA+RMZW+Z0TJWpibtE7cPFnahzyQHDCA9X9LOmGh68MVimZlM9J8n5Ia8lU773te6O3ILW8kw==} engines: {node: '>=12'} cpu: [loong64] os: [linux] requiresBuild: true - dev: true optional: true - /@esbuild/linux-mips64el@0.17.18: - resolution: {integrity: sha512-oVqckATOAGuiUOa6wr8TXaVPSa+6IwVJrGidmNZS1cZVx0HqkTMkqFGD2HIx9H1RvOwFeWYdaYbdY6B89KUMxA==} + /@esbuild/linux-mips64el/0.17.19: + resolution: {integrity: sha512-LKJltc4LVdMKHsrFe4MGNPp0hqDFA1Wpt3jE1gEyM3nKUvOiO//9PheZZHfYRfYl6AwdTH4aTcXSqBerX0ml4A==} engines: {node: '>=12'} cpu: [mips64el] os: [linux] requiresBuild: true + dev: true optional: true - /@esbuild/linux-mips64el@0.18.11: + /@esbuild/linux-mips64el/0.18.11: resolution: {integrity: sha512-qVyPIZrXNMOLYegtD1u8EBccCrBVshxMrn5MkuFc3mEVsw7CCQHaqZ4jm9hbn4gWY95XFnb7i4SsT3eflxZsUg==} engines: {node: '>=12'} cpu: [mips64el] os: [linux] requiresBuild: true - dev: true optional: true - /@esbuild/linux-ppc64@0.17.18: - resolution: {integrity: sha512-3dLlQO+b/LnQNxgH4l9rqa2/IwRJVN9u/bK63FhOPB4xqiRqlQAU0qDU3JJuf0BmaH0yytTBdoSBHrb2jqc5qQ==} + /@esbuild/linux-ppc64/0.17.19: + resolution: {integrity: sha512-/c/DGybs95WXNS8y3Ti/ytqETiW7EU44MEKuCAcpPto3YjQbyK3IQVKfF6nbghD7EcLUGl0NbiL5Rt5DMhn5tg==} engines: {node: '>=12'} cpu: [ppc64] os: [linux] requiresBuild: true + dev: true optional: true - /@esbuild/linux-ppc64@0.18.11: + /@esbuild/linux-ppc64/0.18.11: resolution: {integrity: sha512-T3yd8vJXfPirZaUOoA9D2ZjxZX4Gr3QuC3GztBJA6PklLotc/7sXTOuuRkhE9W/5JvJP/K9b99ayPNAD+R+4qQ==} engines: {node: '>=12'} cpu: [ppc64] os: [linux] requiresBuild: true - dev: true optional: true - /@esbuild/linux-riscv64@0.17.18: - resolution: {integrity: sha512-/x7leOyDPjZV3TcsdfrSI107zItVnsX1q2nho7hbbQoKnmoeUWjs+08rKKt4AUXju7+3aRZSsKrJtaRmsdL1xA==} + /@esbuild/linux-riscv64/0.17.19: + resolution: {integrity: sha512-FC3nUAWhvFoutlhAkgHf8f5HwFWUL6bYdvLc/TTuxKlvLi3+pPzdZiFKSWz/PF30TB1K19SuCxDTI5KcqASJqA==} engines: {node: '>=12'} cpu: [riscv64] os: [linux] requiresBuild: true + dev: true optional: true - /@esbuild/linux-riscv64@0.18.11: + /@esbuild/linux-riscv64/0.18.11: resolution: {integrity: sha512-evUoRPWiwuFk++snjH9e2cAjF5VVSTj+Dnf+rkO/Q20tRqv+644279TZlPK8nUGunjPAtQRCj1jQkDAvL6rm2w==} engines: {node: '>=12'} cpu: [riscv64] os: [linux] requiresBuild: true - dev: true optional: true - /@esbuild/linux-s390x@0.17.18: - resolution: {integrity: sha512-cX0I8Q9xQkL/6F5zWdYmVf5JSQt+ZfZD2bJudZrWD+4mnUvoZ3TDDXtDX2mUaq6upMFv9FlfIh4Gfun0tbGzuw==} + /@esbuild/linux-s390x/0.17.19: + resolution: {integrity: sha512-IbFsFbxMWLuKEbH+7sTkKzL6NJmG2vRyy6K7JJo55w+8xDk7RElYn6xvXtDW8HCfoKBFK69f3pgBJSUSQPr+4Q==} engines: {node: '>=12'} cpu: [s390x] os: [linux] requiresBuild: true + dev: true optional: true - /@esbuild/linux-s390x@0.18.11: + /@esbuild/linux-s390x/0.18.11: resolution: {integrity: sha512-/SlRJ15XR6i93gRWquRxYCfhTeC5PdqEapKoLbX63PLCmAkXZHY2uQm2l9bN0oPHBsOw2IswRZctMYS0MijFcg==} engines: {node: '>=12'} cpu: [s390x] os: [linux] requiresBuild: true - dev: true optional: true - /@esbuild/linux-x64@0.17.18: - resolution: {integrity: sha512-66RmRsPlYy4jFl0vG80GcNRdirx4nVWAzJmXkevgphP1qf4dsLQCpSKGM3DUQCojwU1hnepI63gNZdrr02wHUA==} + /@esbuild/linux-x64/0.17.19: + resolution: {integrity: sha512-68ngA9lg2H6zkZcyp22tsVt38mlhWde8l3eJLWkyLrp4HwMUr3c1s/M2t7+kHIhvMjglIBrFpncX1SzMckomGw==} engines: {node: '>=12'} cpu: [x64] os: [linux] requiresBuild: true + dev: true optional: true - /@esbuild/linux-x64@0.18.11: + /@esbuild/linux-x64/0.18.11: resolution: {integrity: sha512-xcncej+wF16WEmIwPtCHi0qmx1FweBqgsRtEL1mSHLFR6/mb3GEZfLQnx+pUDfRDEM4DQF8dpXIW7eDOZl1IbA==} engines: {node: '>=12'} cpu: [x64] os: [linux] requiresBuild: true - dev: true optional: true - /@esbuild/netbsd-x64@0.17.18: - resolution: {integrity: sha512-95IRY7mI2yrkLlTLb1gpDxdC5WLC5mZDi+kA9dmM5XAGxCME0F8i4bYH4jZreaJ6lIZ0B8hTrweqG1fUyW7jbg==} + /@esbuild/netbsd-x64/0.17.19: + resolution: {integrity: sha512-CwFq42rXCR8TYIjIfpXCbRX0rp1jo6cPIUPSaWwzbVI4aOfX96OXY8M6KNmtPcg7QjYeDmN+DD0Wp3LaBOLf4Q==} engines: {node: '>=12'} cpu: [x64] os: [netbsd] requiresBuild: true + dev: true optional: true - /@esbuild/netbsd-x64@0.18.11: + /@esbuild/netbsd-x64/0.18.11: resolution: {integrity: sha512-aSjMHj/F7BuS1CptSXNg6S3M4F3bLp5wfFPIJM+Km2NfIVfFKhdmfHF9frhiCLIGVzDziggqWll0B+9AUbud/Q==} engines: {node: '>=12'} cpu: [x64] os: [netbsd] requiresBuild: true - dev: true optional: true - /@esbuild/openbsd-x64@0.17.18: - resolution: {integrity: sha512-WevVOgcng+8hSZ4Q3BKL3n1xTv5H6Nb53cBrtzzEjDbbnOmucEVcZeGCsCOi9bAOcDYEeBZbD2SJNBxlfP3qiA==} + /@esbuild/openbsd-x64/0.17.19: + resolution: {integrity: sha512-cnq5brJYrSZ2CF6c35eCmviIN3k3RczmHz8eYaVlNasVqsNY+JKohZU5MKmaOI+KkllCdzOKKdPs762VCPC20g==} engines: {node: '>=12'} cpu: [x64] os: [openbsd] requiresBuild: true + dev: true optional: true - /@esbuild/openbsd-x64@0.18.11: + /@esbuild/openbsd-x64/0.18.11: resolution: {integrity: sha512-tNBq+6XIBZtht0xJGv7IBB5XaSyvYPCm1PxJ33zLQONdZoLVM0bgGqUrXnJyiEguD9LU4AHiu+GCXy/Hm9LsdQ==} engines: {node: '>=12'} cpu: [x64] os: [openbsd] requiresBuild: true - dev: true optional: true - /@esbuild/sunos-x64@0.17.18: - resolution: {integrity: sha512-Rzf4QfQagnwhQXVBS3BYUlxmEbcV7MY+BH5vfDZekU5eYpcffHSyjU8T0xucKVuOcdCsMo+Ur5wmgQJH2GfNrg==} + /@esbuild/sunos-x64/0.17.19: + resolution: {integrity: sha512-vCRT7yP3zX+bKWFeP/zdS6SqdWB8OIpaRq/mbXQxTGHnIxspRtigpkUcDMlSCOejlHowLqII7K2JKevwyRP2rg==} engines: {node: '>=12'} cpu: [x64] os: [sunos] requiresBuild: true + dev: true optional: true - /@esbuild/sunos-x64@0.18.11: + /@esbuild/sunos-x64/0.18.11: resolution: {integrity: sha512-kxfbDOrH4dHuAAOhr7D7EqaYf+W45LsAOOhAet99EyuxxQmjbk8M9N4ezHcEiCYPaiW8Dj3K26Z2V17Gt6p3ng==} engines: {node: '>=12'} cpu: [x64] os: [sunos] requiresBuild: true - dev: true optional: true - /@esbuild/win32-arm64@0.17.18: - resolution: {integrity: sha512-Kb3Ko/KKaWhjeAm2YoT/cNZaHaD1Yk/pa3FTsmqo9uFh1D1Rfco7BBLIPdDOozrObj2sahslFuAQGvWbgWldAg==} + /@esbuild/win32-arm64/0.17.19: + resolution: {integrity: sha512-yYx+8jwowUstVdorcMdNlzklLYhPxjniHWFKgRqH7IFlUEa0Umu3KuYplf1HUZZ422e3NU9F4LGb+4O0Kdcaag==} engines: {node: '>=12'} cpu: [arm64] os: [win32] requiresBuild: true + dev: true optional: true - /@esbuild/win32-arm64@0.18.11: + /@esbuild/win32-arm64/0.18.11: resolution: {integrity: sha512-Sh0dDRyk1Xi348idbal7lZyfSkjhJsdFeuC13zqdipsvMetlGiFQNdO+Yfp6f6B4FbyQm7qsk16yaZk25LChzg==} engines: {node: '>=12'} cpu: [arm64] os: [win32] requiresBuild: true - dev: true optional: true - /@esbuild/win32-ia32@0.17.18: - resolution: {integrity: sha512-0/xUMIdkVHwkvxfbd5+lfG7mHOf2FRrxNbPiKWg9C4fFrB8H0guClmaM3BFiRUYrznVoyxTIyC/Ou2B7QQSwmw==} + /@esbuild/win32-ia32/0.17.19: + resolution: {integrity: sha512-eggDKanJszUtCdlVs0RB+h35wNlb5v4TWEkq4vZcmVt5u/HiDZrTXe2bWFQUez3RgNHwx/x4sk5++4NSSicKkw==} engines: {node: '>=12'} cpu: [ia32] os: [win32] requiresBuild: true + dev: true optional: true - /@esbuild/win32-ia32@0.18.11: + /@esbuild/win32-ia32/0.18.11: resolution: {integrity: sha512-o9JUIKF1j0rqJTFbIoF4bXj6rvrTZYOrfRcGyL0Vm5uJ/j5CkBD/51tpdxe9lXEDouhRgdr/BYzUrDOvrWwJpg==} engines: {node: '>=12'} cpu: [ia32] os: [win32] requiresBuild: true - dev: true optional: true - /@esbuild/win32-x64@0.17.18: - resolution: {integrity: sha512-qU25Ma1I3NqTSHJUOKi9sAH1/Mzuvlke0ioMJRthLXKm7JiSKVwFghlGbDLOO2sARECGhja4xYfRAZNPAkooYg==} + /@esbuild/win32-x64/0.17.19: + resolution: {integrity: sha512-lAhycmKnVOuRYNtRtatQR1LPQf2oYCkRGkSFnseDAKPl8lu5SOsK/e1sXe5a0Pc5kHIHe6P2I/ilntNv2xf3cA==} engines: {node: '>=12'} cpu: [x64] os: [win32] requiresBuild: true + dev: true optional: true - /@esbuild/win32-x64@0.18.11: + /@esbuild/win32-x64/0.18.11: resolution: {integrity: sha512-rQI4cjLHd2hGsM1LqgDI7oOCYbQ6IBOVsX9ejuRMSze0GqXUG2ekwiKkiBU1pRGSeCqFFHxTrcEydB2Hyoz9CA==} engines: {node: '>=12'} cpu: [x64] os: [win32] requiresBuild: true - dev: true optional: true - /@eslint-community/eslint-utils@4.4.0(eslint@8.44.0): + /@eslint-community/eslint-utils/4.4.0_eslint@8.44.0: resolution: {integrity: sha512-1/sA4dwrzBAyeUoQ6oxahHKmrZvsnLCg4RfxW3ZFGGmQkSNQPFNLV9CUEFQP1x9EYXHTo5p6xdhZM1Ne9p/AfA==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: @@ -5678,20 +4071,20 @@ packages: eslint-visitor-keys: 3.4.1 dev: true - /@eslint-community/regexpp@4.5.0: - resolution: {integrity: sha512-vITaYzIcNmjn5tF5uxcZ/ft7/RXGrMUIS9HalWckEOF6ESiwXKoMzAQf2UW0aVd6rnOeExTJVd5hmWXucBKGXQ==} + /@eslint-community/regexpp/4.5.1: + resolution: {integrity: sha512-Z5ba73P98O1KUYCCJTUeVpja9RcGoMdncZ6T49FCUl2lN38JtCJ+3WgIDBv0AuY4WChU5PmtJmOCTlN6FZTFKQ==} engines: {node: ^12.0.0 || ^14.0.0 || >=16.0.0} dev: true - /@eslint/eslintrc@1.4.1: + /@eslint/eslintrc/1.4.1: resolution: {integrity: sha512-XXrH9Uarn0stsyldqDYq8r++mROmWRI1xKMXa640Bb//SY1+ECYX6VzT6Lcx5frD0V30XieqJ0oX9I2Xj5aoMA==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dependencies: ajv: 6.12.6 - debug: 4.3.4(supports-color@8.1.1) - espree: 9.5.2 - globals: 13.19.0 - ignore: 5.2.0 + debug: 4.3.4 + espree: 9.6.0 + globals: 13.20.0 + ignore: 5.2.4 import-fresh: 3.3.0 js-yaml: 4.1.0 minimatch: 3.1.2 @@ -5700,15 +4093,15 @@ packages: - supports-color dev: true - /@eslint/eslintrc@2.1.0: + /@eslint/eslintrc/2.1.0: resolution: {integrity: sha512-Lj7DECXqIVCqnqjjHMPna4vn6GJcMgul/wuS0je9OZ9gsL0zzDpKPVtcG1HaDVc+9y+qgXneTeUMbCqXJNpH1A==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dependencies: ajv: 6.12.6 - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 espree: 9.6.0 - globals: 13.19.0 - ignore: 5.2.0 + globals: 13.20.0 + ignore: 5.2.4 import-fresh: 3.3.0 js-yaml: 4.1.0 minimatch: 3.1.2 @@ -5717,115 +4110,125 @@ packages: - supports-color dev: true - /@eslint/js@8.44.0: + /@eslint/js/8.44.0: resolution: {integrity: sha512-Ag+9YM4ocKQx9AarydN0KY2j0ErMHNIocPDrVo8zAE44xLTjEtz81OdR68/cydGtk6m6jDb5Za3r2useMzYmSw==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dev: true - /@faker-js/faker@8.0.2: + /@faker-js/faker/8.0.2: resolution: {integrity: sha512-Uo3pGspElQW91PCvKSIAXoEgAUlRnH29sX2/p89kg7sP1m2PzCufHINd0FhTXQf6DYGiUlVncdSPa2F9wxed2A==} engines: {node: ^14.17.0 || ^16.13.0 || >=18.0.0, npm: '>=6.14.13'} dev: true - /@fastify/ajv-compiler@3.2.0: - resolution: {integrity: sha512-JrqgKmZoh1AJojDZk699DupQ9+tz5gSy7/w+5DrkXy5whM5IcqdV3SjG5qnOqgVJT1nPtUMDY0xYus2j6vwJiw==} + /@fastify/ajv-compiler/3.5.0: + resolution: {integrity: sha512-ebbEtlI7dxXF5ziNdr05mOY8NnDiPB1XvAlLHctRt/Rc+C3LCOVW5imUVX+mhvUhnNzmPBHewUkOFgGlCxgdAA==} dependencies: - ajv: 8.11.0 - ajv-formats: 2.1.1(ajv@8.11.0) - fast-uri: 2.1.0 + ajv: 8.12.0 + ajv-formats: 2.1.1 + fast-uri: 2.2.0 dev: true - /@fastify/deepmerge@1.1.0: - resolution: {integrity: sha512-E8Hfdvs1bG6u0N4vN5Nty6JONUfTdOciyD5rn8KnEsLKIenvOVcr210BQR9t34PRkNyjqnMLGk3e0BsaxRdL+g==} + /@fastify/deepmerge/1.3.0: + resolution: {integrity: sha512-J8TOSBq3SoZbDhM9+R/u77hP93gz/rajSA+K2kGyijPpORPWUXHUpTaleoj+92As0S9uPRP7Oi8IqMf0u+ro6A==} dev: true - /@fastify/error@3.0.0: - resolution: {integrity: sha512-dPRyT40GiHRzSCll3/Jn2nPe25+E1VXc9tDwRAIKwFCxd5Np5wzgz1tmooWG3sV0qKgrBibihVoCna2ru4SEFg==} + /@fastify/error/3.3.0: + resolution: {integrity: sha512-dj7vjIn1Ar8sVXj2yAXiMNCJDmS9MQ9XMlIecX2dIzzhjSHCyKo4DdXjXMs7wKW2kj6yvVRSpuQjOZ3YLrh56w==} dev: true - /@fastify/fast-json-stringify-compiler@4.1.0: - resolution: {integrity: sha512-cTKBV2J9+u6VaKDhX7HepSfPSzw+F+TSd+k0wzifj4rG+4E5PjSFJCk19P8R6tr/72cuzgGd+mbB3jFT6lvAgw==} + /@fastify/fast-json-stringify-compiler/4.3.0: + resolution: {integrity: sha512-aZAXGYo6m22Fk1zZzEUKBvut/CIIQe/BapEORnxiD5Qr0kPHqqI69NtEMCme74h+at72sPhbkb4ZrLd1W3KRLA==} dependencies: - fast-json-stringify: 5.2.0 + fast-json-stringify: 5.7.0 dev: true - /@floating-ui/core@0.3.1: + /@floating-ui/core/0.3.1: resolution: {integrity: sha512-ensKY7Ub59u16qsVIFEo2hwTCqZ/r9oZZFh51ivcLGHfUwTn8l1Xzng8RJUe91H/UP8PeqeBronAGx0qmzwk2g==} dev: true - /@floating-ui/dom@0.1.10: + /@floating-ui/dom/0.1.10: resolution: {integrity: sha512-4kAVoogvQm2N0XE0G6APQJuCNuErjOfPW8Ux7DFxh8+AfugWflwVJ5LDlHOwrwut7z/30NUvdtHzQ3zSip4EzQ==} dependencies: '@floating-ui/core': 0.3.1 dev: true - /@gar/promisify@1.1.3: + /@gar/promisify/1.1.3: resolution: {integrity: sha512-k2Ty1JcVojjJFwrg/ThKi2ujJ7XNLYaFGNB/bWT9wGR+oSMJHMa5w+CUq6p/pVrKeNNgA7pCqEcjSnHVoqJQFw==} dev: true - /@graphql-typed-document-node/core@3.1.1(graphql@16.6.0): - resolution: {integrity: sha512-NQ17ii0rK1b34VZonlmT2QMJFI70m0TRwbknO/ihlbatXyaktDhN/98vBiUU6kNBPljqGqyIrl2T4nY2RpFANg==} + /@graphql-typed-document-node/core/3.2.0: + resolution: {integrity: sha512-mB9oAsNCm9aM3/SOv4YtBMqZbYj10R7dkq8byBqxGY/ncFwhf2oQzMV+LCRlWoDSEBJ3COiR1yeDvMtsoOsuFQ==} peerDependencies: - graphql: ^0.8.0 || ^0.9.0 || ^0.10.0 || ^0.11.0 || ^0.12.0 || ^0.13.0 || ^14.0.0 || ^15.0.0 || ^16.0.0 - dependencies: - graphql: 16.6.0 + graphql: ^0.8.0 || ^0.9.0 || ^0.10.0 || ^0.11.0 || ^0.12.0 || ^0.13.0 || ^14.0.0 || ^15.0.0 || ^16.0.0 || ^17.0.0 dev: false - /@humanwhocodes/config-array@0.11.10: + /@humanwhocodes/config-array/0.11.10: resolution: {integrity: sha512-KVVjQmNUepDVGXNuoRRdmmEjruj0KfiGSbS8LVc12LMsWDQzRXJ0qdhN8L8uUigKpfEHRhlaQFY0ib1tnUbNeQ==} engines: {node: '>=10.10.0'} dependencies: '@humanwhocodes/object-schema': 1.2.1 - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 minimatch: 3.1.2 transitivePeerDependencies: - supports-color dev: true - /@humanwhocodes/config-array@0.9.5: + /@humanwhocodes/config-array/0.9.5: resolution: {integrity: sha512-ObyMyWxZiCu/yTisA7uzx81s40xR2fD5Cg/2Kq7G02ajkNubJf6BopgDTmDyc3U7sXpNKM8cYOw7s7Tyr+DnCw==} engines: {node: '>=10.10.0'} dependencies: '@humanwhocodes/object-schema': 1.2.1 - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 minimatch: 3.1.2 transitivePeerDependencies: - supports-color dev: true - /@humanwhocodes/module-importer@1.0.1: + /@humanwhocodes/module-importer/1.0.1: resolution: {integrity: sha512-bxveV4V8v5Yb4ncFTT3rPSgZBOpCkjfK0y4oVVVJwIuDVBRMDXrPyXRL988i5ap9m9bnyEEjWfm5WkBmtffLfA==} engines: {node: '>=12.22'} dev: true - /@humanwhocodes/object-schema@1.2.1: + /@humanwhocodes/object-schema/1.2.1: resolution: {integrity: sha512-ZnQMnLV4e7hDlUvw8H+U8ASL02SS2Gn6+9Ac3wGGLIe7+je2AeAOxPY+izIPJDfFDb7eDjev0Us8MO1iFRN8hA==} dev: true - /@iconify-json/carbon@1.1.18: + /@iconify-json/carbon/1.1.18: resolution: {integrity: sha512-RbKET6KS9xUMeYVq1FUH3UUA7AYNcnApkHt2AccCwTWTQQs/O58ji4Of6z6PhRajGlbfvrJzT/Uqh19OKECRvA==} dependencies: '@iconify/types': 2.0.0 dev: true - /@iconify/types@2.0.0: + /@iconify/types/2.0.0: resolution: {integrity: sha512-+wluvCrRhXrhyOmRDJ3q8mux9JkKy5SJ/v8ol2tu4FVjyYvtEzkc/3pK15ET6RKg4b4w4BmTk1+gsCUhf21Ykg==} dev: true - /@iconify/utils@2.1.7: + /@iconify/utils/2.1.7: resolution: {integrity: sha512-P8S3z/L1LcV4Qem9AoCfVAaTFGySEMzFEY4CHZLkfRj0Fv9LiR+AwjDgrDrzyI93U2L2mg9JHsbTJ52mF8suNw==} dependencies: '@antfu/install-pkg': 0.1.1 - '@antfu/utils': 0.7.4 + '@antfu/utils': 0.7.5 '@iconify/types': 2.0.0 - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 kolorist: 1.8.0 local-pkg: 0.4.3 transitivePeerDependencies: - supports-color dev: true - /@istanbuljs/load-nyc-config@1.1.0: + /@isaacs/cliui/8.0.2: + resolution: {integrity: sha512-O8jcjabXaleOG9DQ0+ARXWZBTfnP4WNAqzuiJK7ll44AmxGKv/J2M4TPjxjY3znBCfvBXFzucm1twdyFybFqEA==} + engines: {node: '>=12'} + dependencies: + string-width: 5.1.2 + string-width-cjs: /string-width/4.2.3 + strip-ansi: 7.1.0 + strip-ansi-cjs: /strip-ansi/6.0.1 + wrap-ansi: 8.1.0 + wrap-ansi-cjs: /wrap-ansi/7.0.0 + dev: true + + /@istanbuljs/load-nyc-config/1.1.0: resolution: {integrity: sha512-VjeHSlIzpv/NyD3N0YuHfXOPDIixcA1q2ZV98wsMqcYlPmv2n3Yb2lYP9XMElnaFVXg5A7YLTeLu6V84uQDjmQ==} engines: {node: '>=8'} dependencies: @@ -5836,219 +4239,39 @@ packages: resolve-from: 5.0.0 dev: true - /@istanbuljs/schema@0.1.3: + /@istanbuljs/schema/0.1.3: resolution: {integrity: sha512-ZXRY4jNvVgSVQ8DL3LTcakaAtXwTVUxE81hslsyD2AtoXW/wVob10HkOJ1X/pAlcI7D+2YoZKg5do8G/w6RYgA==} engines: {node: '>=8'} - /@jest/console@27.5.1: - resolution: {integrity: sha512-kZ/tNpS3NXn0mlXXXPNuDZnb4c0oZ20r4K5eemM2k30ZC3G0T02nXUvyhf5YdbXWHPEJLc9qGLxEZ216MdL+Zg==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - '@jest/types': 27.5.1 - '@types/node': 20.4.1 - chalk: 4.1.2 - jest-message-util: 27.5.1 - jest-util: 27.5.1 - slash: 3.0.0 - dev: true - - /@jest/core@27.5.1(ts-node@10.9.1): - resolution: {integrity: sha512-AK6/UTrvQD0Cd24NSqmIA6rKsu0tKIxfiCducZvqxYdmMisOYAsdItspT+fQDQYARPf8XgjAFZi0ogW2agH5nQ==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - peerDependencies: - node-notifier: ^8.0.1 || ^9.0.0 || ^10.0.0 - peerDependenciesMeta: - node-notifier: - optional: true - dependencies: - '@jest/console': 27.5.1 - '@jest/reporters': 27.5.1 - '@jest/test-result': 27.5.1 - '@jest/transform': 27.5.1 - '@jest/types': 27.5.1 - '@types/node': 20.4.1 - ansi-escapes: 4.3.2 - chalk: 4.1.2 - emittery: 0.8.1 - exit: 0.1.2 - graceful-fs: 4.2.10 - jest-changed-files: 27.5.1 - jest-config: 27.5.1(ts-node@10.9.1) - jest-haste-map: 27.5.1 - jest-message-util: 27.5.1 - jest-regex-util: 27.5.1 - jest-resolve: 27.5.1 - jest-resolve-dependencies: 27.5.1 - jest-runner: 27.5.1 - jest-runtime: 27.5.1 - jest-snapshot: 27.5.1 - jest-util: 27.5.1 - jest-validate: 27.5.1 - jest-watcher: 27.5.1 - micromatch: 4.0.5 - rimraf: 3.0.2 - slash: 3.0.0 - strip-ansi: 6.0.1 - transitivePeerDependencies: - - bufferutil - - canvas - - supports-color - - ts-node - - utf-8-validate - dev: true - - /@jest/environment@27.5.1: - resolution: {integrity: sha512-/WQjhPJe3/ghaol/4Bq480JKXV/Rfw8nQdN7f41fM8VDHLcxKXou6QyXAh3EFr9/bVG3x74z1NWDkP87EiY8gA==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - '@jest/fake-timers': 27.5.1 - '@jest/types': 27.5.1 - '@types/node': 20.4.1 - jest-mock: 27.5.1 - dev: true - - /@jest/expect-utils@29.0.1: - resolution: {integrity: sha512-Tw5kUUOKmXGQDmQ9TSgTraFFS7HMC1HG/B7y0AN2G2UzjdAXz9BzK2rmNpCSDl7g7y0Gf/VLBm//blonvhtOTQ==} + /@jest/expect-utils/29.6.1: + resolution: {integrity: sha512-o319vIf5pEMx0LmzSxxkYYxo4wrRLKHq9dP1yJU7FoPTB0LfAKSz8SWD6D/6U3v/O52t9cF5t+MeJiRsfk7zMw==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: - jest-get-type: 29.0.0 - dev: true - - /@jest/fake-timers@27.5.1: - resolution: {integrity: sha512-/aPowoolwa07k7/oM3aASneNeBGCmGQsc3ugN4u6s4C/+s5M64MFo/+djTdiwcbQlRfFElGuDXWzaWj6QgKObQ==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - '@jest/types': 27.5.1 - '@sinonjs/fake-timers': 8.1.0 - '@types/node': 20.4.1 - jest-message-util: 27.5.1 - jest-mock: 27.5.1 - jest-util: 27.5.1 - dev: true - - /@jest/globals@27.5.1: - resolution: {integrity: sha512-ZEJNB41OBQQgGzgyInAv0UUfDDj3upmHydjieSxFvTRuZElrx7tXg/uVQ5hYVEwiXs3+aMsAeEc9X7xiSKCm4Q==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - '@jest/environment': 27.5.1 - '@jest/types': 27.5.1 - expect: 27.5.1 - dev: true - - /@jest/reporters@27.5.1: - resolution: {integrity: sha512-cPXh9hWIlVJMQkVk84aIvXuBB4uQQmFqZiacloFuGiP3ah1sbCxCosidXFDfqG8+6fO1oR2dTJTlsOy4VFmUfw==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - peerDependencies: - node-notifier: ^8.0.1 || ^9.0.0 || ^10.0.0 - peerDependenciesMeta: - node-notifier: - optional: true - dependencies: - '@bcoe/v8-coverage': 0.2.3 - '@jest/console': 27.5.1 - '@jest/test-result': 27.5.1 - '@jest/transform': 27.5.1 - '@jest/types': 27.5.1 - '@types/node': 20.4.1 - chalk: 4.1.2 - collect-v8-coverage: 1.0.1 - exit: 0.1.2 - glob: 7.2.3 - graceful-fs: 4.2.10 - istanbul-lib-coverage: 3.2.0 - istanbul-lib-instrument: 5.2.1 - istanbul-lib-report: 3.0.1 - istanbul-lib-source-maps: 4.0.1 - istanbul-reports: 3.1.5 - jest-haste-map: 27.5.1 - jest-resolve: 27.5.1 - jest-util: 27.5.1 - jest-worker: 27.5.1 - slash: 3.0.0 - source-map: 0.6.1 - string-length: 4.0.2 - terminal-link: 2.1.1 - v8-to-istanbul: 8.1.1 - transitivePeerDependencies: - - supports-color + jest-get-type: 29.4.3 dev: true - /@jest/schemas@29.4.3: - resolution: {integrity: sha512-VLYKXQmtmuEz6IxJsrZwzG9NvtkQsWNnWMsKxqWNu3+CnfzJQhp0WDDKWLVV9hLKr0l3SLLFRqcYHjhtyuDVxg==} + /@jest/schemas/29.6.0: + resolution: {integrity: sha512-rxLjXyJBTL4LQeJW3aKo0M/+GkCOXsO+8i9Iu7eDb6KwtP65ayoDsitrdPBtujxQ88k4wI2FNYfa6TOGwSn6cQ==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: - '@sinclair/typebox': 0.25.24 - - /@jest/source-map@27.5.1: - resolution: {integrity: sha512-y9NIHUYF3PJRlHk98NdC/N1gl88BL08aQQgu4k4ZopQkCw9t9cV8mtl3TV8b/YCB8XaVTFrmUTAJvjsntDireg==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - callsites: 3.1.0 - graceful-fs: 4.2.10 - source-map: 0.6.1 - dev: true - - /@jest/test-result@27.5.1: - resolution: {integrity: sha512-EW35l2RYFUcUQxFJz5Cv5MTOxlJIQs4I7gxzi2zVU7PJhOwfYq1MdC5nhSmYjX1gmMmLPvB3sIaC+BkcHRBfag==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - '@jest/console': 27.5.1 - '@jest/types': 27.5.1 - '@types/istanbul-lib-coverage': 2.0.4 - collect-v8-coverage: 1.0.1 - dev: true - - /@jest/test-sequencer@27.5.1: - resolution: {integrity: sha512-LCheJF7WB2+9JuCS7VB/EmGIdQuhtqjRNI9A43idHv3E4KltCTsPsLxvdaubFHSYwY/fNjMWjl6vNRhDiN7vpQ==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - '@jest/test-result': 27.5.1 - graceful-fs: 4.2.10 - jest-haste-map: 27.5.1 - jest-runtime: 27.5.1 - transitivePeerDependencies: - - supports-color - dev: true + '@sinclair/typebox': 0.27.8 - /@jest/transform@26.6.2: + /@jest/transform/26.6.2: resolution: {integrity: sha512-E9JjhUgNzvuQ+vVAL21vlyfy12gP0GhazGgJC4h6qUt1jSdUXGWJ1wfu/X7Sd8etSgxV4ovT1pb9v5D6QW4XgA==} engines: {node: '>= 10.14.2'} dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 '@jest/types': 26.6.2 babel-plugin-istanbul: 6.1.1 chalk: 4.1.2 convert-source-map: 1.9.0 fast-json-stable-stringify: 2.1.0 - graceful-fs: 4.2.10 + graceful-fs: 4.2.11 jest-haste-map: 26.6.2 jest-regex-util: 26.0.0 jest-util: 26.6.2 micromatch: 4.0.5 - pirates: 4.0.5 - slash: 3.0.0 - source-map: 0.6.1 - write-file-atomic: 3.0.3 - transitivePeerDependencies: - - supports-color - dev: true - - /@jest/transform@27.5.1: - resolution: {integrity: sha512-ipON6WtYgl/1329g5AIJVbUuEh0wZVbdpGwC99Jw4LwuoBNS95MVphU6zOeD9pDkon+LLbFL7lOQRapbB8SCHw==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - '@babel/core': 7.22.5 - '@jest/types': 27.5.1 - babel-plugin-istanbul: 6.1.1 - chalk: 4.1.2 - convert-source-map: 1.9.0 - fast-json-stable-stringify: 2.1.0 - graceful-fs: 4.2.10 - jest-haste-map: 27.5.1 - jest-regex-util: 27.5.1 - jest-util: 27.5.1 - micromatch: 4.0.5 - pirates: 4.0.5 + pirates: 4.0.6 slash: 3.0.0 source-map: 0.6.1 write-file-atomic: 3.0.3 @@ -6056,129 +4279,122 @@ packages: - supports-color dev: true - /@jest/types@26.6.2: + /@jest/types/26.6.2: resolution: {integrity: sha512-fC6QCp7Sc5sX6g8Tvbmj4XUTbyrik0akgRy03yjXbQaBWWNWGE7SGtJk98m0N8nzegD/7SggrUlivxo5ax4KWQ==} engines: {node: '>= 10.14.2'} dependencies: '@types/istanbul-lib-coverage': 2.0.4 '@types/istanbul-reports': 3.0.1 '@types/node': 20.4.1 - '@types/yargs': 15.0.14 - chalk: 4.1.2 - dev: true - - /@jest/types@27.5.1: - resolution: {integrity: sha512-Cx46iJ9QpwQTjIdq5VJu2QTMMs3QlEjI0x1QbBP5W1+nMzyc2XmimiRR/CbX9TO0cPTeUlxWMOu8mslYsJ8DEw==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - '@types/istanbul-lib-coverage': 2.0.4 - '@types/istanbul-reports': 3.0.1 - '@types/node': 20.4.1 - '@types/yargs': 16.0.5 + '@types/yargs': 15.0.15 chalk: 4.1.2 dev: true - /@jest/types@29.0.1: - resolution: {integrity: sha512-ft01rxzVsbh9qZPJ6EFgAIj3PT9FCRfBF9Xljo2/33VDOUjLZr0ZJ2oKANqh9S/K0/GERCsHDAQlBwj7RxA+9g==} + /@jest/types/29.6.1: + resolution: {integrity: sha512-tPKQNMPuXgvdOn2/Lg9HNfUvjYVGolt04Hp03f5hAk878uwOLikN+JzeLY0HcVgKgFl9Hs3EIqpu3WX27XNhnw==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: - '@jest/schemas': 29.4.3 + '@jest/schemas': 29.6.0 '@types/istanbul-lib-coverage': 2.0.4 '@types/istanbul-reports': 3.0.1 '@types/node': 20.4.1 - '@types/yargs': 17.0.12 + '@types/yargs': 17.0.24 chalk: 4.1.2 dev: true - /@joshwooding/vite-plugin-react-docgen-typescript@0.0.4(typescript@4.8.4)(vite@4.3.9): + /@joshwooding/vite-plugin-react-docgen-typescript/0.0.4_ilntetca2wlekmurdwyomywvbi: resolution: {integrity: sha512-ezL7SU//1OV4Oyt/zQ3CsX8uLujVEYUHuULkqgcW6wOuQfRnvgkn99HZtLWwS257GmZVwszGQzhL7VE3PbMAYw==} peerDependencies: typescript: '>= 4.3.x' vite: '>2.0.0-0' dependencies: glob: 7.2.3 - glob-promise: 4.2.2(glob@7.2.3) + glob-promise: 4.2.2_glob@7.2.3 magic-string: 0.26.7 - react-docgen-typescript: 2.2.2(typescript@4.8.4) - typescript: 4.8.4 - vite: 4.3.9(@types/node@18.16.19) + react-docgen-typescript: 2.2.2_typescript@4.9.5 + typescript: 4.9.5 + vite: 4.4.3 dev: true - /@jridgewell/gen-mapping@0.1.1: - resolution: {integrity: sha512-sQXCasFk+U8lWYEe66WxRDOE9PjVz4vSM51fTu3Hw+ClTpUSQb718772vH3pyS5pShp6lvQM7SxgIDXXXmOX7w==} - engines: {node: '>=6.0.0'} - dependencies: - '@jridgewell/set-array': 1.1.2 - '@jridgewell/sourcemap-codec': 1.4.15 - - /@jridgewell/gen-mapping@0.3.2: - resolution: {integrity: sha512-mh65xKQAzI6iBcFzwv28KVWSmCkdRBWoOh+bYQGW3+6OZvbbN3TqMGo5hqYxQniRcH9F2VZIoJCm4pa3BPDK/A==} + /@jridgewell/gen-mapping/0.3.3: + resolution: {integrity: sha512-HLhSWOLRi875zjjMG/r+Nv0oCW8umGb0BgEhyX3dDX3egwZtB8PqLnjz3yedt8R5StBrzcg4aBpnh8UA9D1BoQ==} engines: {node: '>=6.0.0'} dependencies: '@jridgewell/set-array': 1.1.2 '@jridgewell/sourcemap-codec': 1.4.15 '@jridgewell/trace-mapping': 0.3.18 - /@jridgewell/resolve-uri@3.1.0: + /@jridgewell/resolve-uri/3.1.0: resolution: {integrity: sha512-F2msla3tad+Mfht5cJq7LSXcdudKTWCVYUgw6pLFOOHSTtZlj6SWNYAp+AhuqLmWdBO2X5hPrLcu8cVP8fy28w==} engines: {node: '>=6.0.0'} - /@jridgewell/set-array@1.1.2: + /@jridgewell/resolve-uri/3.1.1: + resolution: {integrity: sha512-dSYZh7HhCDtCKm4QakX0xFpsRDqjjtZf/kjI/v3T3Nwt5r8/qz/M19F9ySyOqU94SXBmeG9ttTul+YnR4LOxFA==} + engines: {node: '>=6.0.0'} + dev: true + + /@jridgewell/set-array/1.1.2: resolution: {integrity: sha512-xnkseuNADM0gt2bs+BvhO0p78Mk762YnZdsuzFV018NoG1Sj1SCQvpSqa7XUaTam5vAGasABV9qXASMKnFMwMw==} engines: {node: '>=6.0.0'} - /@jridgewell/source-map@0.3.2: - resolution: {integrity: sha512-m7O9o2uR8k2ObDysZYzdfhb08VuEml5oWGiosa1VdaPZ/A6QyPkAJuwN0Q1lhULOf6B7MtQmHENS743hWtCrgw==} + /@jridgewell/source-map/0.3.5: + resolution: {integrity: sha512-UTYAUj/wviwdsMfzoSJspJxbkH5o1snzwX0//0ENX1u/55kkZZkcTZP6u9bwKGkv+dkk9at4m1Cpt0uY80kcpQ==} dependencies: - '@jridgewell/gen-mapping': 0.3.2 + '@jridgewell/gen-mapping': 0.3.3 '@jridgewell/trace-mapping': 0.3.18 dev: true - /@jridgewell/sourcemap-codec@1.4.14: + /@jridgewell/sourcemap-codec/1.4.14: resolution: {integrity: sha512-XPSJHWmi394fuUuzDnGz1wiKqWfo1yXecHQMRf2l6hztTO+nPru658AyDngaBe7isIxEkRsPR3FZh+s7iVa4Uw==} - /@jridgewell/sourcemap-codec@1.4.15: + /@jridgewell/sourcemap-codec/1.4.15: resolution: {integrity: sha512-eF2rxCRulEKXHTRiDrDy6erMYWqNw4LPdQ8UQA4huuxaQsVeRPFl2oM8oDGxMFhJUWZf9McpLtJasDDZb/Bpeg==} - /@jridgewell/trace-mapping@0.3.18: + /@jridgewell/trace-mapping/0.3.18: resolution: {integrity: sha512-w+niJYzMHdd7USdiH2U6869nqhD2nbfZXND5Yp93qIbEmnDNk7PD48o+YchRVpzMU7M6jVCbenTR7PA1FLQ9pA==} dependencies: '@jridgewell/resolve-uri': 3.1.0 '@jridgewell/sourcemap-codec': 1.4.14 - /@jridgewell/trace-mapping@0.3.9: + /@jridgewell/trace-mapping/0.3.9: resolution: {integrity: sha512-3Belt6tdc8bPgAtbcmdtNJlirVoTmEb5e2gC94PnkwEW9jI6CAHUeoG85tjWP5WquqfavoMtMwiG4P926ZKKuQ==} dependencies: - '@jridgewell/resolve-uri': 3.1.0 + '@jridgewell/resolve-uri': 3.1.1 '@jridgewell/sourcemap-codec': 1.4.15 dev: true - /@jsdevtools/ez-spawn@3.0.4: + /@jsdevtools/ez-spawn/3.0.4: resolution: {integrity: sha512-f5DRIOZf7wxogefH03RjMPMdBF7ADTWUMoOs9kaJo06EfwF+aFhMZMDZxHg/Xe12hptN9xoZjGso2fdjapBRIA==} engines: {node: '>=10'} dependencies: call-me-maybe: 1.0.2 cross-spawn: 7.0.3 - string-argv: 0.3.1 + string-argv: 0.3.2 type-detect: 4.0.8 dev: true - /@jspm/core@2.0.0-beta.24: + /@jspm/core/2.0.0-beta.24: resolution: {integrity: sha512-a4Bo/80Z6CoJNor5ldgs6002utmmbttP4JYd/FJ0Ob2fVdf6O6ha5SORBCqrnDnBvMc1TlrHY7dCfat5+H0a6A==} dev: false - /@lit/reactive-element@1.4.1: - resolution: {integrity: sha512-qDv4851VFSaBWzpS02cXHclo40jsbAjRXnebNXpm0uVg32kCneZPo9RYVQtrTNICtZ+1wAYHu1ZtxWSWMbKrBw==} + /@lit-labs/ssr-dom-shim/1.1.1: + resolution: {integrity: sha512-kXOeFbfCm4fFf2A3WwVEeQj55tMZa8c8/f9AKHMobQMkzNUfUj+antR3fRPaZJawsa1aZiP/Da3ndpZrwEe4rQ==} dev: false - /@mdx-js/mdx@1.6.22: + /@lit/reactive-element/1.6.2: + resolution: {integrity: sha512-rDfl+QnCYjuIGf5xI2sVJWdYIi56CTCwWa+nidKYX6oIuBYwUbT/vX4qbUDlHiZKJ/3FRNQ/tWJui44p6/stSA==} + dependencies: + '@lit-labs/ssr-dom-shim': 1.1.1 + dev: false + + /@mdx-js/mdx/1.6.22: resolution: {integrity: sha512-AMxuLxPz2j5/6TpF/XSdKpQP1NlG0z11dFOlq+2IP/lSgl11GY8ji6S/rgsViN/L0BDvHvUMruRb7ub+24LUYA==} dependencies: '@babel/core': 7.12.9 - '@babel/plugin-syntax-jsx': 7.12.1(@babel/core@7.12.9) - '@babel/plugin-syntax-object-rest-spread': 7.8.3(@babel/core@7.12.9) + '@babel/plugin-syntax-jsx': 7.12.1_@babel+core@7.12.9 + '@babel/plugin-syntax-object-rest-spread': 7.8.3_@babel+core@7.12.9 '@mdx-js/util': 1.6.22 - babel-plugin-apply-mdx-type-prop: 1.6.22(@babel/core@7.12.9) + babel-plugin-apply-mdx-type-prop: 1.6.22_@babel+core@7.12.9 babel-plugin-extract-import-names: 1.6.22 camelcase-css: 2.0.1 detab: 2.0.4 @@ -6197,7 +4413,7 @@ packages: - supports-color dev: true - /@mdx-js/react@1.6.22(react@17.0.2): + /@mdx-js/react/1.6.22_react@17.0.2: resolution: {integrity: sha512-TDoPum4SHdfPiGSAaRBw7ECyI8VaHpK8GJugbJIJuqyh6kzw9ZLJZW3HGL3NNrJGxcAixUvqROm+YuQOo5eXtg==} peerDependencies: react: ^16.13.1 || ^17.0.0 @@ -6205,11 +4421,11 @@ packages: react: 17.0.2 dev: true - /@mdx-js/util@1.6.22: + /@mdx-js/util/1.6.22: resolution: {integrity: sha512-H1rQc1ZOHANWBvPcW+JpGwr+juXSxM8Q8YCkm3GhZd8REu1fHR3z99CErO1p9pkcfcxZnMdIZdIsXkOHY0NilA==} dev: true - /@mrmlnc/readdir-enhanced@2.2.1: + /@mrmlnc/readdir-enhanced/2.2.1: resolution: {integrity: sha512-bPHp6Ji8b41szTOcaP63VlnbbO5Ny6dwAATtY6JTjh5N2OLrb5Qk/Th5cRkRQhkWCt+EJsYrNB0MiL+Gpn6e3g==} engines: {node: '>=4'} dependencies: @@ -6217,32 +4433,32 @@ packages: glob-to-regexp: 0.3.0 dev: true - /@mswjs/cookies@0.2.2: + /@mswjs/cookies/0.2.2: resolution: {integrity: sha512-mlN83YSrcFgk7Dm1Mys40DLssI1KdJji2CMKN8eOlBqsTADYzj2+jWzsANsUTFbxDMWPD5e9bfA1RGqBpS3O1g==} engines: {node: '>=14'} dependencies: '@types/set-cookie-parser': 2.4.2 - set-cookie-parser: 2.5.1 + set-cookie-parser: 2.6.0 dev: true - /@mswjs/interceptors@0.17.6: - resolution: {integrity: sha512-201pBIWehTURb6q8Gheu4Zhvd3Ox1U4BJq5KiOQsYzkWyfiOG4pwcz5hPZIEryztgrf8/sdwABpvY757xMmfrQ==} + /@mswjs/interceptors/0.17.9: + resolution: {integrity: sha512-4LVGt03RobMH/7ZrbHqRxQrS9cc2uh+iNKSj8UWr8M26A2i793ju+csaB5zaqYltqJmA2jUq4VeYfKmVqvsXQg==} engines: {node: '>=14'} dependencies: '@open-draft/until': 1.0.3 '@types/debug': 4.1.8 - '@xmldom/xmldom': 0.8.6 - debug: 4.3.4(supports-color@8.1.1) + '@xmldom/xmldom': 0.8.8 + debug: 4.3.4 headers-polyfill: 3.1.2 - outvariant: 1.3.0 + outvariant: 1.4.0 strict-event-emitter: 0.2.8 web-encoding: 1.1.5 transitivePeerDependencies: - supports-color dev: true - /@mui/base@5.0.0-alpha.95(react-dom@18.2.0)(react@18.2.0): - resolution: {integrity: sha512-fcxnDeO7rBwzP0buVdI5fn0aA7NQ/AeUV5RzIIH0kOXVVT21HB4JFf41Qhwd0PIq63PXxmc6Fs2mdlzMYuPo9g==} + /@mui/base/5.0.0-beta.7_biqbaboplfbrettd7655fr4n2y: + resolution: {integrity: sha512-Pjbwm6gjiS96kOMF7E5fjEJsenc0tZBesrLQ4rrdi3eT/c/yhSWnPbCUkHSz8bnS0l3/VQ8bA+oERSGSV2PK6A==} engines: {node: '>=12.0.0'} peerDependencies: '@types/react': ^17.0.0 || ^18.0.0 @@ -6252,24 +4468,24 @@ packages: '@types/react': optional: true dependencies: - '@babel/runtime': 7.18.9 - '@emotion/is-prop-valid': 1.2.0 - '@mui/types': 7.2.0 - '@mui/utils': 5.10.3(react@18.2.0) - '@popperjs/core': 2.11.6 + '@babel/runtime': 7.22.6 + '@emotion/is-prop-valid': 1.2.1 + '@mui/types': 7.2.4 + '@mui/utils': 5.13.7_react@18.2.0 + '@popperjs/core': 2.11.8 clsx: 1.2.1 prop-types: 15.8.1 react: 18.2.0 - react-dom: 18.2.0(react@18.2.0) + react-dom: 18.2.0_react@18.2.0 react-is: 18.2.0 dev: false - /@mui/core-downloads-tracker@5.10.3: - resolution: {integrity: sha512-mX2S0d1oboKBbWQqWIgRmyALAEzh37yiknpD3mKx8bcoMKbp1VtqzIt0aeHP16Uhsd0eValDFILxLNHWi0oddQ==} + /@mui/core-downloads-tracker/5.14.0: + resolution: {integrity: sha512-SYBOVCatVDUf/lbrLGah09bHhX5WfUXg7kSskfLILr6SvKRni0NLp0aonxQ0SMALVVK3Qwa6cW4CdWuwS0gC1w==} dev: false - /@mui/material@5.10.3(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(react-dom@18.2.0)(react@18.2.0): - resolution: {integrity: sha512-g0lzHcqWHYeOEAxTzcwpM1I7b+wyiRTeXkEdRsspnOpZtb0H/1xg386tMFRGbxBJ4zfVGT+TWublofw7pyQkqw==} + /@mui/material/5.14.0_vizhjgize6w4e5tnsjmztd65da: + resolution: {integrity: sha512-HP7CP71NhMkui2HUIEKl2/JfuHMuoarSUWAKlNw6s17bl/Num9rN61EM6uUzc2A2zHjj/00A66GnvDnmixEJEw==} engines: {node: '>=12.0.0'} peerDependencies: '@emotion/react': ^11.5.0 @@ -6285,26 +4501,26 @@ packages: '@types/react': optional: true dependencies: - '@babel/runtime': 7.18.9 - '@emotion/react': 11.10.4(@babel/core@7.22.5)(react@18.2.0) - '@emotion/styled': 11.10.4(@babel/core@7.22.5)(@emotion/react@11.10.4)(react@18.2.0) - '@mui/base': 5.0.0-alpha.95(react-dom@18.2.0)(react@18.2.0) - '@mui/core-downloads-tracker': 5.10.3 - '@mui/system': 5.10.3(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(react@18.2.0) - '@mui/types': 7.2.0 - '@mui/utils': 5.10.3(react@18.2.0) - '@types/react-transition-group': 4.4.5 + '@babel/runtime': 7.22.6 + '@emotion/react': 11.11.1_react@18.2.0 + '@emotion/styled': 11.11.0_xo5t6f4ryb2nvjgwj2cxjowrye + '@mui/base': 5.0.0-beta.7_biqbaboplfbrettd7655fr4n2y + '@mui/core-downloads-tracker': 5.14.0 + '@mui/system': 5.14.0_5uavjbr3lmuxf4a3t6dmknaeea + '@mui/types': 7.2.4 + '@mui/utils': 5.13.7_react@18.2.0 + '@types/react-transition-group': 4.4.6 clsx: 1.2.1 - csstype: 3.1.0 + csstype: 3.1.2 prop-types: 15.8.1 react: 18.2.0 - react-dom: 18.2.0(react@18.2.0) + react-dom: 18.2.0_react@18.2.0 react-is: 18.2.0 - react-transition-group: 4.4.5(react-dom@18.2.0)(react@18.2.0) + react-transition-group: 4.4.5_biqbaboplfbrettd7655fr4n2y dev: false - /@mui/private-theming@5.10.3(react@18.2.0): - resolution: {integrity: sha512-LCYIKlkGz2BTSng2BFzzwSJBRZbChIUri2x2Nh8ryk2B1Ho7zpvE7ex6y39LlStG2Frf92NFC/V4YQbmMAjD5A==} + /@mui/private-theming/5.13.7_react@18.2.0: + resolution: {integrity: sha512-qbSr+udcij5F9dKhGX7fEdx2drXchq7htLNr2Qg2Ma+WJ6q0ERlEqGSBiPiVDJkptcjeVL4DGmcf1wl5+vD4EA==} engines: {node: '>=12.0.0'} peerDependencies: '@types/react': ^17.0.0 || ^18.0.0 @@ -6313,14 +4529,14 @@ packages: '@types/react': optional: true dependencies: - '@babel/runtime': 7.18.9 - '@mui/utils': 5.10.3(react@18.2.0) + '@babel/runtime': 7.22.6 + '@mui/utils': 5.13.7_react@18.2.0 prop-types: 15.8.1 react: 18.2.0 dev: false - /@mui/styled-engine@5.10.3(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(react@18.2.0): - resolution: {integrity: sha512-9Uz7eB8xXoiDvpJ9qBxZ/2xGO8xKfA2T23dw4AsQ69SQtGatrOLAapzP2lNr0tfB9xvKucclPFhRO5aLhDFOVQ==} + /@mui/styled-engine/5.13.2_5uavjbr3lmuxf4a3t6dmknaeea: + resolution: {integrity: sha512-VCYCU6xVtXOrIN8lcbuPmoG+u7FYuOERG++fpY74hPpEWkyFQG97F+/XfTQVYzlR2m7nPjnwVUgATcTCMEaMvw==} engines: {node: '>=12.0.0'} peerDependencies: '@emotion/react': ^11.4.1 @@ -6332,17 +4548,17 @@ packages: '@emotion/styled': optional: true dependencies: - '@babel/runtime': 7.18.9 - '@emotion/cache': 11.10.3 - '@emotion/react': 11.10.4(@babel/core@7.22.5)(react@18.2.0) - '@emotion/styled': 11.10.4(@babel/core@7.22.5)(@emotion/react@11.10.4)(react@18.2.0) + '@babel/runtime': 7.22.6 + '@emotion/cache': 11.11.0 + '@emotion/react': 11.11.1_react@18.2.0 + '@emotion/styled': 11.11.0_xo5t6f4ryb2nvjgwj2cxjowrye csstype: 3.1.2 prop-types: 15.8.1 react: 18.2.0 dev: false - /@mui/system@5.10.3(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(react@18.2.0): - resolution: {integrity: sha512-uLW/CIz3zk1jr5zH0ahOUqJIrpWP02Mv4emfrplh7Mh5JCb/oumhYaC/ALJJEjzUHKg9wwiyuM0pCwK/kSf1jQ==} + /@mui/system/5.14.0_5uavjbr3lmuxf4a3t6dmknaeea: + resolution: {integrity: sha512-0HZGkX8miJbiNw+rjlZ9l0Cfkz1bSqfSHQH0EH9J+nx0aAm5cBleg9piOlLdCNIWGgecCqsw4x62erGrGjjcJg==} engines: {node: '>=12.0.0'} peerDependencies: '@emotion/react': ^11.5.0 @@ -6357,21 +4573,21 @@ packages: '@types/react': optional: true dependencies: - '@babel/runtime': 7.18.9 - '@emotion/react': 11.10.4(@babel/core@7.22.5)(react@18.2.0) - '@emotion/styled': 11.10.4(@babel/core@7.22.5)(@emotion/react@11.10.4)(react@18.2.0) - '@mui/private-theming': 5.10.3(react@18.2.0) - '@mui/styled-engine': 5.10.3(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(react@18.2.0) - '@mui/types': 7.2.0 - '@mui/utils': 5.10.3(react@18.2.0) + '@babel/runtime': 7.22.6 + '@emotion/react': 11.11.1_react@18.2.0 + '@emotion/styled': 11.11.0_xo5t6f4ryb2nvjgwj2cxjowrye + '@mui/private-theming': 5.13.7_react@18.2.0 + '@mui/styled-engine': 5.13.2_5uavjbr3lmuxf4a3t6dmknaeea + '@mui/types': 7.2.4 + '@mui/utils': 5.13.7_react@18.2.0 clsx: 1.2.1 csstype: 3.1.2 prop-types: 15.8.1 react: 18.2.0 dev: false - /@mui/types@7.2.0: - resolution: {integrity: sha512-lGXtFKe5lp3UxTBGqKI1l7G8sE2xBik8qCfrLHD5olwP/YU0/ReWoWT7Lp1//ri32dK39oPMrJN8TgbkCSbsNA==} + /@mui/types/7.2.4: + resolution: {integrity: sha512-LBcwa8rN84bKF+f5sDyku42w1NTxaPgPyYKODsh01U1fVstTClbUoSA96oyRBnSNyEiAVjKm6Gwx9vjR+xyqHA==} peerDependencies: '@types/react': '*' peerDependenciesMeta: @@ -6379,21 +4595,21 @@ packages: optional: true dev: false - /@mui/utils@5.10.3(react@18.2.0): - resolution: {integrity: sha512-4jXMDPfx6bpMVuheLaOpKTjpzw39ogAZLeaLj5+RJec3E37/hAZMYjURfblLfTWMMoGoqkY03mNsZaEwNobBow==} + /@mui/utils/5.13.7_react@18.2.0: + resolution: {integrity: sha512-/3BLptG/q0u36eYED7Nhf4fKXmcKb6LjjT7ZMwhZIZSdSxVqDqSTmATW3a56n3KEPQUXCU9TpxAfCBQhs6brVA==} engines: {node: '>=12.0.0'} peerDependencies: react: ^17.0.0 || ^18.0.0 dependencies: - '@babel/runtime': 7.18.9 + '@babel/runtime': 7.22.6 '@types/prop-types': 15.7.5 - '@types/react-is': 17.0.3 + '@types/react-is': 18.2.1 prop-types: 15.8.1 react: 18.2.0 react-is: 18.2.0 dev: false - /@mui/x-date-pickers@5.0.0-beta.0(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(@mui/material@5.10.3)(@mui/system@5.10.3)(date-fns@2.29.2)(react-dom@18.2.0)(react@18.2.0): + /@mui/x-date-pickers/5.0.0-beta.0_dc6gge3gqnljarlkhzo67xqsla: resolution: {integrity: sha512-WfcYe+5j3xbGO9d+uMFem06b9q+9yIcFj0dP3PKCa1zb6m3Tbkigig6vlCuHLKLSXe1P6IQCt+BNVVbU1rfh7A==} engines: {node: '>=12.0.0'} peerDependencies: @@ -6420,33 +4636,32 @@ packages: moment: optional: true dependencies: - '@babel/runtime': 7.18.9 - '@date-io/core': 2.15.0 - '@date-io/date-fns': 2.15.0(date-fns@2.29.2) - '@date-io/dayjs': 2.15.0 - '@date-io/luxon': 2.15.0 - '@date-io/moment': 2.15.0 - '@emotion/react': 11.10.4(@babel/core@7.22.5)(react@18.2.0) - '@emotion/styled': 11.10.4(@babel/core@7.22.5)(@emotion/react@11.10.4)(react@18.2.0) - '@mui/material': 5.10.3(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(react-dom@18.2.0)(react@18.2.0) - '@mui/system': 5.10.3(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(react@18.2.0) - '@mui/utils': 5.10.3(react@18.2.0) - '@types/react-transition-group': 4.4.5 + '@babel/runtime': 7.22.6 + '@date-io/core': 2.16.0 + '@date-io/date-fns': 2.16.0_date-fns@2.30.0 + '@date-io/dayjs': 2.16.0 + '@date-io/luxon': 2.16.1 + '@date-io/moment': 2.16.1 + '@emotion/react': 11.11.1_react@18.2.0 + '@emotion/styled': 11.11.0_xo5t6f4ryb2nvjgwj2cxjowrye + '@mui/material': 5.14.0_vizhjgize6w4e5tnsjmztd65da + '@mui/utils': 5.13.7_react@18.2.0 + '@types/react-transition-group': 4.4.6 clsx: 1.2.1 - date-fns: 2.29.2 + date-fns: 2.30.0 prop-types: 15.8.1 react: 18.2.0 - react-transition-group: 4.4.5(react-dom@18.2.0)(react@18.2.0) - rifm: 0.12.1(react@18.2.0) + react-transition-group: 4.4.5_biqbaboplfbrettd7655fr4n2y + rifm: 0.12.1_react@18.2.0 transitivePeerDependencies: - react-dom dev: false - /@next/env@12.1.5: + /@next/env/12.1.5: resolution: {integrity: sha512-+34yUJslfJi7Lyx6ELuN8nWcOzi27izfYnZIC1Dqv7kmmfiBVxgzR3BXhlvEMTKC2IRJhXVs2FkMY+buQe3k7Q==} dev: false - /@next/swc-android-arm-eabi@12.1.5: + /@next/swc-android-arm-eabi/12.1.5: resolution: {integrity: sha512-SKnGTdYcoN04Y2DvE0/Y7/MjkA+ltsmbuH/y/hR7Ob7tsj+8ZdOYuk+YvW1B8dY20nDPHP58XgDTSm2nA8BzzA==} engines: {node: '>= 10'} cpu: [arm] @@ -6455,7 +4670,7 @@ packages: dev: false optional: true - /@next/swc-android-arm64@12.1.5: + /@next/swc-android-arm64/12.1.5: resolution: {integrity: sha512-YXiqgQ/9Rxg1dXp6brXbeQM1JDx9SwUY/36JiE+36FXqYEmDYbxld9qkX6GEzkc5rbwJ+RCitargnzEtwGW0mw==} engines: {node: '>= 10'} cpu: [arm64] @@ -6464,7 +4679,7 @@ packages: dev: false optional: true - /@next/swc-darwin-arm64@12.1.5: + /@next/swc-darwin-arm64/12.1.5: resolution: {integrity: sha512-y8mhldb/WFZ6lFeowkGfi0cO/lBdiBqDk4T4LZLvCpoQp4Or/NzUN6P5NzBQZ5/b4oUHM/wQICEM+1wKA4qIVw==} engines: {node: '>= 10'} cpu: [arm64] @@ -6473,7 +4688,7 @@ packages: dev: false optional: true - /@next/swc-darwin-x64@12.1.5: + /@next/swc-darwin-x64/12.1.5: resolution: {integrity: sha512-wqJ3X7WQdTwSGi0kIDEmzw34QHISRIQ5uvC+VXmsIlCPFcMA+zM5723uh8NfuKGquDMiEMS31a83QgkuHMYbwQ==} engines: {node: '>= 10'} cpu: [x64] @@ -6482,7 +4697,7 @@ packages: dev: false optional: true - /@next/swc-linux-arm-gnueabihf@12.1.5: + /@next/swc-linux-arm-gnueabihf/12.1.5: resolution: {integrity: sha512-WnhdM5duONMvt2CncAl+9pim0wBxDS2lHoo7ub/o/i1bRbs11UTzosKzEXVaTDCUkCX2c32lIDi1WcN2ZPkcdw==} engines: {node: '>= 10'} cpu: [arm] @@ -6491,7 +4706,7 @@ packages: dev: false optional: true - /@next/swc-linux-arm64-gnu@12.1.5: + /@next/swc-linux-arm64-gnu/12.1.5: resolution: {integrity: sha512-Jq2H68yQ4bLUhR/XQnbw3LDW0GMQn355qx6rU36BthDLeGue7YV7MqNPa8GKvrpPocEMW77nWx/1yI6w6J07gw==} engines: {node: '>= 10'} cpu: [arm64] @@ -6500,7 +4715,7 @@ packages: dev: false optional: true - /@next/swc-linux-arm64-musl@12.1.5: + /@next/swc-linux-arm64-musl/12.1.5: resolution: {integrity: sha512-KgPjwdbhDqXI7ghNN8V/WAiLquc9Ebe8KBrNNEL0NQr+yd9CyKJ6KqjayVkmX+hbHzbyvbui/5wh/p3CZQ9xcQ==} engines: {node: '>= 10'} cpu: [arm64] @@ -6509,7 +4724,7 @@ packages: dev: false optional: true - /@next/swc-linux-x64-gnu@12.1.5: + /@next/swc-linux-x64-gnu/12.1.5: resolution: {integrity: sha512-O2ErUTvCJ6DkNTSr9pbu1n3tcqykqE/ebty1rwClzIYdOgpB3T2MfEPP+K7GhUR87wmN/hlihO9ch7qpVFDGKw==} engines: {node: '>= 10'} cpu: [x64] @@ -6518,7 +4733,7 @@ packages: dev: false optional: true - /@next/swc-linux-x64-musl@12.1.5: + /@next/swc-linux-x64-musl/12.1.5: resolution: {integrity: sha512-1eIlZmlO/VRjxxzUBcVosf54AFU3ltAzHi+BJA+9U/lPxCYIsT+R4uO3QksRzRjKWhVQMRjEnlXyyq5SKJm7BA==} engines: {node: '>= 10'} cpu: [x64] @@ -6527,7 +4742,7 @@ packages: dev: false optional: true - /@next/swc-win32-arm64-msvc@12.1.5: + /@next/swc-win32-arm64-msvc/12.1.5: resolution: {integrity: sha512-oromsfokbEuVb0CBLLE7R9qX3KGXucZpsojLpzUh1QJjuy1QkrPJncwr8xmWQnwgtQ6ecMWXgXPB+qtvizT9Tw==} engines: {node: '>= 10'} cpu: [arm64] @@ -6536,7 +4751,7 @@ packages: dev: false optional: true - /@next/swc-win32-ia32-msvc@12.1.5: + /@next/swc-win32-ia32-msvc/12.1.5: resolution: {integrity: sha512-a/51L5KzBpeZSW9LbekMo3I3Cwul+V+QKwbEIMA+Qwb2qrlcn1L9h3lt8cHqNTFt2y72ce6aTwDTw1lyi5oIRA==} engines: {node: '>= 10'} cpu: [ia32] @@ -6545,7 +4760,7 @@ packages: dev: false optional: true - /@next/swc-win32-x64-msvc@12.1.5: + /@next/swc-win32-x64-msvc/12.1.5: resolution: {integrity: sha512-/SoXW1Ntpmpw3AXAzfDRaQidnd8kbZ2oSni8u5z0yw6t4RwJvmdZy1eOaAADRThWKV+2oU90++LSnXJIwBRWYQ==} engines: {node: '>= 10'} cpu: [x64] @@ -6554,72 +4769,79 @@ packages: dev: false optional: true - /@nodelib/fs.scandir@2.1.5: + /@nicolo-ribaudo/semver-v6/6.3.3: + resolution: {integrity: sha512-3Yc1fUTs69MG/uZbJlLSI3JISMn2UV2rg+1D/vROUqZyh3l6iYHCs7GMp+M40ZD7yOdDbYjJcU1oTJhrc+dGKg==} + hasBin: true + + /@nodelib/fs.scandir/2.1.5: resolution: {integrity: sha512-vq24Bq3ym5HEQm2NKCr3yXDwjc7vTsEThRDnkp2DK9p1uqLR+DHurm/NOTo0KG7HYHU7eppKZj3MyqYuMBf62g==} engines: {node: '>= 8'} dependencies: '@nodelib/fs.stat': 2.0.5 run-parallel: 1.2.0 - /@nodelib/fs.stat@1.1.3: + /@nodelib/fs.stat/1.1.3: resolution: {integrity: sha512-shAmDyaQC4H92APFoIaVDHCx5bStIocgvbwQyxPRrbUY20V1EYTbSDchWbuwlMG3V17cprZhA6+78JfB+3DTPw==} engines: {node: '>= 6'} dev: true - /@nodelib/fs.stat@2.0.5: + /@nodelib/fs.stat/2.0.5: resolution: {integrity: sha512-RkhPPp2zrqDAQA/2jNhnztcPAlv64XdhIp7a7454A5ovI7Bukxgt7MX7udwAu3zg1DcpPU0rz3VV1SeaqvY4+A==} engines: {node: '>= 8'} - /@nodelib/fs.walk@1.2.8: + /@nodelib/fs.walk/1.2.8: resolution: {integrity: sha512-oGB+UxlgWcgQkgwo8GcEGwemoTFt3FIO9ababBmaGwXIoBKZ+GTy0pP185beGg7Llih/NSHSV2XAs1lnznocSg==} engines: {node: '>= 8'} dependencies: '@nodelib/fs.scandir': 2.1.5 - fastq: 1.13.0 + fastq: 1.15.0 - /@npmcli/fs@1.1.1: + /@npmcli/fs/1.1.1: resolution: {integrity: sha512-8KG5RD0GVP4ydEzRn/I4BNDuxDtqVbOdm8675T49OIG/NGhaK0pjPX7ZcDlvKYbA+ulvVK3ztfcF4uBdOxuJbQ==} dependencies: '@gar/promisify': 1.1.3 semver: 7.5.4 dev: true - /@npmcli/move-file@1.1.2: + /@npmcli/move-file/1.1.2: resolution: {integrity: sha512-1SUf/Cg2GzGDyaf15aR9St9TWlb+XvbZXWpDx8YKs7MLzMH/BCeopv+y9vzrzgkfykCGuWOlSu3mZhj2+FQcrg==} engines: {node: '>=10'} + deprecated: This functionality has been moved to @npmcli/fs dependencies: mkdirp: 1.0.4 rimraf: 3.0.2 dev: true - /@open-draft/until@1.0.3: + /@open-draft/until/1.0.3: resolution: {integrity: sha512-Aq58f5HiWdyDlFffbbSjAlv596h/cOnt2DO1w3DOC7OJ5EHs0hd/nycJfiu9RJbT6Yk6F1knnRRXNSpxoIVZ9Q==} dev: true - /@pkgjs/parseargs@0.11.0: + /@pkgjs/parseargs/0.11.0: resolution: {integrity: sha512-+1VkjdD0QBLPodGrJUeqarH8VAIvQODIbwh9XpP5Syisf7YoQgsJKPNFoqqLQlu+VQ/tVSshMR6loPMn8U+dPg==} engines: {node: '>=14'} requiresBuild: true dev: true optional: true - /@playwright/test@1.28.0: - resolution: {integrity: sha512-vrHs5DFTPwYox5SGKq/7TDn/S4q6RA1zArd7uhO6EyP9hj3XgZBBM12ktMbnDQNxh/fL1IUKsTNLxihmsU38lQ==} - engines: {node: '>=14'} + /@playwright/test/1.36.0: + resolution: {integrity: sha512-yN+fvMYtiyLFDCQos+lWzoX4XW3DNuaxjBu68G0lkgLgC6BP+m/iTxJQoSicz/x2G5EsrqlZTqTIP9sTgLQerg==} + engines: {node: '>=16'} hasBin: true dependencies: '@types/node': 20.4.1 - playwright-core: 1.28.0 + playwright-core: 1.36.0 + optionalDependencies: + fsevents: 2.3.2 dev: true - /@pmmmwh/react-refresh-webpack-plugin@0.5.7(react-refresh@0.11.0)(webpack@5.74.0): - resolution: {integrity: sha512-bcKCAzF0DV2IIROp9ZHkRJa6O4jy7NlnHdWL3GmcUxYWNjLXkK5kfELELwEfSP5hXPfVL/qOGMAROuMQb9GG8Q==} + /@pmmmwh/react-refresh-webpack-plugin/0.5.10_3s7aftcw26g2vhqubpxl7hhzpa: + resolution: {integrity: sha512-j0Ya0hCFZPd4x40qLzbhGsh9TMtdb+CJQiso+WxLOPNasohq9cc5SNUcwsZaRH6++Xh91Xkm/xHCkuIiIu0LUA==} engines: {node: '>= 10.13'} peerDependencies: '@types/webpack': 4.x || 5.x react-refresh: '>=0.10.0 <1.0.0' sockjs-client: ^1.4.0 - type-fest: '>=0.17.0 <3.0.0' + type-fest: '>=0.17.0 <4.0.0' webpack: '>=4.43.0 <6.0.0' webpack-dev-server: 3.x || 4.x webpack-hot-middleware: 2.x @@ -6640,25 +4862,25 @@ packages: dependencies: ansi-html-community: 0.0.8 common-path-prefix: 3.0.0 - core-js-pure: 3.25.0 + core-js-pure: 3.31.1 error-stack-parser: 2.1.4 find-up: 5.0.0 - html-entities: 2.3.3 - loader-utils: 2.0.2 + html-entities: 2.4.0 + loader-utils: 2.0.4 react-refresh: 0.11.0 - schema-utils: 3.1.1 + schema-utils: 3.3.0 source-map: 0.7.4 - webpack: 5.74.0(esbuild@0.18.11) + webpack: 5.88.1 dev: true - /@polka/url@1.0.0-next.21: + /@polka/url/1.0.0-next.21: resolution: {integrity: sha512-a5Sab1C4/icpTZVzZc5Ghpz88yQtGOyNqYXcZgOssB2uuAr+wF/MvN6bgtW32q7HHrvBki+BsZ0OuNv6EV3K9g==} - /@popperjs/core@2.11.6: - resolution: {integrity: sha512-50/17A98tWUfQ176raKiOGXuYpLyyVMkxxG6oylzL3BPOlA6ADGdK7EYunSa4I064xerltq9TGXs8HmOk5E+vw==} + /@popperjs/core/2.11.8: + resolution: {integrity: sha512-P1st0aksCrn9sGZhp8GMYwBnQsbvAWsZAX44oXNNvLHGqAOcoVxmjZiohstwQ7SqKnbR47akdNi+uleWD8+g6A==} dev: false - /@puppeteer/browsers@1.3.0(typescript@5.1.6): + /@puppeteer/browsers/1.3.0: resolution: {integrity: sha512-an3QdbNPkuU6qpxpbssxAbjRLJcF+eP4L8UqIY3+6n0sbaVxw5pz7PiCLy9g32XEZuoamUlV5ZQPnA6FxvkIHA==} engines: {node: '>=16.0.0'} hasBin: true @@ -6668,21 +4890,25 @@ packages: typescript: optional: true dependencies: - debug: 4.3.4(supports-color@8.1.1) - extract-zip: 2.0.1(supports-color@8.1.1) + debug: 4.3.4 + extract-zip: 2.0.1 http-proxy-agent: 5.0.0 https-proxy-agent: 5.0.1 progress: 2.0.3 proxy-from-env: 1.1.0 tar-fs: 2.1.1 - typescript: 5.1.6 unbzip2-stream: 1.4.3 yargs: 17.7.1 transitivePeerDependencies: - supports-color dev: true - /@rollup/plugin-alias@5.0.0(rollup@3.26.0): + /@remix-run/router/1.7.1: + resolution: {integrity: sha512-bgVQM4ZJ2u2CM8k1ey70o1ePFXsEzYVZoWghh6WjM8p59jQ7HxzbHW4SbnWFG7V9ig9chLawQxDTZ3xzOF8MkQ==} + engines: {node: '>=14'} + dev: false + + /@rollup/plugin-alias/5.0.0_rollup@3.26.2: resolution: {integrity: sha512-l9hY5chSCjuFRPsnRm16twWBiSApl2uYFLsepQYwtBuAxNMQ/1dJqADld40P0Jkqm65GRTLy/AC6hnpVebtLsA==} engines: {node: '>=14.0.0'} peerDependencies: @@ -6691,11 +4917,11 @@ packages: rollup: optional: true dependencies: - rollup: 3.26.0 + rollup: 3.26.2 slash: 4.0.0 dev: true - /@rollup/plugin-babel@5.3.1(@babel/core@7.22.5)(rollup@2.79.1): + /@rollup/plugin-babel/5.3.1_dk2tutsrvslwzit5bccevt2cya: resolution: {integrity: sha512-WFfdLWU/xVWKeRQnKmIAQULUI7Il0gZnBIH/ZFO069wYIfPu+8zrfp/KMW0atmELoRDq8FbiP3VCss9MhCut7Q==} engines: {node: '>= 10.0.0'} peerDependencies: @@ -6706,13 +4932,13 @@ packages: '@types/babel__core': optional: true dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 '@babel/helper-module-imports': 7.22.5 - '@rollup/pluginutils': 3.1.0(rollup@2.79.1) + '@rollup/pluginutils': 3.1.0_rollup@2.79.1 rollup: 2.79.1 dev: true - /@rollup/plugin-commonjs@25.0.2(rollup@3.26.0): + /@rollup/plugin-commonjs/25.0.2_rollup@3.26.2: resolution: {integrity: sha512-NGTwaJxIO0klMs+WSFFtBP7b9TdTJ3K76HZkewT8/+yHzMiUGVQgaPtLQxNVYIgT5F7lxkEyVID+yS3K7bhCow==} engines: {node: '>=14.0.0'} peerDependencies: @@ -6721,28 +4947,27 @@ packages: rollup: optional: true dependencies: - '@rollup/pluginutils': 5.0.2(rollup@3.26.0) + '@rollup/pluginutils': 5.0.2_rollup@3.26.2 commondir: 1.0.1 estree-walker: 2.0.2 - glob: 8.0.3 + glob: 8.1.0 is-reference: 1.2.1 magic-string: 0.27.0 - rollup: 3.26.0 + rollup: 3.26.2 dev: true - /@rollup/plugin-graphql@1.1.0(graphql@16.6.0)(rollup@2.79.1): + /@rollup/plugin-graphql/1.1.0_graphql@16.7.1: resolution: {integrity: sha512-X+H6oFlprDlnO3D0UiEytdW97AMphPXO0C7KunS7i/rBXIGQRQVDU5WKTXnBu2tfyYbjCTtfhXMSGI0i885PNg==} peerDependencies: graphql: '>=0.9.0' rollup: ^1.20.0 || ^2.0.0 dependencies: '@rollup/pluginutils': 4.2.1 - graphql: 16.6.0 - graphql-tag: 2.12.6(graphql@16.6.0) - rollup: 2.79.1 + graphql: 16.7.1 + graphql-tag: 2.12.6_graphql@16.7.1 dev: false - /@rollup/plugin-json@6.0.0(rollup@3.26.0): + /@rollup/plugin-json/6.0.0_rollup@3.26.2: resolution: {integrity: sha512-i/4C5Jrdr1XUarRhVu27EEwjt4GObltD7c+MkCIpO2QIbojw8MUs+CCTqOphQi3Qtg1FLmYt+l+6YeoIf51J7w==} engines: {node: '>=14.0.0'} peerDependencies: @@ -6751,17 +4976,17 @@ packages: rollup: optional: true dependencies: - '@rollup/pluginutils': 5.0.2(rollup@3.26.0) - rollup: 3.26.0 + '@rollup/pluginutils': 5.0.2_rollup@3.26.2 + rollup: 3.26.2 dev: true - /@rollup/plugin-node-resolve@11.2.1(rollup@2.79.1): + /@rollup/plugin-node-resolve/11.2.1_rollup@2.79.1: resolution: {integrity: sha512-yc2n43jcqVyGE2sqV5/YCmocy9ArjVAP/BeXyTtADTBBX6V0e5UMqwO8CdQ0kzjb6zu5P1qMzsScCMRvE9OlVg==} engines: {node: '>= 10.0.0'} peerDependencies: rollup: ^1.20.0||^2.0.0 dependencies: - '@rollup/pluginutils': 3.1.0(rollup@2.79.1) + '@rollup/pluginutils': 3.1.0_rollup@2.79.1 '@types/resolve': 1.17.1 builtin-modules: 3.3.0 deepmerge: 4.3.1 @@ -6770,7 +4995,7 @@ packages: rollup: 2.79.1 dev: true - /@rollup/plugin-node-resolve@15.1.0(rollup@3.26.0): + /@rollup/plugin-node-resolve/15.1.0_rollup@3.26.2: resolution: {integrity: sha512-xeZHCgsiZ9pzYVgAo9580eCGqwh/XCEUM9q6iQfGNocjgkufHAqC3exA+45URvhiYV8sBF9RlBai650eNs7AsA==} engines: {node: '>=14.0.0'} peerDependencies: @@ -6779,26 +5004,26 @@ packages: rollup: optional: true dependencies: - '@rollup/pluginutils': 5.0.2(rollup@3.26.0) + '@rollup/pluginutils': 5.0.2_rollup@3.26.2 '@types/resolve': 1.20.2 deepmerge: 4.3.1 is-builtin-module: 3.2.1 is-module: 1.0.0 resolve: 1.22.2 - rollup: 3.26.0 + rollup: 3.26.2 dev: true - /@rollup/plugin-replace@2.4.2(rollup@2.79.1): + /@rollup/plugin-replace/2.4.2_rollup@2.79.1: resolution: {integrity: sha512-IGcu+cydlUMZ5En85jxHH4qj2hta/11BHq95iHEyb2sbgiN0eCdzvUcHw5gt9pBL5lTi4JDYJ1acCoMGpTvEZg==} peerDependencies: rollup: ^1.20.0 || ^2.0.0 dependencies: - '@rollup/pluginutils': 3.1.0(rollup@2.79.1) + '@rollup/pluginutils': 3.1.0_rollup@2.79.1 magic-string: 0.25.9 rollup: 2.79.1 dev: true - /@rollup/pluginutils@3.1.0(rollup@2.79.1): + /@rollup/pluginutils/3.1.0_rollup@2.79.1: resolution: {integrity: sha512-GksZ6pr6TpIjHm8h9lSQ8pi8BE9VeubNT0OMJ3B5uZJ8pz73NPiqOtCog/x2/QzM1ENChPKxMDhiQuRHsqc+lg==} engines: {node: '>= 8.0.0'} peerDependencies: @@ -6810,7 +5035,7 @@ packages: rollup: 2.79.1 dev: true - /@rollup/pluginutils@3.1.0(rollup@3.26.0): + /@rollup/pluginutils/3.1.0_rollup@3.26.2: resolution: {integrity: sha512-GksZ6pr6TpIjHm8h9lSQ8pi8BE9VeubNT0OMJ3B5uZJ8pz73NPiqOtCog/x2/QzM1ENChPKxMDhiQuRHsqc+lg==} engines: {node: '>= 8.0.0'} peerDependencies: @@ -6819,17 +5044,17 @@ packages: '@types/estree': 0.0.39 estree-walker: 1.0.1 picomatch: 2.3.1 - rollup: 3.26.0 + rollup: 3.26.2 dev: false - /@rollup/pluginutils@4.2.1: + /@rollup/pluginutils/4.2.1: resolution: {integrity: sha512-iKnFXr7NkdZAIHiIWE+BX5ULi/ucVFYWD6TbAV+rZctiRTY2PL6tsIKhoIOaoskiWAkgu+VsbXgUVDNLHf+InQ==} engines: {node: '>= 8.0.0'} dependencies: estree-walker: 2.0.2 picomatch: 2.3.1 - /@rollup/pluginutils@5.0.2(rollup@2.79.1): + /@rollup/pluginutils/5.0.2: resolution: {integrity: sha512-pTd9rIsP92h+B6wWwFbW8RkZv4hiR/xKsqre4SIuAOaOEQRxi0lqLke9k2/7WegC85GgUs9pjmOjCUi3In4vwA==} engines: {node: '>=14.0.0'} peerDependencies: @@ -6841,10 +5066,9 @@ packages: '@types/estree': 1.0.1 estree-walker: 2.0.2 picomatch: 2.3.1 - rollup: 2.79.1 dev: true - /@rollup/pluginutils@5.0.2(rollup@3.26.0): + /@rollup/pluginutils/5.0.2_rollup@3.26.2: resolution: {integrity: sha512-pTd9rIsP92h+B6wWwFbW8RkZv4hiR/xKsqre4SIuAOaOEQRxi0lqLke9k2/7WegC85GgUs9pjmOjCUi3In4vwA==} engines: {node: '>=14.0.0'} peerDependencies: @@ -6856,43 +5080,31 @@ packages: '@types/estree': 1.0.1 estree-walker: 2.0.2 picomatch: 2.3.1 - rollup: 3.26.0 + rollup: 3.26.2 dev: true - /@sinclair/typebox@0.25.24: - resolution: {integrity: sha512-XJfwUVUKDHF5ugKwIcxEgc9k8b7HbznCp6eUfWgu710hMPNIO4aw4/zB5RogDQz8nd6gyCDpU9O/m6qYEWY6yQ==} + /@sinclair/typebox/0.27.8: + resolution: {integrity: sha512-+Fj43pSMwJs4KRrH/938Uf+uAELIgVBmQzg/q1YG10djyfA3TnrU8N8XzqCh/okZdszqBQTZf96idMfE5lnwTA==} - /@sindresorhus/is@5.3.0: - resolution: {integrity: sha512-CX6t4SYQ37lzxicAqsBtxA3OseeoVrh9cSJ5PFYam0GksYlupRfy1A+Q4aYD3zvcfECLc0zO2u+ZnR2UYKvCrw==} + /@sindresorhus/is/5.4.1: + resolution: {integrity: sha512-axlrvsHlHlFmKKMEg4VyvMzFr93JWJj4eIfXY1STVuO2fsImCa7ncaiG5gC8HKOX590AW5RtRsC41/B+OfrSqw==} engines: {node: '>=14.16'} dev: true - /@sinonjs/commons@1.8.6: - resolution: {integrity: sha512-Ky+XkAkqPZSm3NLBeUng77EBQl3cmeJhITaGHdYH8kjVB+aun3S4XBRti2zt17mtt0mIUDiNxYeoJm6drVvBJQ==} - dependencies: - type-detect: 4.0.8 - dev: true - - /@sinonjs/commons@3.0.0: + /@sinonjs/commons/3.0.0: resolution: {integrity: sha512-jXBtWAF4vmdNmZgD5FoKsVLv3rPgDnLgPbU84LIJ3otV44vJlDRokVng5v8NFJdCf/da9legHcKaRuZs4L7faA==} dependencies: type-detect: 4.0.8 dev: true - /@sinonjs/fake-timers@11.0.0: + /@sinonjs/fake-timers/11.0.0: resolution: {integrity: sha512-bqiI/5ur6ZOozG06BeJjbplIqHY/KftV1zaewbZHORH902GrHURKwl7H1G/4OC5EaxDYQJlrD0OLJ1XD6x01dQ==} dependencies: '@sinonjs/commons': 3.0.0 dev: true - /@sinonjs/fake-timers@8.1.0: - resolution: {integrity: sha512-OAPJUAtgeINhh/TAlUID4QTs53Njm7xzddaVlEs/SXwgtiD1tW22zAB/W1wdqfrpmikgaWQ9Fw6Ws+hsiRm5Vg==} - dependencies: - '@sinonjs/commons': 1.8.6 - dev: true - - /@storybook/addon-actions@6.5.10(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-vpCnEu81fmtYzOf0QsRYoDuf9wXgVVl2VysE1dWRebRhIUDU0JurrthTnw322e38D4FzaoNGqZE7wnBYBohzZA==} + /@storybook/addon-actions/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + resolution: {integrity: sha512-aADjilFmuD6TNGz2CRPSupnyiA/IGkPJHDBTqMpsDXTUr8xnuD122xkIhg6UxmCM2y1c+ncwYXy3WPK2xXK57g==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -6902,31 +5114,31 @@ packages: react-dom: optional: true dependencies: - '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/api': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.10 - '@storybook/components': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/core-events': 6.5.10 + '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/client-logger': 6.5.16 + '@storybook/components': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/theming': 6.5.10(react-dom@17.0.2)(react@17.0.2) - core-js: 3.25.0 + '@storybook/theming': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + core-js: 3.31.1 fast-deep-equal: 3.1.3 global: 4.4.0 lodash: 4.17.21 polished: 4.2.2 prop-types: 15.8.1 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) - react-inspector: 5.1.1(react@17.0.2) - regenerator-runtime: 0.13.9 + react-dom: 17.0.2_react@17.0.2 + react-inspector: 5.1.1_react@17.0.2 + regenerator-runtime: 0.13.11 telejson: 6.0.8 ts-dedent: 2.2.0 util-deprecate: 1.0.2 uuid-browser: 3.1.0 dev: true - /@storybook/addon-backgrounds@6.5.10(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-5uzQda3dh891h7BL8e9Ymk7BI+QgkkzDJXuA4mHjOXfIiD3S3efhJI8amXuBC2ZpIr6zmVit0MqZVyoVve46cQ==} + /@storybook/addon-backgrounds/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + resolution: {integrity: sha512-t7qooZ892BruhilFmzYPbysFwpULt/q4zYXNSmKVbAYta8UVvitjcU4F18p8FpWd9WvhiTr0SDlyhNZuzvDfug==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -6936,25 +5148,25 @@ packages: react-dom: optional: true dependencies: - '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/api': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.10 - '@storybook/components': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/core-events': 6.5.10 + '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/client-logger': 6.5.16 + '@storybook/components': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/theming': 6.5.10(react-dom@17.0.2)(react@17.0.2) - core-js: 3.25.0 + '@storybook/theming': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + core-js: 3.31.1 global: 4.4.0 memoizerific: 1.11.3 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 regenerator-runtime: 0.13.11 ts-dedent: 2.2.0 util-deprecate: 1.0.2 dev: true - /@storybook/addon-controls@6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4): - resolution: {integrity: sha512-lC2y3XcolmQAJwFurIyGrynAHPWmfNtTCdu3rQBTVGwyxCoNwdOOeC2jV0BRqX2+CW6OHzJr9frNWXPSaZ8c4w==} + /@storybook/addon-controls/6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy: + resolution: {integrity: sha512-kShSGjq1MjmmyL3l8i+uPz6yddtf82mzys0l82VKtcuyjrr5944wYFJ5NTXMfZxrO/U6FeFsfuFZE/k6ex3EMg==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -6964,19 +5176,19 @@ packages: react-dom: optional: true dependencies: - '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/api': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.10 - '@storybook/components': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/core-common': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) + '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/client-logger': 6.5.16 + '@storybook/components': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/core-common': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/node-logger': 6.5.10 - '@storybook/store': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/theming': 6.5.10(react-dom@17.0.2)(react@17.0.2) - core-js: 3.25.0 + '@storybook/node-logger': 6.5.16 + '@storybook/store': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/theming': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + core-js: 3.31.1 lodash: 4.17.21 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 ts-dedent: 2.2.0 transitivePeerDependencies: - eslint @@ -6987,8 +5199,8 @@ packages: - webpack-command dev: true - /@storybook/addon-docs@6.5.10(@babel/core@7.18.13)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4)(webpack@5.74.0): - resolution: {integrity: sha512-1kgjo3f0vL6GN8fTwLL05M/q/kDdzvuqwhxPY/v5hubFb3aQZGr2yk9pRBaLAbs4bez0yG0ASXcwhYnrEZUppg==} + /@storybook/addon-docs/6.5.16_7i6vyke6ny6b2xsni3leqxtq5y: + resolution: {integrity: sha512-QM9WDZG9P02UvbzLu947a8ZngOrQeAKAT8jCibQFM/+RJ39xBlfm8rm+cQy3dm94wgtjmVkA3mKGOV/yrrsddg==} peerDependencies: '@storybook/mdx2-csf': ^0.0.3 react: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -7001,31 +5213,31 @@ packages: react-dom: optional: true dependencies: - '@babel/plugin-transform-react-jsx': 7.19.0(@babel/core@7.18.13) - '@babel/preset-env': 7.18.10(@babel/core@7.18.13) + '@babel/plugin-transform-react-jsx': 7.22.5_@babel+core@7.22.8 + '@babel/preset-env': 7.22.7_@babel+core@7.22.8 '@jest/transform': 26.6.2 - '@mdx-js/react': 1.6.22(react@17.0.2) - '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/api': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/components': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/core-common': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) - '@storybook/core-events': 6.5.10 + '@mdx-js/react': 1.6.22_react@17.0.2 + '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/components': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/core-common': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy + '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/docs-tools': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/mdx1-csf': 0.0.1(@babel/core@7.18.13) - '@storybook/node-logger': 6.5.10 - '@storybook/postinstall': 6.5.10 - '@storybook/preview-web': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/source-loader': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/store': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/theming': 6.5.10(react-dom@17.0.2)(react@17.0.2) - babel-loader: 8.2.5(@babel/core@7.18.13)(webpack@5.74.0) - core-js: 3.25.0 + '@storybook/docs-tools': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/mdx1-csf': 0.0.1_@babel+core@7.22.8 + '@storybook/node-logger': 6.5.16 + '@storybook/postinstall': 6.5.16 + '@storybook/preview-web': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/source-loader': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/store': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/theming': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + babel-loader: 8.3.0_@babel+core@7.22.8 + core-js: 3.31.1 fast-deep-equal: 3.1.3 global: 4.4.0 lodash: 4.17.21 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 regenerator-runtime: 0.13.11 remark-external-links: 8.0.0 remark-slug: 6.1.0 @@ -7042,8 +5254,8 @@ packages: - webpack-command dev: true - /@storybook/addon-essentials@6.5.10(@babel/core@7.18.13)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4)(webpack@5.74.0): - resolution: {integrity: sha512-PT2aiR4vgAyB0pl3HNBUa4/a7NDRxASxAazz7zt9ZDirkipDKfxwdcLeRoJzwSngVDWEhuz5/paN5x4eNp4Hww==} + /@storybook/addon-essentials/6.5.16_7i6vyke6ny6b2xsni3leqxtq5y: + resolution: {integrity: sha512-TeoMr6tEit4Pe91GH6f8g/oar1P4M0JL9S6oMcFxxrhhtOGO7XkWD5EnfyCx272Ok2VYfE58FNBTGPNBVIqYKQ==} peerDependencies: '@babel/core': ^7.9.6 '@storybook/angular': '*' @@ -7099,25 +5311,24 @@ packages: webpack: optional: true dependencies: - '@babel/core': 7.18.13 - '@storybook/addon-actions': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/addon-backgrounds': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/addon-controls': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) - '@storybook/addon-docs': 6.5.10(@babel/core@7.18.13)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4)(webpack@5.74.0) - '@storybook/addon-measure': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/addon-outline': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/addon-toolbars': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/addon-viewport': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/api': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/core-common': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) - '@storybook/node-logger': 6.5.10 - core-js: 3.25.0 + '@babel/core': 7.22.8 + '@storybook/addon-actions': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/addon-backgrounds': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/addon-controls': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy + '@storybook/addon-docs': 6.5.16_7i6vyke6ny6b2xsni3leqxtq5y + '@storybook/addon-measure': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/addon-outline': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/addon-toolbars': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/addon-viewport': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/core-common': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy + '@storybook/node-logger': 6.5.16 + core-js: 3.31.1 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) - regenerator-runtime: 0.13.9 + react-dom: 17.0.2_react@17.0.2 + regenerator-runtime: 0.13.11 ts-dedent: 2.2.0 - webpack: 5.74.0(esbuild@0.18.11) transitivePeerDependencies: - '@storybook/mdx2-csf' - eslint @@ -7128,8 +5339,8 @@ packages: - webpack-command dev: true - /@storybook/addon-links@6.5.10(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-r3WzYIPz7WjHiaPObC2Tg6bHuZRBb/Kt/X+Eitw+jTqBel7ksvkO36tn81q8Eyj61qIdNQmUWAaX/0aewT0kLA==} + /@storybook/addon-links/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + resolution: {integrity: sha512-P/mmqK57NGXnR0i3d/T5B0rIt0Lg8Yq+qionRr3LK3AwG/4yGnYt4GNomLEknn/eEwABYq1Q/Z1aOpgIhNdq5A==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -7139,24 +5350,24 @@ packages: react-dom: optional: true dependencies: - '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.10 - '@storybook/core-events': 6.5.10 + '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/client-logger': 6.5.16 + '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/router': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/router': 6.5.16_sfoxds7t5ydpegc3knd667wn6m '@types/qs': 6.9.7 - core-js: 3.25.0 + core-js: 3.31.1 global: 4.4.0 prop-types: 15.8.1 - qs: 6.11.0 + qs: 6.11.2 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) - regenerator-runtime: 0.13.9 + react-dom: 17.0.2_react@17.0.2 + regenerator-runtime: 0.13.11 ts-dedent: 2.2.0 dev: true - /@storybook/addon-measure@6.5.10(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-ss7L1H5K5hXygDIoVwj+QyVXbve5V67x7CofLiLCgQYuJzfO16+sPGjiTGWMpTb4ijox2uKWnTkpilt5bCjXgw==} + /@storybook/addon-measure/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + resolution: {integrity: sha512-DMwnXkmM2L6POTh4KaOWvOAtQ2p9Tr1UUNxz6VXiN5cKFohpCs6x0txdLU5WN8eWIq0VFsO7u5ZX34CGCc6gCg==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -7166,20 +5377,20 @@ packages: react-dom: optional: true dependencies: - '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/api': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.10 - '@storybook/components': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/core-events': 6.5.10 + '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/client-logger': 6.5.16 + '@storybook/components': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - core-js: 3.25.0 + core-js: 3.31.1 global: 4.4.0 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 dev: true - /@storybook/addon-outline@6.5.10(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-AjdaeQ+/iBKmGrAqRW4niwMB6AkgGnYmSzVs5Cf6F/Sb4Dp+vzgLNOwLABD9qs8Ri8dvHl5J4QpVwQKUhYZaOQ==} + /@storybook/addon-outline/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + resolution: {integrity: sha512-0du96nha4qltexO0Xq1xB7LeRSbqjC9XqtZLflXG7/X3ABoPD2cXgOV97eeaXUodIyb2qYBbHUfftBeA75x0+w==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -7189,22 +5400,22 @@ packages: react-dom: optional: true dependencies: - '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/api': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.10 - '@storybook/components': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/core-events': 6.5.10 + '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/client-logger': 6.5.16 + '@storybook/components': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - core-js: 3.25.0 + core-js: 3.31.1 global: 4.4.0 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 regenerator-runtime: 0.13.11 ts-dedent: 2.2.0 dev: true - /@storybook/addon-toolbars@6.5.10(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-S0Ljc6Wv+bPbx2e0iTveJ6bBDqjsemu+FZD4qDLsHreoI7DAcqyrF5Def1l8xNohixIVpx8dQpYXRtyzNlXekg==} + /@storybook/addon-toolbars/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + resolution: {integrity: sha512-y3PuUKiwOWrAvqx1YdUvArg0UaAwmboXFeR2bkrowk1xcT+xnRO3rML4npFeUl26OQ1FzwxX/cw6nknREBBLEA==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -7214,19 +5425,19 @@ packages: react-dom: optional: true dependencies: - '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/api': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.10 - '@storybook/components': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/theming': 6.5.10(react-dom@17.0.2)(react@17.0.2) - core-js: 3.25.0 + '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/client-logger': 6.5.16 + '@storybook/components': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/theming': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + core-js: 3.31.1 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 regenerator-runtime: 0.13.11 dev: true - /@storybook/addon-viewport@6.5.10(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-RFMd+4kZljyuJjR9OJ2bFXHrSG7VTi5FDZYWEU+4W1sBxzC+JhnVnUP+HJH3gUxEFIRQC5neRzwWRE9RUUoALQ==} + /@storybook/addon-viewport/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + resolution: {integrity: sha512-1Vyqf1U6Qng6TXlf4SdqUKyizlw1Wn6+qW8YeA2q1lbkJqn3UlnHXIp8Q0t/5q1dK5BFtREox3+jkGwbJrzkmA==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -7236,62 +5447,62 @@ packages: react-dom: optional: true dependencies: - '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/api': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.10 - '@storybook/components': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/core-events': 6.5.10 - '@storybook/theming': 6.5.10(react-dom@17.0.2)(react@17.0.2) - core-js: 3.25.0 + '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/client-logger': 6.5.16 + '@storybook/components': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/core-events': 6.5.16 + '@storybook/theming': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + core-js: 3.31.1 global: 4.4.0 memoizerific: 1.11.3 prop-types: 15.8.1 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 regenerator-runtime: 0.13.11 dev: true - /@storybook/addons@6.5.10(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-VD4tBCQ23PkSeDoxuHcKy0RfhIs3oMYjBacOZx7d0bvOzK9WjPyvE2ysDAh7r/ceqnwmWHAScIpE+I1RU7gl+g==} + /@storybook/addons/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + resolution: {integrity: sha512-p3DqQi+8QRL5k7jXhXmJZLsE/GqHqyY6PcoA1oNTJr0try48uhTGUOYkgzmqtDaa/qPFO5LP+xCPzZXckGtquQ==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/api': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/channels': 6.5.10 - '@storybook/client-logger': 6.5.10 - '@storybook/core-events': 6.5.10 + '@storybook/api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/channels': 6.5.16 + '@storybook/client-logger': 6.5.16 + '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/router': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/theming': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@types/webpack-env': 1.18.0 - core-js: 3.25.0 + '@storybook/router': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/theming': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@types/webpack-env': 1.18.1 + core-js: 3.31.1 global: 4.4.0 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 regenerator-runtime: 0.13.11 dev: true - /@storybook/api@6.5.10(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-AkmgSPNEGdKp4oZA4KQ+RJsacw7GwfvjsVDnCkcXqS9zmSr/RNL0fhpcd60KKkmx/hGKPTDFpK3ZayxDrJ/h4A==} + /@storybook/api/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + resolution: {integrity: sha512-HOsuT8iomqeTMQJrRx5U8nsC7lJTwRr1DhdD0SzlqL4c80S/7uuCy4IZvOt4sYQjOzW5fOo/kamcoBXyLproTA==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/channels': 6.5.10 - '@storybook/client-logger': 6.5.10 - '@storybook/core-events': 6.5.10 + '@storybook/channels': 6.5.16 + '@storybook/client-logger': 6.5.16 + '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/router': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/router': 6.5.16_sfoxds7t5ydpegc3knd667wn6m '@storybook/semver': 7.3.2 - '@storybook/theming': 6.5.10(react-dom@17.0.2)(react@17.0.2) - core-js: 3.25.0 + '@storybook/theming': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + core-js: 3.31.1 fast-deep-equal: 3.1.3 global: 4.4.0 lodash: 4.17.21 memoizerific: 1.11.3 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 regenerator-runtime: 0.13.11 store2: 2.14.2 telejson: 6.0.8 @@ -7299,42 +5510,40 @@ packages: util-deprecate: 1.0.2 dev: true - /@storybook/builder-vite@0.1.41(@babel/core@7.18.13)(@storybook/core-common@6.5.10)(@storybook/node-logger@6.5.10)(@storybook/source-loader@6.5.10)(react@17.0.2)(typescript@4.8.4)(vite@4.3.9): + /@storybook/builder-vite/0.1.41_qr3s4pqg2febfejexmksv4rlaa: resolution: {integrity: sha512-h/7AgEUfSuVexTD6LuJ6BCNu+FSo/+IKYBQ1O3TyF2BEgcob5/BGrx9QcwM0LJCF44L1zNKaxkKpCZs9p+LRRA==} peerDependencies: '@storybook/core-common': '>=6.4.3 || >=6.5.0-alpha.0' '@storybook/mdx2-csf': ^0.0.3 '@storybook/node-logger': '>=6.4.3 || >=6.5.0-alpha.0' - '@storybook/source-loader': '>=6.4.3 || >=6.5.0-alpha.0' vite: '>=2.6.7' peerDependenciesMeta: '@storybook/mdx2-csf': optional: true dependencies: - '@joshwooding/vite-plugin-react-docgen-typescript': 0.0.4(typescript@4.8.4)(vite@4.3.9) - '@storybook/core-common': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) - '@storybook/mdx1-csf': 0.0.4(@babel/core@7.18.13)(react@17.0.2) - '@storybook/node-logger': 6.5.10 - '@storybook/source-loader': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@joshwooding/vite-plugin-react-docgen-typescript': 0.0.4_ilntetca2wlekmurdwyomywvbi + '@storybook/mdx1-csf': 0.0.4_wumd2qseuobkz2wudw2hqnarr4 + '@storybook/source-loader': 6.5.16_sfoxds7t5ydpegc3knd667wn6m '@vitejs/plugin-react': 1.3.2 ast-types: 0.14.2 es-module-lexer: 0.9.3 glob: 7.2.3 - glob-promise: 4.2.2(glob@7.2.3) + glob-promise: 4.2.2_glob@7.2.3 magic-string: 0.26.7 - react-docgen: 6.0.0-alpha.3 + react-docgen: 6.0.1 slash: 3.0.0 sveltedoc-parser: 4.2.1 - vite: 4.3.9(@types/node@18.16.19) + vite: 4.4.3 transitivePeerDependencies: - '@babel/core' - react + - react-dom - supports-color - typescript dev: true - /@storybook/builder-webpack4@6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4): - resolution: {integrity: sha512-AoKjsCNoQQoZXYwBDxO8s+yVEd5FjBJAaysEuUTHq2fb81jwLrGcEOo6hjw4jqfugZQIzYUEjPazlvubS78zpw==} + /@storybook/builder-webpack4/6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy: + resolution: {integrity: sha512-YqDIrVNsUo8r9xc6AxsYDLxVYtMgl5Bxk+8/h1adsOko+jAFhdg6hOcAVxEmoSI0TMASOOVMFlT2hr23ppN2rQ==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -7343,55 +5552,55 @@ packages: typescript: optional: true dependencies: - '@babel/core': 7.22.5 - '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/api': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/channel-postmessage': 6.5.10 - '@storybook/channels': 6.5.10 - '@storybook/client-api': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.10 - '@storybook/components': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/core-common': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) - '@storybook/core-events': 6.5.10 - '@storybook/node-logger': 6.5.10 - '@storybook/preview-web': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/router': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@babel/core': 7.22.8 + '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/channel-postmessage': 6.5.16 + '@storybook/channels': 6.5.16 + '@storybook/client-api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/client-logger': 6.5.16 + '@storybook/components': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/core-common': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy + '@storybook/core-events': 6.5.16 + '@storybook/node-logger': 6.5.16 + '@storybook/preview-web': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/router': 6.5.16_sfoxds7t5ydpegc3knd667wn6m '@storybook/semver': 7.3.2 - '@storybook/store': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/theming': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/ui': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@types/node': 16.11.56 - '@types/webpack': 4.41.32 + '@storybook/store': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/theming': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/ui': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@types/node': 16.18.38 + '@types/webpack': 4.41.33 autoprefixer: 9.8.8 - babel-loader: 8.2.5(@babel/core@7.22.5)(webpack@4.46.0) + babel-loader: 8.3.0_n6tf3ekqtzvxjokzr6jiserpma case-sensitive-paths-webpack-plugin: 2.4.0 - core-js: 3.25.0 - css-loader: 3.6.0(webpack@4.46.0) - file-loader: 6.2.0(webpack@4.46.0) + core-js: 3.31.1 + css-loader: 3.6.0_webpack@4.46.0 + file-loader: 6.2.0_webpack@4.46.0 find-up: 5.0.0 - fork-ts-checker-webpack-plugin: 4.1.6(eslint@8.4.1)(typescript@4.8.4)(webpack@4.46.0) + fork-ts-checker-webpack-plugin: 4.1.6_evijigonbo4skk2vlqtwtdqibu glob: 7.2.3 - glob-promise: 3.4.0(glob@7.2.3) + glob-promise: 3.4.0_glob@7.2.3 global: 4.4.0 - html-webpack-plugin: 4.5.2(webpack@4.46.0) - pnp-webpack-plugin: 1.6.4(typescript@4.8.4) + html-webpack-plugin: 4.5.2_webpack@4.46.0 + pnp-webpack-plugin: 1.6.4_typescript@4.9.5 postcss: 7.0.39 postcss-flexbugs-fixes: 4.2.1 - postcss-loader: 4.3.0(postcss@7.0.39)(webpack@4.46.0) - raw-loader: 4.0.2(webpack@4.46.0) + postcss-loader: 4.3.0_gzaxsinx64nntyd3vmdqwl7coe + raw-loader: 4.0.2_webpack@4.46.0 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 stable: 0.1.8 - style-loader: 1.3.0(webpack@4.46.0) - terser-webpack-plugin: 4.2.3(webpack@4.46.0) + style-loader: 1.3.0_webpack@4.46.0 + terser-webpack-plugin: 4.2.3_webpack@4.46.0 ts-dedent: 2.2.0 - typescript: 4.8.4 - url-loader: 4.1.1(file-loader@6.2.0)(webpack@4.46.0) + typescript: 4.9.5 + url-loader: 4.1.1_lit45vopotvaqup7lrvlnvtxwy util-deprecate: 1.0.2 webpack: 4.46.0 - webpack-dev-middleware: 3.7.3(webpack@4.46.0) - webpack-filter-warnings-plugin: 1.2.1(webpack@4.46.0) - webpack-hot-middleware: 2.25.2 + webpack-dev-middleware: 3.7.3_webpack@4.46.0 + webpack-filter-warnings-plugin: 1.2.1_webpack@4.46.0 + webpack-hot-middleware: 2.25.4 webpack-virtual-modules: 0.2.2 transitivePeerDependencies: - bluebird @@ -7402,93 +5611,114 @@ packages: - webpack-command dev: true - /@storybook/channel-postmessage@6.5.10: - resolution: {integrity: sha512-t9PTA0UzFvYa3IlOfpBOolfrRMPTjUMIeCQ6FNyM0aj5GqLKSvoQzP8NeoRpIrvyf6ljFKKdaMaZ3fiCvh45ag==} + /@storybook/channel-postmessage/6.5.16: + resolution: {integrity: sha512-fZZSN29dsUArWOx7e7lTdMA9+7zijVwCwbvi2Fo4fqhRLh1DsTb/VXfz1FKMCWAjNlcX7QQvV25tnxbqsD6lyw==} dependencies: - '@storybook/channels': 6.5.10 - '@storybook/client-logger': 6.5.10 - '@storybook/core-events': 6.5.10 - core-js: 3.25.0 + '@storybook/channels': 6.5.16 + '@storybook/client-logger': 6.5.16 + '@storybook/core-events': 6.5.16 + core-js: 3.31.1 global: 4.4.0 - qs: 6.11.0 + qs: 6.11.2 telejson: 6.0.8 dev: true - /@storybook/channel-websocket@6.5.10: - resolution: {integrity: sha512-RTXMZbMWCS3xU+4GVIdfnUXsKcwg/WTozy88/5OxaKjGw6KgRedqLAQJKJ6Y5XlnwIcWelirkHj/COwTTXhbPg==} + /@storybook/channel-postmessage/7.0.26: + resolution: {integrity: sha512-ZvFLr/tUD9dWIjQtIn1JXHjqrbOP/uEEOqzwpKSVj0Cl4Vgc12s8hecbzBufkOF7fwLsFvfieSi7ENOmjoncdQ==} dependencies: - '@storybook/channels': 6.5.10 - '@storybook/client-logger': 6.5.10 - core-js: 3.25.0 + '@storybook/channels': 7.0.26 + '@storybook/client-logger': 7.0.26 + '@storybook/core-events': 7.0.26 + '@storybook/global': 5.0.0 + qs: 6.11.2 + telejson: 7.1.0 + dev: true + + /@storybook/channel-websocket/6.5.16: + resolution: {integrity: sha512-wJg2lpBjmRC2GJFzmhB9kxlh109VE58r/0WhFtLbwKvPqsvGf82xkBEl6BtBCvIQ4stzYnj/XijjA8qSi2zpOg==} + dependencies: + '@storybook/channels': 6.5.16 + '@storybook/client-logger': 6.5.16 + core-js: 3.31.1 global: 4.4.0 telejson: 6.0.8 dev: true - /@storybook/channels@6.5.10: - resolution: {integrity: sha512-lo26YZ6kWpHXLhuHJF4P/bICY7jD/rXEZqReKtGOSk1Lv99/xvG6pqmcy3hWLf3v3Dy/8otjRPSR7izFVIIZgQ==} + /@storybook/channels/6.5.16: + resolution: {integrity: sha512-VylzaWQZaMozEwZPJdyJoz+0jpDa8GRyaqu9TGG6QGv+KU5POoZaGLDkRE7TzWkyyP0KQLo80K99MssZCpgSeg==} dependencies: - core-js: 3.25.0 + core-js: 3.31.1 ts-dedent: 2.2.0 util-deprecate: 1.0.2 dev: true - /@storybook/client-api@6.5.10(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-3wBWZl3NvMFgMovgEh+euiARAT2FXzpvTF4Q1gerGMNNDlrGxHnFvSuy4FHg/irtOGLa4yLz43ULFbYtpKw0Lg==} + /@storybook/channels/7.0.26: + resolution: {integrity: sha512-Br3XILhrtuL5Sdp91I04kKjJzSqU/N8gGL6B6nIfnuaHUvGMDuMCHAB+g7aoiyH5dnpDZ6yBVGNwtYAyJA+0Og==} + dev: true + + /@storybook/client-api/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + resolution: {integrity: sha512-i3UwkzzUFw8I+E6fOcgB5sc4oU2fhvaKnqC1mpd9IYGJ9JN9MnGIaVl3Ko28DtFItu/QabC9JsLIJVripFLktQ==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/channel-postmessage': 6.5.10 - '@storybook/channels': 6.5.10 - '@storybook/client-logger': 6.5.10 - '@storybook/core-events': 6.5.10 + '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/channel-postmessage': 6.5.16 + '@storybook/channels': 6.5.16 + '@storybook/client-logger': 6.5.16 + '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/store': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/store': 6.5.16_sfoxds7t5ydpegc3knd667wn6m '@types/qs': 6.9.7 - '@types/webpack-env': 1.18.0 - core-js: 3.25.0 + '@types/webpack-env': 1.18.1 + core-js: 3.31.1 fast-deep-equal: 3.1.3 global: 4.4.0 lodash: 4.17.21 memoizerific: 1.11.3 - qs: 6.11.0 + qs: 6.11.2 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 regenerator-runtime: 0.13.11 store2: 2.14.2 - synchronous-promise: 2.0.16 + synchronous-promise: 2.0.17 ts-dedent: 2.2.0 util-deprecate: 1.0.2 dev: true - /@storybook/client-logger@6.5.10: - resolution: {integrity: sha512-/xA0MHOevXev68hyLMQw8Qo8KczSIdXOxliAgrycMTkDmw5eKeA8TP7B8zP3wGuq/e3MrdD9/8MWhb/IQBNC3w==} + /@storybook/client-logger/6.5.16: + resolution: {integrity: sha512-pxcNaCj3ItDdicPTXTtmYJE3YC1SjxFrBmHcyrN+nffeNyiMuViJdOOZzzzucTUG0wcOOX8jaSyak+nnHg5H1Q==} dependencies: - core-js: 3.25.0 + core-js: 3.31.1 global: 4.4.0 dev: true - /@storybook/components@6.5.10(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-9OhgB8YQfGwOKjo/N96N5mrtJ6qDVVoEM1zuhea32tJUd2eYf0aSWpryA9VnOM0V1q/8DAoCg5rPBMYWMBU5uw==} + /@storybook/client-logger/7.0.26: + resolution: {integrity: sha512-OMVLbgceoeuM8sWOfTX/9a4zCrH78G32hg7x8yXLZnRJ9OLaHJHzUM0Onc4MLudqVUdaKH0c8ejpBXUyIr1rJQ==} + dependencies: + '@storybook/global': 5.0.0 + dev: true + + /@storybook/components/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + resolution: {integrity: sha512-LzBOFJKITLtDcbW9jXl0/PaG+4xAz25PK8JxPZpIALbmOpYWOAPcO6V9C2heX6e6NgWFMUxjplkULEk9RCQMNA==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/client-logger': 6.5.10 + '@storybook/client-logger': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/theming': 6.5.10(react-dom@17.0.2)(react@17.0.2) - core-js: 3.25.0 + '@storybook/theming': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + core-js: 3.31.1 memoizerific: 1.11.3 - qs: 6.11.0 + qs: 6.11.2 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 regenerator-runtime: 0.13.11 util-deprecate: 1.0.2 dev: true - /@storybook/core-client@6.5.10(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4)(webpack@4.46.0): - resolution: {integrity: sha512-THsIjNrOrampTl0Lgfjvfjk1JnktKb4CQLOM80KpQb4cjDqorBjJmErzUkUQ2y3fXvrDmQ/kUREkShET4XEdtA==} + /@storybook/core-client/6.5.16_kdhf477f3bq3v2mc53jwn63t6u: + resolution: {integrity: sha512-14IRaDrVtKrQ+gNWC0wPwkCNfkZOKghYV/swCUnQX3rP99defsZK8Hc7xHIYoAiOP5+sc3sweRAxgmFiJeQ1Ig==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -7498,34 +5728,34 @@ packages: typescript: optional: true dependencies: - '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/channel-postmessage': 6.5.10 - '@storybook/channel-websocket': 6.5.10 - '@storybook/client-api': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.10 - '@storybook/core-events': 6.5.10 + '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/channel-postmessage': 6.5.16 + '@storybook/channel-websocket': 6.5.16 + '@storybook/client-api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/client-logger': 6.5.16 + '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/preview-web': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/store': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/ui': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/preview-web': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/store': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/ui': 6.5.16_sfoxds7t5ydpegc3knd667wn6m airbnb-js-shims: 2.2.1 ansi-to-html: 0.6.15 - core-js: 3.25.0 + core-js: 3.31.1 global: 4.4.0 lodash: 4.17.21 - qs: 6.11.0 + qs: 6.11.2 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 regenerator-runtime: 0.13.11 ts-dedent: 2.2.0 - typescript: 4.8.4 + typescript: 4.9.5 unfetch: 4.2.0 util-deprecate: 1.0.2 - webpack: 4.46.0 + webpack: 5.88.1 dev: true - /@storybook/core-client@6.5.10(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4)(webpack@5.74.0): - resolution: {integrity: sha512-THsIjNrOrampTl0Lgfjvfjk1JnktKb4CQLOM80KpQb4cjDqorBjJmErzUkUQ2y3fXvrDmQ/kUREkShET4XEdtA==} + /@storybook/core-client/6.5.16_zpymzxef3xv3tkikcnxd3qomju: + resolution: {integrity: sha512-14IRaDrVtKrQ+gNWC0wPwkCNfkZOKghYV/swCUnQX3rP99defsZK8Hc7xHIYoAiOP5+sc3sweRAxgmFiJeQ1Ig==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -7535,34 +5765,34 @@ packages: typescript: optional: true dependencies: - '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/channel-postmessage': 6.5.10 - '@storybook/channel-websocket': 6.5.10 - '@storybook/client-api': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.10 - '@storybook/core-events': 6.5.10 + '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/channel-postmessage': 6.5.16 + '@storybook/channel-websocket': 6.5.16 + '@storybook/client-api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/client-logger': 6.5.16 + '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/preview-web': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/store': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/ui': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/preview-web': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/store': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/ui': 6.5.16_sfoxds7t5ydpegc3knd667wn6m airbnb-js-shims: 2.2.1 ansi-to-html: 0.6.15 - core-js: 3.25.0 + core-js: 3.31.1 global: 4.4.0 lodash: 4.17.21 - qs: 6.11.0 + qs: 6.11.2 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 regenerator-runtime: 0.13.11 ts-dedent: 2.2.0 - typescript: 4.8.4 + typescript: 4.9.5 unfetch: 4.2.0 util-deprecate: 1.0.2 - webpack: 5.74.0(esbuild@0.18.11) + webpack: 4.46.0 dev: true - /@storybook/core-common@6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4): - resolution: {integrity: sha512-Bx+VKkfWdrAmD8T51Sjq/mMhRaiapBHcpG4cU5bc3DMbg+LF2/yrgqv/cjVu+m5gHAzYCac5D7gqzBgvG7Myww==} + /@storybook/core-common/6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy: + resolution: {integrity: sha512-2qtnKP3TTOzt2cp6LXKRTh7XrI9z5VanMnMTgeoFcA5ebnndD4V6BExQUdYPClE/QooLx6blUWNgS9dFEpjSqQ==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -7571,41 +5801,41 @@ packages: typescript: optional: true dependencies: - '@babel/core': 7.22.5 - '@babel/plugin-proposal-class-properties': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-proposal-decorators': 7.18.10(@babel/core@7.22.5) - '@babel/plugin-proposal-export-default-from': 7.18.10(@babel/core@7.22.5) - '@babel/plugin-proposal-nullish-coalescing-operator': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-proposal-object-rest-spread': 7.18.9(@babel/core@7.22.5) - '@babel/plugin-proposal-optional-chaining': 7.18.9(@babel/core@7.22.5) - '@babel/plugin-proposal-private-methods': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-proposal-private-property-in-object': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-syntax-dynamic-import': 7.8.3(@babel/core@7.22.5) - '@babel/plugin-transform-arrow-functions': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-transform-block-scoping': 7.18.9(@babel/core@7.22.5) - '@babel/plugin-transform-classes': 7.18.9(@babel/core@7.22.5) - '@babel/plugin-transform-destructuring': 7.18.13(@babel/core@7.22.5) - '@babel/plugin-transform-for-of': 7.18.8(@babel/core@7.22.5) - '@babel/plugin-transform-parameters': 7.18.8(@babel/core@7.22.5) - '@babel/plugin-transform-shorthand-properties': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-transform-spread': 7.18.9(@babel/core@7.22.5) - '@babel/preset-env': 7.18.10(@babel/core@7.22.5) - '@babel/preset-react': 7.18.6(@babel/core@7.22.5) - '@babel/preset-typescript': 7.18.6(@babel/core@7.22.5) - '@babel/register': 7.18.9(@babel/core@7.22.5) - '@storybook/node-logger': 6.5.10 + '@babel/core': 7.22.8 + '@babel/plugin-proposal-class-properties': 7.18.6_@babel+core@7.22.8 + '@babel/plugin-proposal-decorators': 7.22.7_@babel+core@7.22.8 + '@babel/plugin-proposal-export-default-from': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-proposal-nullish-coalescing-operator': 7.18.6_@babel+core@7.22.8 + '@babel/plugin-proposal-object-rest-spread': 7.20.7_@babel+core@7.22.8 + '@babel/plugin-proposal-optional-chaining': 7.21.0_@babel+core@7.22.8 + '@babel/plugin-proposal-private-methods': 7.18.6_@babel+core@7.22.8 + '@babel/plugin-proposal-private-property-in-object': 7.21.11_@babel+core@7.22.8 + '@babel/plugin-syntax-dynamic-import': 7.8.3_@babel+core@7.22.8 + '@babel/plugin-transform-arrow-functions': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-block-scoping': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-classes': 7.22.6_@babel+core@7.22.8 + '@babel/plugin-transform-destructuring': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-for-of': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-parameters': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-shorthand-properties': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-spread': 7.22.5_@babel+core@7.22.8 + '@babel/preset-env': 7.22.7_@babel+core@7.22.8 + '@babel/preset-react': 7.22.5_@babel+core@7.22.8 + '@babel/preset-typescript': 7.22.5_@babel+core@7.22.8 + '@babel/register': 7.22.5_@babel+core@7.22.8 + '@storybook/node-logger': 6.5.16 '@storybook/semver': 7.3.2 - '@types/node': 16.11.56 + '@types/node': 16.18.38 '@types/pretty-hrtime': 1.0.1 - babel-loader: 8.2.5(@babel/core@7.22.5)(webpack@4.46.0) + babel-loader: 8.3.0_n6tf3ekqtzvxjokzr6jiserpma babel-plugin-macros: 3.1.0 - babel-plugin-polyfill-corejs3: 0.1.7(@babel/core@7.22.5) + babel-plugin-polyfill-corejs3: 0.1.7_@babel+core@7.22.8 chalk: 4.1.2 - core-js: 3.25.0 - express: 4.18.1 + core-js: 3.31.1 + express: 4.18.2 file-system-cache: 1.1.0 find-up: 5.0.0 - fork-ts-checker-webpack-plugin: 6.5.2(eslint@8.4.1)(typescript@4.8.4)(webpack@4.46.0) + fork-ts-checker-webpack-plugin: 6.5.3_evijigonbo4skk2vlqtwtdqibu fs-extra: 9.1.0 glob: 7.2.3 handlebars: 4.7.7 @@ -7616,12 +5846,12 @@ packages: pkg-dir: 5.0.0 pretty-hrtime: 1.0.3 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 resolve-from: 5.0.0 slash: 3.0.0 telejson: 6.0.8 ts-dedent: 2.2.0 - typescript: 4.8.4 + typescript: 4.9.5 util-deprecate: 1.0.2 webpack: 4.46.0 transitivePeerDependencies: @@ -7632,14 +5862,18 @@ packages: - webpack-command dev: true - /@storybook/core-events@6.5.10: - resolution: {integrity: sha512-EVb1gO1172klVIAABLOoigFMx0V88uctY0K/qVCO8n6v+wd2+0Ccn63kl+gTxsAC3WZ8XhXh9q2w5ImHklVECw==} + /@storybook/core-events/6.5.16: + resolution: {integrity: sha512-qMZQwmvzpH5F2uwNUllTPg6eZXr2OaYZQRRN8VZJiuorZzDNdAFmiVWMWdkThwmyLEJuQKXxqCL8lMj/7PPM+g==} dependencies: - core-js: 3.25.0 + core-js: 3.31.1 + dev: true + + /@storybook/core-events/7.0.26: + resolution: {integrity: sha512-ckZszphEAYs9wp8tPVhayEMzk8JxCiQfzbq0S45sbdqdTrl40PmsOjv5iPNaUYElI/Stfz+v4gDCEUfOsxyC+w==} dev: true - /@storybook/core-server@6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4): - resolution: {integrity: sha512-jqwpA0ccA8X5ck4esWBid04+cEIVqirdAcqJeNb9IZAD+bRreO4Im8ilzr7jc5AmQ9fkqHs2NByFKh9TITp8NQ==} + /@storybook/core-server/6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy: + resolution: {integrity: sha512-/3NPfmNyply395Dm0zaVZ8P9aruwO+tPx4D6/jpw8aqrRSwvAMndPMpoMCm0NXcpSm5rdX+Je4S3JW6JcggFkA==} peerDependencies: '@storybook/builder-webpack5': '*' '@storybook/manager-webpack5': '*' @@ -7655,48 +5889,48 @@ packages: optional: true dependencies: '@discoveryjs/json-ext': 0.5.7 - '@storybook/builder-webpack4': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) - '@storybook/core-client': 6.5.10(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4)(webpack@4.46.0) - '@storybook/core-common': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) - '@storybook/core-events': 6.5.10 + '@storybook/builder-webpack4': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy + '@storybook/core-client': 6.5.16_zpymzxef3xv3tkikcnxd3qomju + '@storybook/core-common': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy + '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/csf-tools': 6.5.10 - '@storybook/manager-webpack4': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) - '@storybook/node-logger': 6.5.10 + '@storybook/csf-tools': 6.5.16 + '@storybook/manager-webpack4': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy + '@storybook/node-logger': 6.5.16 '@storybook/semver': 7.3.2 - '@storybook/store': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/telemetry': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) - '@types/node': 16.11.56 - '@types/node-fetch': 2.6.2 + '@storybook/store': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/telemetry': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy + '@types/node': 16.18.38 + '@types/node-fetch': 2.6.4 '@types/pretty-hrtime': 1.0.1 - '@types/webpack': 4.41.32 + '@types/webpack': 4.41.33 better-opn: 2.1.1 boxen: 5.1.2 chalk: 4.1.2 - cli-table3: 0.6.2 + cli-table3: 0.6.3 commander: 6.2.1 compression: 1.7.4 - core-js: 3.25.0 + core-js: 3.31.1 cpy: 8.1.2 - detect-port: 1.3.0 - express: 4.18.1 + detect-port: 1.5.1 + express: 4.18.2 fs-extra: 9.1.0 global: 4.4.0 globby: 11.1.0 ip: 2.0.0 lodash: 4.17.21 - node-fetch: 2.6.11 - open: 8.4.0 + node-fetch: 2.6.12 + open: 8.4.2 pretty-hrtime: 1.0.3 prompts: 2.4.2 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 regenerator-runtime: 0.13.11 serve-favicon: 2.5.0 slash: 3.0.0 telejson: 6.0.8 ts-dedent: 2.2.0 - typescript: 4.8.4 + typescript: 4.9.5 util-deprecate: 1.0.2 watchpack: 2.4.0 webpack: 4.46.0 @@ -7715,8 +5949,8 @@ packages: - webpack-command dev: true - /@storybook/core@6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4)(webpack@5.74.0): - resolution: {integrity: sha512-K86yYa0tYlMxADlwQTculYvPROokQau09SCVqpsLg3wJCTvYFL4+SIqcYoyBSbFmHOdnYbJgPydjN33MYLiOZQ==} + /@storybook/core/6.5.16_kdhf477f3bq3v2mc53jwn63t6u: + resolution: {integrity: sha512-CEF3QFTsm/VMnMKtRNr4rRdLeIkIG0g1t26WcmxTdSThNPBd8CsWzQJ7Jqu7CKiut+MU4A1LMOwbwCE5F2gmyA==} peerDependencies: '@storybook/builder-webpack5': '*' '@storybook/manager-webpack5': '*' @@ -7732,12 +5966,12 @@ packages: typescript: optional: true dependencies: - '@storybook/core-client': 6.5.10(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4)(webpack@5.74.0) - '@storybook/core-server': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) + '@storybook/core-client': 6.5.16_kdhf477f3bq3v2mc53jwn63t6u + '@storybook/core-server': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) - typescript: 4.8.4 - webpack: 5.74.0(esbuild@0.18.11) + react-dom: 17.0.2_react@17.0.2 + typescript: 4.9.5 + webpack: 5.88.1 transitivePeerDependencies: - '@storybook/mdx2-csf' - bluebird @@ -7751,24 +5985,24 @@ packages: - webpack-command dev: true - /@storybook/csf-tools@6.5.10: - resolution: {integrity: sha512-H77kZQEisu7+skzeIbNZwmE09OqLjwJTeFhLN1pcjxKVa30LEI3pBHcNBxVKqgxl+Yg3KkB7W/ArLO2N+i2ohw==} + /@storybook/csf-tools/6.5.16: + resolution: {integrity: sha512-+WD4sH/OwAfXZX3IN6/LOZ9D9iGEFcN+Vvgv9wOsLRgsAZ10DG/NK6c1unXKDM/ogJtJYccNI8Hd+qNE/GFV6A==} peerDependencies: '@storybook/mdx2-csf': ^0.0.3 peerDependenciesMeta: '@storybook/mdx2-csf': optional: true dependencies: - '@babel/core': 7.22.5 - '@babel/generator': 7.22.5 - '@babel/parser': 7.22.5 - '@babel/plugin-transform-react-jsx': 7.19.0(@babel/core@7.22.5) - '@babel/preset-env': 7.18.10(@babel/core@7.22.5) - '@babel/traverse': 7.22.5 + '@babel/core': 7.22.8 + '@babel/generator': 7.22.7 + '@babel/parser': 7.22.7 + '@babel/plugin-transform-react-jsx': 7.22.5_@babel+core@7.22.8 + '@babel/preset-env': 7.22.7_@babel+core@7.22.8 + '@babel/traverse': 7.22.8 '@babel/types': 7.22.5 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/mdx1-csf': 0.0.1(@babel/core@7.22.5) - core-js: 3.25.0 + '@storybook/mdx1-csf': 0.0.1_@babel+core@7.22.8 + core-js: 3.31.1 fs-extra: 9.1.0 global: 4.4.0 regenerator-runtime: 0.13.11 @@ -7777,25 +6011,31 @@ packages: - supports-color dev: true - /@storybook/csf@0.0.2--canary.4566f4d.1: + /@storybook/csf/0.0.2--canary.4566f4d.1: resolution: {integrity: sha512-9OVvMVh3t9znYZwb0Svf/YQoxX2gVOeQTGe2bses2yj+a3+OJnCrUF3/hGv6Em7KujtOdL2LL+JnG49oMVGFgQ==} dependencies: lodash: 4.17.21 dev: true - /@storybook/csf@0.0.2--canary.87bc651.0: + /@storybook/csf/0.0.2--canary.87bc651.0: resolution: {integrity: sha512-ajk1Uxa+rBpFQHKrCcTmJyQBXZ5slfwHVEaKlkuFaW77it8RgbPJp/ccna3sgoi8oZ7FkkOyvv1Ve4SmwFqRqw==} dependencies: lodash: 4.17.21 dev: true - /@storybook/docs-tools@6.5.10(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-/bvYgOO+CxMEcHifkjJg0A60OTGOhcjGxnsB1h0gJuxMrqA/7Qwc108bFmPiX0eiD1BovFkZLJV4O6OY7zP5Vw==} + /@storybook/csf/0.1.1: + resolution: {integrity: sha512-4hE3AlNVxR60Wc5KSC68ASYzUobjPqtSKyhV6G+ge0FIXU55N5nTY7dXGRZHQGDBPq+XqchMkIdlkHPRs8nTHg==} + dependencies: + type-fest: 2.19.0 + dev: true + + /@storybook/docs-tools/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + resolution: {integrity: sha512-o+rAWPRGifjBF5xZzTKOqnHN3XQWkl0QFJYVDIiJYJrVll7ExCkpEq/PahOGzIBBV+tpMstJgmKM3lr/lu/jmg==} dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/store': 6.5.10(react-dom@17.0.2)(react@17.0.2) - core-js: 3.25.0 + '@storybook/store': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + core-js: 3.31.1 doctrine: 3.0.0 lodash: 4.17.21 regenerator-runtime: 0.13.11 @@ -7805,21 +6045,22 @@ packages: - supports-color dev: true - /@storybook/instrumenter@6.5.10(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-3yKJW68wTnGYEts2mJQG6M7ZE+fe54fuy5lBBzRtvWnC15uWTxuaiFp2kxH5b+stSCi4m71ws45RNiEafdBgEQ==} + /@storybook/global/5.0.0: + resolution: {integrity: sha512-FcOqPAXACP0I3oJ/ws6/rrPT9WGhu915Cg8D02a9YxLo0DE9zI+a9A5gRGvmQ09fiWPukqI8ZAEoQEdWUKMQdQ==} + dev: true + + /@storybook/instrumenter/7.0.26: + resolution: {integrity: sha512-7Ty0LTslgkm5RyH6CqTAKhWz/cF6wq/sNdMYKwvVZHWNZ2LKMtXD0RWM2caCPruAGOQ9+52H+3s4TZGKaPSSWQ==} dependencies: - '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.10 - '@storybook/core-events': 6.5.10 - core-js: 3.25.0 - global: 4.4.0 - transitivePeerDependencies: - - react - - react-dom + '@storybook/channels': 7.0.26 + '@storybook/client-logger': 7.0.26 + '@storybook/core-events': 7.0.26 + '@storybook/global': 5.0.0 + '@storybook/preview-api': 7.0.26 dev: true - /@storybook/manager-webpack4@6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4): - resolution: {integrity: sha512-N/TlNDhuhARuFipR/ZJ/xEVESz23iIbCsZ4VNehLHm8PpiGlQUehk+jMjWmz5XV0bJItwjRclY+CU3GjZKblfQ==} + /@storybook/manager-webpack4/6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy: + resolution: {integrity: sha512-5VJZwmQU6AgdsBPsYdu886UKBHQ9SJEnFMaeUxKEclXk+iRsmbzlL4GHKyVd6oGX/ZaecZtcHPR6xrzmA4Ziew==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -7828,43 +6069,43 @@ packages: typescript: optional: true dependencies: - '@babel/core': 7.22.5 - '@babel/plugin-transform-template-literals': 7.18.9(@babel/core@7.22.5) - '@babel/preset-react': 7.18.6(@babel/core@7.22.5) - '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/core-client': 6.5.10(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4)(webpack@4.46.0) - '@storybook/core-common': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) - '@storybook/node-logger': 6.5.10 - '@storybook/theming': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/ui': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@types/node': 16.11.56 - '@types/webpack': 4.41.32 - babel-loader: 8.2.5(@babel/core@7.22.5)(webpack@4.46.0) + '@babel/core': 7.22.8 + '@babel/plugin-transform-template-literals': 7.22.5_@babel+core@7.22.8 + '@babel/preset-react': 7.22.5_@babel+core@7.22.8 + '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/core-client': 6.5.16_zpymzxef3xv3tkikcnxd3qomju + '@storybook/core-common': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy + '@storybook/node-logger': 6.5.16 + '@storybook/theming': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/ui': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@types/node': 16.18.38 + '@types/webpack': 4.41.33 + babel-loader: 8.3.0_n6tf3ekqtzvxjokzr6jiserpma case-sensitive-paths-webpack-plugin: 2.4.0 chalk: 4.1.2 - core-js: 3.25.0 - css-loader: 3.6.0(webpack@4.46.0) - express: 4.18.1 - file-loader: 6.2.0(webpack@4.46.0) + core-js: 3.31.1 + css-loader: 3.6.0_webpack@4.46.0 + express: 4.18.2 + file-loader: 6.2.0_webpack@4.46.0 find-up: 5.0.0 fs-extra: 9.1.0 - html-webpack-plugin: 4.5.2(webpack@4.46.0) - node-fetch: 2.6.11 - pnp-webpack-plugin: 1.6.4(typescript@4.8.4) + html-webpack-plugin: 4.5.2_webpack@4.46.0 + node-fetch: 2.6.12 + pnp-webpack-plugin: 1.6.4_typescript@4.9.5 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 read-pkg-up: 7.0.1 regenerator-runtime: 0.13.11 resolve-from: 5.0.0 - style-loader: 1.3.0(webpack@4.46.0) + style-loader: 1.3.0_webpack@4.46.0 telejson: 6.0.8 - terser-webpack-plugin: 4.2.3(webpack@4.46.0) + terser-webpack-plugin: 4.2.3_webpack@4.46.0 ts-dedent: 2.2.0 - typescript: 4.8.4 - url-loader: 4.1.1(file-loader@6.2.0)(webpack@4.46.0) + typescript: 4.9.5 + url-loader: 4.1.1_lit45vopotvaqup7lrvlnvtxwy util-deprecate: 1.0.2 webpack: 4.46.0 - webpack-dev-middleware: 3.7.3(webpack@4.46.0) + webpack-dev-middleware: 3.7.3_webpack@4.46.0 webpack-virtual-modules: 0.2.2 transitivePeerDependencies: - bluebird @@ -7876,36 +6117,17 @@ packages: - webpack-command dev: true - /@storybook/mdx1-csf@0.0.1(@babel/core@7.18.13): - resolution: {integrity: sha512-4biZIWWzoWlCarMZmTpqcJNgo/RBesYZwGFbQeXiGYsswuvfWARZnW9RE9aUEMZ4XPn7B1N3EKkWcdcWe/K2tg==} - dependencies: - '@babel/generator': 7.22.5 - '@babel/parser': 7.22.5 - '@babel/preset-env': 7.18.10(@babel/core@7.18.13) - '@babel/types': 7.22.5 - '@mdx-js/mdx': 1.6.22 - '@types/lodash': 4.14.195 - js-string-escape: 1.0.1 - loader-utils: 2.0.2 - lodash: 4.17.21 - prettier: 2.3.0 - ts-dedent: 2.2.0 - transitivePeerDependencies: - - '@babel/core' - - supports-color - dev: true - - /@storybook/mdx1-csf@0.0.1(@babel/core@7.22.5): + /@storybook/mdx1-csf/0.0.1_@babel+core@7.22.8: resolution: {integrity: sha512-4biZIWWzoWlCarMZmTpqcJNgo/RBesYZwGFbQeXiGYsswuvfWARZnW9RE9aUEMZ4XPn7B1N3EKkWcdcWe/K2tg==} dependencies: - '@babel/generator': 7.22.5 - '@babel/parser': 7.22.5 - '@babel/preset-env': 7.18.10(@babel/core@7.22.5) + '@babel/generator': 7.22.7 + '@babel/parser': 7.22.7 + '@babel/preset-env': 7.22.7_@babel+core@7.22.8 '@babel/types': 7.22.5 '@mdx-js/mdx': 1.6.22 '@types/lodash': 4.14.195 js-string-escape: 1.0.1 - loader-utils: 2.0.2 + loader-utils: 2.0.4 lodash: 4.17.21 prettier: 2.3.0 ts-dedent: 2.2.0 @@ -7914,18 +6136,18 @@ packages: - supports-color dev: true - /@storybook/mdx1-csf@0.0.4(@babel/core@7.18.13)(react@17.0.2): + /@storybook/mdx1-csf/0.0.4_wumd2qseuobkz2wudw2hqnarr4: resolution: {integrity: sha512-xxUEMy0D+0G1aSYxbeVNbs+XBU5nCqW4I7awpBYSTywXDv/MJWeC6FDRpj5P1pgfq8j8jWDD5ZDvBQ7syFg0LQ==} dependencies: - '@babel/generator': 7.22.5 - '@babel/parser': 7.22.5 - '@babel/preset-env': 7.18.10(@babel/core@7.18.13) + '@babel/generator': 7.22.7 + '@babel/parser': 7.22.7 + '@babel/preset-env': 7.22.7_@babel+core@7.22.8 '@babel/types': 7.22.5 '@mdx-js/mdx': 1.6.22 - '@mdx-js/react': 1.6.22(react@17.0.2) + '@mdx-js/react': 1.6.22_react@17.0.2 '@types/lodash': 4.14.195 js-string-escape: 1.0.1 - loader-utils: 2.0.2 + loader-utils: 2.0.4 lodash: 4.17.21 prettier: 2.3.0 ts-dedent: 2.2.0 @@ -7935,69 +6157,89 @@ packages: - supports-color dev: true - /@storybook/node-logger@6.5.10: - resolution: {integrity: sha512-bYswXIKV7Stru8vYfkjUMNN8UhF7Qg7NRsUvG5Djt5lLIae1XmUIgnH40mU/nW4X4BSfcR9MKxsSsngvn2WmQg==} + /@storybook/node-logger/6.5.16: + resolution: {integrity: sha512-YjhBKrclQtjhqFNSO+BZK+RXOx6EQypAELJKoLFaawg331e8VUfvUuRCNB3fcEWp8G9oH13PQQte0OTjLyyOYg==} dependencies: '@types/npmlog': 4.1.4 chalk: 4.1.2 - core-js: 3.25.0 + core-js: 3.31.1 npmlog: 5.0.1 pretty-hrtime: 1.0.3 dev: true - /@storybook/postinstall@6.5.10: - resolution: {integrity: sha512-xqUdpnFHYkn8MgtV+QztvIsRWa6jQUk7QT1Mu17Y0S7PbslNGsuskRPHenHhACXBJF+TM86R+4BaAhnVYTmElw==} + /@storybook/postinstall/6.5.16: + resolution: {integrity: sha512-08K2q+qN6pqyPW7PHLCZ5G5Xa6Wosd6t0F16PQ4abX2ItlJLabVoJN5mZ0gm/aeLTjD8QYr8IDvacu4eXh0SVA==} dependencies: - core-js: 3.25.0 + core-js: 3.31.1 + dev: true + + /@storybook/preview-api/7.0.26: + resolution: {integrity: sha512-uJwA4errBOZOoDF2T7Z2oLqjAYvvjMr31sTsOoT0niJtWr29RQp8yS6VoSrsuh+y3FAVqBEl5pS+DX3IGLjvxw==} + dependencies: + '@storybook/channel-postmessage': 7.0.26 + '@storybook/channels': 7.0.26 + '@storybook/client-logger': 7.0.26 + '@storybook/core-events': 7.0.26 + '@storybook/csf': 0.1.1 + '@storybook/global': 5.0.0 + '@storybook/types': 7.0.26 + '@types/qs': 6.9.7 + dequal: 2.0.3 + lodash: 4.17.21 + memoizerific: 1.11.3 + qs: 6.11.2 + synchronous-promise: 2.0.17 + ts-dedent: 2.2.0 + util-deprecate: 1.0.2 dev: true - /@storybook/preview-web@6.5.10(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-sTC/o5gkvALOtcNgtApGKGN9EavvSxRHBeBh+5BQjV2qQ8ap+26RsfUizNBECAa2Jrn4osaDYn9HRhJLFL69WA==} + /@storybook/preview-web/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + resolution: {integrity: sha512-IJnvfe2sKCfk7apN9Fu9U8qibbarrPX5JB55ZzK1amSHVmSDuYk5MIMc/U3NnSQNnvd1DO5v/zMcGgj563hrtg==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/channel-postmessage': 6.5.10 - '@storybook/client-logger': 6.5.10 - '@storybook/core-events': 6.5.10 + '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/channel-postmessage': 6.5.16 + '@storybook/client-logger': 6.5.16 + '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/store': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/store': 6.5.16_sfoxds7t5ydpegc3knd667wn6m ansi-to-html: 0.6.15 - core-js: 3.25.0 + core-js: 3.31.1 global: 4.4.0 lodash: 4.17.21 - qs: 6.11.0 + qs: 6.11.2 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 regenerator-runtime: 0.13.11 - synchronous-promise: 2.0.16 + synchronous-promise: 2.0.17 ts-dedent: 2.2.0 unfetch: 4.2.0 util-deprecate: 1.0.2 dev: true - /@storybook/react-docgen-typescript-plugin@1.0.2-canary.6.9d540b91e815f8fc2f8829189deb00553559ff63.0(typescript@4.8.4)(webpack@5.74.0): + /@storybook/react-docgen-typescript-plugin/1.0.2-canary.6.9d540b91e815f8fc2f8829189deb00553559ff63.0_dhumxs7xcapy5ah5ryvaq7oilu: resolution: {integrity: sha512-eVg3BxlOm2P+chijHBTByr90IZVUtgRW56qEOLX7xlww2NBuKrcavBlcmn+HH7GIUktquWkMPtvy6e0W0NgA5w==} peerDependencies: typescript: '>= 3.x' webpack: '>= 4' dependencies: - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 endent: 2.1.0 find-cache-dir: 3.3.2 flat-cache: 3.0.4 micromatch: 4.0.5 - react-docgen-typescript: 2.2.2(typescript@4.8.4) - tslib: 2.5.3 - typescript: 4.8.4 - webpack: 5.74.0(esbuild@0.18.11) + react-docgen-typescript: 2.2.2_typescript@4.9.5 + tslib: 2.6.0 + typescript: 4.9.5 + webpack: 5.88.1 transitivePeerDependencies: - supports-color dev: true - /@storybook/react@6.5.10(@babel/core@7.18.13)(esbuild@0.18.11)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(require-from-string@2.0.2)(typescript@4.8.4): - resolution: {integrity: sha512-m8S1qQrwA7pDGwdKEvL6LV3YKvSzVUY297Fq+xcTU3irnAy4sHDuFoLqV6Mi1510mErK1r8+rf+0R5rEXB219g==} + /@storybook/react/6.5.16_7i6vyke6ny6b2xsni3leqxtq5y: + resolution: {integrity: sha512-cBtNlOzf/MySpNLBK22lJ8wFU22HnfTB2xJyBk7W7Zi71Lm7Uxkhv1Pz8HdiQndJ0SlsAAQOWjQYsSZsGkZIaA==} engines: {node: '>=10.13.0'} hasBin: true peerDependencies: @@ -8024,46 +6266,45 @@ packages: typescript: optional: true dependencies: - '@babel/core': 7.18.13 - '@babel/preset-flow': 7.18.6(@babel/core@7.18.13) - '@babel/preset-react': 7.18.6(@babel/core@7.18.13) - '@pmmmwh/react-refresh-webpack-plugin': 0.5.7(react-refresh@0.11.0)(webpack@5.74.0) - '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.10 - '@storybook/core': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4)(webpack@5.74.0) - '@storybook/core-common': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) + '@babel/core': 7.22.8 + '@babel/preset-flow': 7.22.5_@babel+core@7.22.8 + '@babel/preset-react': 7.22.5_@babel+core@7.22.8 + '@pmmmwh/react-refresh-webpack-plugin': 0.5.10_3s7aftcw26g2vhqubpxl7hhzpa + '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/client-logger': 6.5.16 + '@storybook/core': 6.5.16_kdhf477f3bq3v2mc53jwn63t6u + '@storybook/core-common': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/docs-tools': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/node-logger': 6.5.10 - '@storybook/react-docgen-typescript-plugin': 1.0.2-canary.6.9d540b91e815f8fc2f8829189deb00553559ff63.0(typescript@4.8.4)(webpack@5.74.0) + '@storybook/docs-tools': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/node-logger': 6.5.16 + '@storybook/react-docgen-typescript-plugin': 1.0.2-canary.6.9d540b91e815f8fc2f8829189deb00553559ff63.0_dhumxs7xcapy5ah5ryvaq7oilu '@storybook/semver': 7.3.2 - '@storybook/store': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/store': 6.5.16_sfoxds7t5ydpegc3knd667wn6m '@types/estree': 0.0.51 - '@types/node': 16.11.56 - '@types/webpack-env': 1.18.0 + '@types/node': 16.18.38 + '@types/webpack-env': 1.18.1 acorn: 7.4.1 - acorn-jsx: 5.3.2(acorn@7.4.1) + acorn-jsx: 5.3.2_acorn@7.4.1 acorn-walk: 7.2.0 babel-plugin-add-react-displayname: 0.0.5 babel-plugin-react-docgen: 4.2.1 - core-js: 3.25.0 - escodegen: 2.0.0 + core-js: 3.31.1 + escodegen: 2.1.0 fs-extra: 9.1.0 global: 4.4.0 - html-tags: 3.2.0 + html-tags: 3.3.1 lodash: 4.17.21 prop-types: 15.8.1 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) - react-element-to-jsx-string: 14.3.4(react-dom@17.0.2)(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 + react-element-to-jsx-string: 14.3.4_sfoxds7t5ydpegc3knd667wn6m react-refresh: 0.11.0 read-pkg-up: 7.0.1 - regenerator-runtime: 0.13.9 - require-from-string: 2.0.2 + regenerator-runtime: 0.13.11 ts-dedent: 2.2.0 - typescript: 4.8.4 + typescript: 4.9.5 util-deprecate: 1.0.2 - webpack: 5.74.0(esbuild@0.18.11) + webpack: 5.88.1 transitivePeerDependencies: - '@storybook/mdx2-csf' - '@swc/core' @@ -8086,84 +6327,84 @@ packages: - webpack-plugin-serve dev: true - /@storybook/router@6.5.10(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-O+vNW/eEpYFF8eCg5jZjNQ6q2DKQVxqDRPCy9pJdEbvavMDZn6AFYgVK+VJe5F4211WW2yncOu922xObCxXJYg==} + /@storybook/router/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + resolution: {integrity: sha512-ZgeP8a5YV/iuKbv31V8DjPxlV4AzorRiR8OuSt/KqaiYXNXlOoQDz/qMmiNcrshrfLpmkzoq7fSo4T8lWo2UwQ==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/client-logger': 6.5.10 - core-js: 3.25.0 + '@storybook/client-logger': 6.5.16 + core-js: 3.31.1 memoizerific: 1.11.3 - qs: 6.11.0 + qs: 6.11.2 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 regenerator-runtime: 0.13.11 dev: true - /@storybook/semver@7.3.2: + /@storybook/semver/7.3.2: resolution: {integrity: sha512-SWeszlsiPsMI0Ps0jVNtH64cI5c0UF3f7KgjVKJoNP30crQ6wUSddY2hsdeczZXEKVJGEn50Q60flcGsQGIcrg==} engines: {node: '>=10'} hasBin: true dependencies: - core-js: 3.25.0 + core-js: 3.31.1 find-up: 4.1.0 dev: true - /@storybook/source-loader@6.5.10(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-1RxxRumpjs8VUUwES9LId+cuNQnixhZAcwCxd6jaKkTZbjiQCtAhXX6DBTjJGV1u/JnCsqEp5b1wB8j/EioNHw==} + /@storybook/source-loader/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + resolution: {integrity: sha512-fyVl4jrM/5JLrb48aqXPu7sTsmySQaVGFp1zfeqvPPlJRFMastDrePm5XGPN7Qjv1wsKmpuBvuweFKOT1pru3g==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.10 + '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/client-logger': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - core-js: 3.25.0 + core-js: 3.31.1 estraverse: 5.3.0 global: 4.4.0 - loader-utils: 2.0.2 + loader-utils: 2.0.4 lodash: 4.17.21 prettier: 2.3.0 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 regenerator-runtime: 0.13.11 dev: true - /@storybook/store@6.5.10(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-RswrSYh2IiKkytFPxP9AvP+hekjrvHK2ILvyDk2ZgduCN4n5ivsekOb+N3M2t+dq1eLuW9or5n2T4OWwAwjxxQ==} + /@storybook/store/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + resolution: {integrity: sha512-g+bVL5hmMq/9cM51K04e37OviUPHT0rHHrRm5wj/hrf18Kd9120b3sxdQ5Dc+HZ292yuME0n+cyrQPTYx9Epmw==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.10 - '@storybook/core-events': 6.5.10 + '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/client-logger': 6.5.16 + '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - core-js: 3.25.0 + core-js: 3.31.1 fast-deep-equal: 3.1.3 global: 4.4.0 lodash: 4.17.21 memoizerific: 1.11.3 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 regenerator-runtime: 0.13.11 slash: 3.0.0 stable: 0.1.8 - synchronous-promise: 2.0.16 + synchronous-promise: 2.0.17 ts-dedent: 2.2.0 util-deprecate: 1.0.2 dev: true - /@storybook/telemetry@6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4): - resolution: {integrity: sha512-+M5HILDFS8nDumLxeSeAwi1MTzIuV6UWzV4yB2wcsEXOBTdplcl9oYqFKtlst78oOIdGtpPYxYfivDlqxC2K4g==} + /@storybook/telemetry/6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy: + resolution: {integrity: sha512-CWr5Uko1l9jJW88yTXsZTj/3GTabPvw0o7pDPOXPp8JRZiJTxv1JFaFCafhK9UzYbgcRuGfCC8kEWPZims7iKA==} dependencies: - '@storybook/client-logger': 6.5.10 - '@storybook/core-common': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) + '@storybook/client-logger': 6.5.16 + '@storybook/core-common': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy chalk: 4.1.2 - core-js: 3.25.0 + core-js: 3.31.1 detect-package-manager: 2.0.1 - fetch-retry: 5.0.3 + fetch-retry: 5.0.6 fs-extra: 9.1.0 global: 4.4.0 isomorphic-unfetch: 3.1.0 @@ -8182,20 +6423,17 @@ packages: - webpack-command dev: true - /@storybook/testing-library@0.0.11(react-dom@17.0.2)(react@17.0.2): + /@storybook/testing-library/0.0.11: resolution: {integrity: sha512-8KbKx3s1e+uF3oWlPdyXRpZa6xtCsCHtXh1nCTisMA6P5YcSDaCg59NXIOVIQCAwKvjRomlqMJH8JL1WyOzeVg==} dependencies: - '@storybook/client-logger': 6.5.10 - '@storybook/instrumenter': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@testing-library/dom': 8.17.1 - '@testing-library/user-event': 13.5.0(@testing-library/dom@8.17.1) + '@storybook/client-logger': 7.0.26 + '@storybook/instrumenter': 7.0.26 + '@testing-library/dom': 8.20.1 + '@testing-library/user-event': 13.5.0_szfc7t2zqsdonxwckqxkjn2the ts-dedent: 2.2.0 - transitivePeerDependencies: - - react - - react-dom dev: true - /@storybook/testing-react@1.3.0(@storybook/addons@6.5.10)(@storybook/client-api@6.5.10)(@storybook/preview-web@6.5.10)(@storybook/react@6.5.10)(react@17.0.2): + /@storybook/testing-react/1.3.0_o7jp7fwfcghoqe4nbzdqvmyhrm: resolution: {integrity: sha512-TfxzflxwBHSPhetWKuYt239t+1iN8gnnUN8OKo5UGtwwirghKQlApjH23QXW6j8YBqFhmq+yP29Oqf8HgKCFLw==} engines: {node: '>=10'} peerDependencies: @@ -8205,72 +6443,78 @@ packages: '@storybook/react': '>=6.4.0' react: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-api': 6.5.10(react-dom@17.0.2)(react@17.0.2) '@storybook/csf': 0.0.2--canary.87bc651.0 - '@storybook/preview-web': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/react': 6.5.10(@babel/core@7.18.13)(esbuild@0.18.11)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(require-from-string@2.0.2)(typescript@4.8.4) + '@storybook/react': 6.5.16_7i6vyke6ny6b2xsni3leqxtq5y react: 17.0.2 dev: true - /@storybook/theming@6.5.10(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-BvTQBBcSEwKKcsVmF+Ol6v0RIQUr+bxP7gb10wtfBd23mZTEFA0C1N5FnZr/dDeiBKG1pvf1UKvoYA731y0BsA==} + /@storybook/theming/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + resolution: {integrity: sha512-hNLctkjaYLRdk1+xYTkC1mg4dYz2wSv6SqbLpcKMbkPHTE0ElhddGPHQqB362md/w9emYXNkt1LSMD8Xk9JzVQ==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/client-logger': 6.5.10 - core-js: 3.25.0 + '@storybook/client-logger': 6.5.16 + core-js: 3.31.1 memoizerific: 1.11.3 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 regenerator-runtime: 0.13.11 dev: true - /@storybook/ui@6.5.10(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-6iaoaRAiTqB1inTw35vao+5hjcDE0Qa0A3a9ZIeNa6yHvpB1k0lO/N/0PMrRdVvySYpXVD1iry4z4QYdo1rU+w==} + /@storybook/types/7.0.26: + resolution: {integrity: sha512-5RBi6agtDglNXdffmw4+Fyv2dUdlIdeOdUj0O5+JRYajTxfHdurZd9r/42z4OstN+ORDkLA/svt8Q9JyRpIb6Q==} + dependencies: + '@storybook/channels': 7.0.26 + '@types/babel__core': 7.20.1 + '@types/express': 4.17.17 + file-system-cache: 2.3.0 + dev: true + + /@storybook/ui/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + resolution: {integrity: sha512-rHn/n12WM8BaXtZ3IApNZCiS+C4Oc5+Lkl4MoctX8V7QSml0SxZBB5hsJ/AiWkgbRxjQpa/L/Nt7/Qw0FjTH/A==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/api': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/channels': 6.5.10 - '@storybook/client-logger': 6.5.10 - '@storybook/components': 6.5.10(react-dom@17.0.2)(react@17.0.2) - '@storybook/core-events': 6.5.10 - '@storybook/router': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/channels': 6.5.16 + '@storybook/client-logger': 6.5.16 + '@storybook/components': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/core-events': 6.5.16 + '@storybook/router': 6.5.16_sfoxds7t5ydpegc3knd667wn6m '@storybook/semver': 7.3.2 - '@storybook/theming': 6.5.10(react-dom@17.0.2)(react@17.0.2) - core-js: 3.25.0 + '@storybook/theming': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + core-js: 3.31.1 memoizerific: 1.11.3 - qs: 6.11.0 + qs: 6.11.2 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 regenerator-runtime: 0.13.11 resolve-from: 5.0.0 dev: true - /@surma/rollup-plugin-off-main-thread@2.2.3: + /@surma/rollup-plugin-off-main-thread/2.2.3: resolution: {integrity: sha512-lR8q/9W7hZpMWweNiAKU7NQerBnzQQLvi8qnTDU/fxItPhtZVMbPV3lbCwjhIlNBe9Bbr5V+KHshvWmVSG9cxQ==} dependencies: - ejs: 3.1.8 + ejs: 3.1.9 json5: 2.2.3 magic-string: 0.25.9 - string.prototype.matchall: 4.0.7 + string.prototype.matchall: 4.0.8 dev: true - /@sveltejs/adapter-auto@2.1.0(@sveltejs/kit@1.20.2): + /@sveltejs/adapter-auto/2.1.0_@sveltejs+kit@1.22.2: resolution: {integrity: sha512-o2pZCfATFtA/Gw/BB0Xm7k4EYaekXxaPGER3xGSY3FvzFJGTlJlZjBseaXwYSM94lZ0HniOjTokN3cWaLX6fow==} peerDependencies: '@sveltejs/kit': ^1.0.0 dependencies: - '@sveltejs/kit': 1.20.2(svelte@3.59.1)(vite@4.3.9) + '@sveltejs/kit': 1.22.2_svelte@3.59.2+vite@4.4.3 import-meta-resolve: 3.0.0 dev: true - /@sveltejs/kit@1.20.2(svelte@3.59.1)(vite@4.3.9): - resolution: {integrity: sha512-MtR1i+HtmYWcRgtubw1GQqT/+CWXL/z24PegE0xYAdObbhdr7YtEfmoe705D/JZMtMmoPXrmSk4W0MfL5A3lYw==} + /@sveltejs/kit/1.22.2_svelte@3.59.2+vite@4.4.3: + resolution: {integrity: sha512-T6GY5jSfQgoDnNPNqAuDi9IK+ZW0TspzTV16UAN6GTsxbri67DGVIbw7QOXPg8FMrZQMmda1AtAxPMfXbOqCgw==} engines: {node: ^16.14 || >=18} hasBin: true requiresBuild: true @@ -8278,26 +6522,25 @@ packages: svelte: ^3.54.0 || ^4.0.0-next.0 vite: ^4.0.0 dependencies: - '@sveltejs/vite-plugin-svelte': 2.4.2(svelte@3.59.1)(vite@4.3.9) + '@sveltejs/vite-plugin-svelte': 2.4.2_svelte@3.59.2+vite@4.4.3 '@types/cookie': 0.5.1 cookie: 0.5.0 devalue: 4.3.2 esm-env: 1.0.0 kleur: 4.1.5 - magic-string: 0.30.0 + magic-string: 0.30.1 mime: 3.0.0 sade: 1.8.1 set-cookie-parser: 2.6.0 sirv: 2.0.3 - svelte: 3.59.1 - tiny-glob: 0.2.9 + svelte: 3.59.2 undici: 5.22.1 - vite: 4.3.9(@types/node@18.16.19) + vite: 4.4.3 transitivePeerDependencies: - supports-color dev: true - /@sveltejs/vite-plugin-svelte-inspector@1.0.3(@sveltejs/vite-plugin-svelte@2.4.2)(svelte@3.59.1)(vite@4.3.9): + /@sveltejs/vite-plugin-svelte-inspector/1.0.3_cryykssficcegziiuctbhcjymy: resolution: {integrity: sha512-Khdl5jmmPN6SUsVuqSXatKpQTMIifoQPDanaxC84m9JxIibWvSABJyHpyys0Z+1yYrxY5TTEQm+6elh0XCMaOA==} engines: {node: ^14.18.0 || >= 16} peerDependencies: @@ -8305,15 +6548,15 @@ packages: svelte: ^3.54.0 || ^4.0.0 vite: ^4.0.0 dependencies: - '@sveltejs/vite-plugin-svelte': 2.4.2(svelte@3.59.1)(vite@4.3.9) - debug: 4.3.4(supports-color@8.1.1) - svelte: 3.59.1 - vite: 4.3.9(@types/node@18.16.19) + '@sveltejs/vite-plugin-svelte': 2.4.2_svelte@4.0.5+vite@4.4.3 + debug: 4.3.4 + svelte: 4.0.5 + vite: 4.4.3 transitivePeerDependencies: - supports-color dev: true - /@sveltejs/vite-plugin-svelte-inspector@1.0.3(@sveltejs/vite-plugin-svelte@2.4.2)(svelte@4.0.5)(vite@4.3.9): + /@sveltejs/vite-plugin-svelte-inspector/1.0.3_f2bspsxjd2jtgfnohks6gor5ka: resolution: {integrity: sha512-Khdl5jmmPN6SUsVuqSXatKpQTMIifoQPDanaxC84m9JxIibWvSABJyHpyys0Z+1yYrxY5TTEQm+6elh0XCMaOA==} engines: {node: ^14.18.0 || >= 16} peerDependencies: @@ -8321,186 +6564,158 @@ packages: svelte: ^3.54.0 || ^4.0.0 vite: ^4.0.0 dependencies: - '@sveltejs/vite-plugin-svelte': 2.4.2(svelte@4.0.5)(vite@4.3.9) - debug: 4.3.4(supports-color@8.1.1) - svelte: 4.0.5 - vite: 4.3.9(@types/node@18.16.19) + '@sveltejs/vite-plugin-svelte': 2.4.2_svelte@3.59.2+vite@4.4.3 + debug: 4.3.4 + svelte: 3.59.2 + vite: 4.4.3 transitivePeerDependencies: - supports-color dev: true - /@sveltejs/vite-plugin-svelte@2.4.2(svelte@3.59.1)(vite@4.3.9): + /@sveltejs/vite-plugin-svelte/2.4.2_svelte@3.59.2+vite@4.4.3: resolution: {integrity: sha512-ePfcC48ftMKhkT0OFGdOyycYKnnkT6i/buzey+vHRTR/JpQvuPzzhf1PtKqCDQfJRgoPSN2vscXs6gLigx/zGw==} engines: {node: ^14.18.0 || >= 16} peerDependencies: svelte: ^3.54.0 || ^4.0.0 vite: ^4.0.0 dependencies: - '@sveltejs/vite-plugin-svelte-inspector': 1.0.3(@sveltejs/vite-plugin-svelte@2.4.2)(svelte@3.59.1)(vite@4.3.9) - debug: 4.3.4(supports-color@8.1.1) + '@sveltejs/vite-plugin-svelte-inspector': 1.0.3_f2bspsxjd2jtgfnohks6gor5ka + debug: 4.3.4 deepmerge: 4.3.1 kleur: 4.1.5 magic-string: 0.30.1 - svelte: 3.59.1 - svelte-hmr: 0.15.2(svelte@3.59.1) - vite: 4.3.9(@types/node@18.16.19) - vitefu: 0.2.4(vite@4.3.9) + svelte: 3.59.2 + svelte-hmr: 0.15.2_svelte@3.59.2 + vite: 4.4.3 + vitefu: 0.2.4_vite@4.4.3 transitivePeerDependencies: - supports-color dev: true - /@sveltejs/vite-plugin-svelte@2.4.2(svelte@4.0.5)(vite@4.3.9): + /@sveltejs/vite-plugin-svelte/2.4.2_svelte@4.0.5+vite@4.4.3: resolution: {integrity: sha512-ePfcC48ftMKhkT0OFGdOyycYKnnkT6i/buzey+vHRTR/JpQvuPzzhf1PtKqCDQfJRgoPSN2vscXs6gLigx/zGw==} engines: {node: ^14.18.0 || >= 16} peerDependencies: svelte: ^3.54.0 || ^4.0.0 vite: ^4.0.0 dependencies: - '@sveltejs/vite-plugin-svelte-inspector': 1.0.3(@sveltejs/vite-plugin-svelte@2.4.2)(svelte@4.0.5)(vite@4.3.9) - debug: 4.3.4(supports-color@8.1.1) + '@sveltejs/vite-plugin-svelte-inspector': 1.0.3_cryykssficcegziiuctbhcjymy + debug: 4.3.4 deepmerge: 4.3.1 kleur: 4.1.5 magic-string: 0.30.1 svelte: 4.0.5 - svelte-hmr: 0.15.2(svelte@4.0.5) - vite: 4.3.9(@types/node@18.16.19) - vitefu: 0.2.4(vite@4.3.9) + svelte-hmr: 0.15.2_svelte@4.0.5 + vite: 4.4.3 + vitefu: 0.2.4_vite@4.4.3 transitivePeerDependencies: - supports-color dev: true - /@szmarczak/http-timer@5.0.1: + /@szmarczak/http-timer/5.0.1: resolution: {integrity: sha512-+PmQX0PiAYPMeVYe237LJAYvOMYW1j2rH5YROyS3b4CTVJum34HfRvKvAzozHAQG0TnHNdUfY9nCeUyRAs//cw==} engines: {node: '>=14.16'} dependencies: defer-to-connect: 2.0.1 dev: true - /@testing-library/cypress@9.0.0(cypress@12.16.0): + /@testing-library/cypress/9.0.0_cypress@12.17.1: resolution: {integrity: sha512-c1XiCGeHGGTWn0LAU12sFUfoX3qfId5gcSE2yHode+vsyHDWraxDPALjVnHd4/Fa3j4KBcc5k++Ccy6A9qnkMA==} engines: {node: '>=12', npm: '>=6'} peerDependencies: cypress: ^12.0.0 dependencies: - '@babel/runtime': 7.18.9 - '@testing-library/dom': 8.19.0 - cypress: 12.16.0 - dev: true - - /@testing-library/dom@8.17.1: - resolution: {integrity: sha512-KnH2MnJUzmFNPW6RIKfd+zf2Wue8mEKX0M3cpX6aKl5ZXrJM1/c/Pc8c2xDNYQCnJO48Sm5ITbMXgqTr3h4jxQ==} - engines: {node: '>=12'} - dependencies: - '@babel/code-frame': 7.22.5 - '@babel/runtime': 7.18.9 - '@types/aria-query': 4.2.2 - aria-query: 5.3.0 - chalk: 4.1.2 - dom-accessibility-api: 0.5.14 - lz-string: 1.4.4 - pretty-format: 27.5.1 + '@babel/runtime': 7.22.6 + '@testing-library/dom': 8.20.1 + cypress: 12.17.1 dev: true - /@testing-library/dom@8.19.0: - resolution: {integrity: sha512-6YWYPPpxG3e/xOo6HIWwB/58HukkwIVTOaZ0VwdMVjhRUX/01E4FtQbck9GazOOj7MXHc5RBzMrU86iBJHbI+A==} + /@testing-library/dom/8.20.1: + resolution: {integrity: sha512-/DiOQ5xBxgdYRC8LNk7U+RWat0S3qRLeIw3ZIkMQ9kkVlRmwD/Eg8k8CqIpD6GW7u20JIUOfMKbxtiLutpjQ4g==} engines: {node: '>=12'} dependencies: '@babel/code-frame': 7.22.5 - '@babel/runtime': 7.18.9 - '@types/aria-query': 4.2.2 - aria-query: 5.3.0 + '@babel/runtime': 7.22.6 + '@types/aria-query': 5.0.1 + aria-query: 5.1.3 chalk: 4.1.2 - dom-accessibility-api: 0.5.14 + dom-accessibility-api: 0.5.16 lz-string: 1.5.0 pretty-format: 27.5.1 dev: true - /@testing-library/dom@9.3.1: + /@testing-library/dom/9.3.1: resolution: {integrity: sha512-0DGPd9AR3+iDTjGoMpxIkAsUihHZ3Ai6CneU6bRRrffXMgzCdlNk43jTrD2/5LT6CBb3MWTP8v510JzYtahD2w==} engines: {node: '>=14'} dependencies: '@babel/code-frame': 7.22.5 - '@babel/runtime': 7.18.9 + '@babel/runtime': 7.22.6 '@types/aria-query': 5.0.1 aria-query: 5.1.3 chalk: 4.1.2 - dom-accessibility-api: 0.5.14 + dom-accessibility-api: 0.5.16 lz-string: 1.5.0 pretty-format: 27.5.1 dev: true - /@testing-library/jest-dom@5.16.5: + /@testing-library/jest-dom/5.16.5: resolution: {integrity: sha512-N5ixQ2qKpi5OLYfwQmUb/5mSV9LneAcaUfp32pn4yCnpb8r/Yz0pXFPck21dIicKmi+ta5WRAknkZCfA8refMA==} engines: {node: '>=8', npm: '>=6', yarn: '>=1'} dependencies: - '@adobe/css-tools': 4.0.1 - '@babel/runtime': 7.18.9 - '@types/testing-library__jest-dom': 5.14.5 - aria-query: 5.0.2 + '@adobe/css-tools': 4.2.0 + '@babel/runtime': 7.22.6 + '@types/testing-library__jest-dom': 5.14.8 + aria-query: 5.3.0 chalk: 3.0.0 css.escape: 1.5.1 - dom-accessibility-api: 0.5.14 + dom-accessibility-api: 0.5.16 lodash: 4.17.21 redent: 3.0.0 dev: true - /@testing-library/react@12.1.5(react-dom@17.0.2)(react@17.0.2): + /@testing-library/react/12.1.5_sfoxds7t5ydpegc3knd667wn6m: resolution: {integrity: sha512-OfTXCJUFgjd/digLUuPxa0+/3ZxsQmE7ub9kcbW/wi96Bh3o/p5vrETcBGfP17NWPGqeYYl5LTRpwyGoMC4ysg==} engines: {node: '>=12'} peerDependencies: react: <18.0.0 react-dom: <18.0.0 dependencies: - '@babel/runtime': 7.18.9 - '@testing-library/dom': 8.17.1 - '@types/react-dom': 17.0.17 + '@babel/runtime': 7.22.6 + '@testing-library/dom': 8.20.1 + '@types/react-dom': 17.0.20 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) - dev: true - - /@testing-library/react@13.3.0(react-dom@18.0.0)(react@18.0.0): - resolution: {integrity: sha512-DB79aA426+deFgGSjnf5grczDPiL4taK3hFaa+M5q7q20Kcve9eQottOG5kZ74KEr55v0tU2CQormSSDK87zYQ==} - engines: {node: '>=12'} - peerDependencies: - react: ^18.0.0 - react-dom: ^18.0.0 - dependencies: - '@babel/runtime': 7.18.9 - '@testing-library/dom': 8.17.1 - '@types/react-dom': 18.0.6 - react: 18.0.0 - react-dom: 18.0.0(react@18.0.0) + react-dom: 17.0.2_react@17.0.2 dev: true - /@testing-library/react@13.3.0(react-dom@18.2.0)(react@18.2.0): - resolution: {integrity: sha512-DB79aA426+deFgGSjnf5grczDPiL4taK3hFaa+M5q7q20Kcve9eQottOG5kZ74KEr55v0tU2CQormSSDK87zYQ==} + /@testing-library/react/13.4.0_biqbaboplfbrettd7655fr4n2y: + resolution: {integrity: sha512-sXOGON+WNTh3MLE9rve97ftaZukN3oNf2KjDy7YTx6hcTO2uuLHuCGynMDhFwGw/jYf4OJ2Qk0i4i79qMNNkyw==} engines: {node: '>=12'} peerDependencies: react: ^18.0.0 react-dom: ^18.0.0 dependencies: - '@babel/runtime': 7.18.9 - '@testing-library/dom': 8.17.1 - '@types/react-dom': 18.0.6 + '@babel/runtime': 7.22.6 + '@testing-library/dom': 8.20.1 + '@types/react-dom': 18.2.6 react: 18.2.0 - react-dom: 18.2.0(react@18.2.0) + react-dom: 18.2.0_react@18.2.0 dev: true - /@testing-library/react@13.4.0(react-dom@18.2.0)(react@18.2.0): + /@testing-library/react/13.4.0_zpnidt7m3osuk7shl3s4oenomq: resolution: {integrity: sha512-sXOGON+WNTh3MLE9rve97ftaZukN3oNf2KjDy7YTx6hcTO2uuLHuCGynMDhFwGw/jYf4OJ2Qk0i4i79qMNNkyw==} engines: {node: '>=12'} peerDependencies: react: ^18.0.0 react-dom: ^18.0.0 dependencies: - '@babel/runtime': 7.18.9 - '@testing-library/dom': 8.17.1 - '@types/react-dom': 18.0.8 - react: 18.2.0 - react-dom: 18.2.0(react@18.2.0) + '@babel/runtime': 7.22.6 + '@testing-library/dom': 8.20.1 + '@types/react-dom': 18.2.6 + react: 18.0.0 + react-dom: 18.0.0_react@18.0.0 dev: true - /@testing-library/svelte@4.0.3(svelte@4.0.5): + /@testing-library/svelte/4.0.3_svelte@4.0.5: resolution: {integrity: sha512-GldAnyGEOn5gMwME+hLVQrnfuKZFB+it5YOMnRBHX+nqeHMsSa18HeqkdvGqtqLpvn81xV7R7EYFb500ngUfXA==} engines: {node: '>= 10'} peerDependencies: @@ -8510,247 +6725,316 @@ packages: svelte: 4.0.5 dev: true - /@testing-library/user-event@13.5.0(@testing-library/dom@8.17.1): + /@testing-library/user-event/13.5.0: resolution: {integrity: sha512-5Kwtbo3Y/NowpkbRuSepbyMFkZmHgD+vPzYB/RJ4oxt5Gj/avFFBYjhw27cqSVPVw/3a67NK1PbiIr9k4Gwmdg==} engines: {node: '>=10', npm: '>=6'} peerDependencies: '@testing-library/dom': '>=7.21.4' dependencies: - '@babel/runtime': 7.18.9 - '@testing-library/dom': 8.17.1 + '@babel/runtime': 7.22.6 dev: true - /@testing-library/user-event@13.5.0(@testing-library/dom@9.3.1): + /@testing-library/user-event/13.5.0_szfc7t2zqsdonxwckqxkjn2the: resolution: {integrity: sha512-5Kwtbo3Y/NowpkbRuSepbyMFkZmHgD+vPzYB/RJ4oxt5Gj/avFFBYjhw27cqSVPVw/3a67NK1PbiIr9k4Gwmdg==} engines: {node: '>=10', npm: '>=6'} peerDependencies: '@testing-library/dom': '>=7.21.4' dependencies: - '@babel/runtime': 7.18.9 - '@testing-library/dom': 9.3.1 + '@babel/runtime': 7.22.6 + '@testing-library/dom': 8.20.1 dev: true - /@testing-library/user-event@14.4.3(@testing-library/dom@9.3.1): + /@testing-library/user-event/14.4.3: resolution: {integrity: sha512-kCUc5MEwaEMakkO5x7aoD+DLi02ehmEM2QCGWvNqAS1dV/fAvORWEjnjsEIvml59M7Y5kCkWN6fCCyPOe8OL6Q==} engines: {node: '>=12', npm: '>=6'} peerDependencies: '@testing-library/dom': '>=7.21.4' - dependencies: - '@testing-library/dom': 9.3.1 - dev: true - - /@tootallnate/once@1.1.2: - resolution: {integrity: sha512-RbzJvlNzmRq5c3O09UipeuXno4tA1FE6ikOjxZK0tuxVv3412l64l5t1W5pj4+rJq9vpkm/kwiR07aZXnsKPxw==} - engines: {node: '>= 6'} dev: true - /@tootallnate/once@2.0.0: + /@tootallnate/once/2.0.0: resolution: {integrity: sha512-XCuKFP5PS55gnMVu3dty8KPatLqUoy/ZYzDzAGCQ8JNFCkLXzmI7vNHCR+XpbZaMWQK/vQubr7PkYq8g470J/A==} engines: {node: '>= 10'} dev: true - /@tsconfig/node10@1.0.9: + /@tsconfig/node10/1.0.9: resolution: {integrity: sha512-jNsYVVxU8v5g43Erja32laIDHXeoNvFEpX33OK4d6hljo3jDhCBDhx5dhCCTMWUojscpAagGiRkBKxpdl9fxqA==} dev: true - /@tsconfig/node12@1.0.11: + /@tsconfig/node12/1.0.11: resolution: {integrity: sha512-cqefuRsh12pWyGsIoBKJA9luFu3mRxCA+ORZvA4ktLSzIuCUtWVxGIuXigEwO5/ywWFMZ2QEGKWvkZG1zDMTag==} dev: true - /@tsconfig/node14@1.0.3: + /@tsconfig/node14/1.0.3: resolution: {integrity: sha512-ysT8mhdixWK6Hw3i1V2AeRqZ5WfXg1G43mqoYlM2nc6388Fq5jcXyr5mRsqViLx/GJYdoL0bfXD8nmF+Zn/Iow==} dev: true - /@tsconfig/node16@1.0.3: - resolution: {integrity: sha512-yOlFc+7UtL/89t2ZhjPvvB/DeAr3r+Dq58IgzsFkOAvVC6NMJXmCGjbptdXdR9qsX7pKcTL+s87FtYREi2dEEQ==} + /@tsconfig/node16/1.0.4: + resolution: {integrity: sha512-vxhUy4J8lyeyinH7Azl1pdd43GJhZH/tP2weN8TntQblOY+A0XbT8DJk1/oCPuOOyg/Ja757rG0CgHcWC8OfMA==} dev: true - /@types/aria-query@4.2.2: - resolution: {integrity: sha512-HnYpAE1Y6kRyKM/XkEuiRQhTHvkzMBurTHnpFLYLBGPIylZNPs9jJcuOOYWxPLJCSEtmZT0Y8rHDokKN7rRTig==} - dev: true - - /@types/aria-query@5.0.1: + /@types/aria-query/5.0.1: resolution: {integrity: sha512-XTIieEY+gvJ39ChLcB4If5zHtPxt3Syj5rgZR+e1ctpmK8NjPf0zFqsz4JpLJT0xla9GFDKjy8Cpu331nrmE1Q==} dev: true - /@types/babel-types@7.0.11: + /@types/babel-types/7.0.11: resolution: {integrity: sha512-pkPtJUUY+Vwv6B1inAz55rQvivClHJxc9aVEPPmaq2cbyeMLCiDpbKpcKyX4LAwpNGi+SHBv0tHv6+0gXv0P2A==} dev: true - /@types/babel__core@7.20.0: - resolution: {integrity: sha512-+n8dL/9GWblDO0iU6eZAwEIJVr5DWigtle+Q6HLOrh/pdbXOhOtqzq8VPPE2zvNJzSKY4vH/z3iT3tn0A3ypiQ==} + /@types/babel__core/7.20.1: + resolution: {integrity: sha512-aACu/U/omhdk15O4Nfb+fHgH/z3QsfQzpnvRZhYhThms83ZnAOZz7zZAWO7mn2yyNQaA4xTO8GLK3uqFU4bYYw==} dependencies: - '@babel/parser': 7.22.5 + '@babel/parser': 7.22.7 '@babel/types': 7.22.5 '@types/babel__generator': 7.6.4 '@types/babel__template': 7.4.1 - '@types/babel__traverse': 7.18.3 + '@types/babel__traverse': 7.20.1 dev: true - /@types/babel__generator@7.6.4: + /@types/babel__generator/7.6.4: resolution: {integrity: sha512-tFkciB9j2K755yrTALxD44McOrk+gfpIpvC3sxHjRawj6PfnQxrse4Clq5y/Rq+G3mrBurMax/lG8Qn2t9mSsg==} dependencies: '@babel/types': 7.22.5 dev: true - /@types/babel__template@7.4.1: + /@types/babel__template/7.4.1: resolution: {integrity: sha512-azBFKemX6kMg5Io+/rdGT0dkGreboUVR0Cdm3fz9QJWpaQGJRQXl7C+6hOTCZcMll7KFyEQpgbYI2lHdsS4U7g==} dependencies: - '@babel/parser': 7.22.5 + '@babel/parser': 7.22.7 '@babel/types': 7.22.5 dev: true - /@types/babel__traverse@7.18.3: - resolution: {integrity: sha512-1kbcJ40lLB7MHsj39U4Sh1uTd2E7rLEa79kmDpI6cy+XiXsteB3POdQomoq4FxszMrO3ZYchkhYJw7A2862b3w==} + /@types/babel__traverse/7.20.1: + resolution: {integrity: sha512-MitHFXnhtgwsGZWtT68URpOvLN4EREih1u3QtQiN4VdAxWKRVvGCSvw/Qth0M0Qq3pJpnGOu5JaM/ydK7OGbqg==} dependencies: '@babel/types': 7.22.5 dev: true - /@types/braces@3.0.1: - resolution: {integrity: sha512-+euflG6ygo4bn0JHtn4pYqcXwRtLvElQ7/nnjDu7iYG56H0+OhCd7d6Ug0IE3WcFpZozBKW2+80FUbv5QGk5AQ==} + /@types/body-parser/1.19.2: + resolution: {integrity: sha512-ALYone6pm6QmwZoAgeyNksccT9Q4AWZQ6PvfwR37GT6r6FWUPguq6sUmNGSMV2Wr761oQoBxwGGa6DR5o1DC9g==} + dependencies: + '@types/connect': 3.4.35 + '@types/node': 20.4.1 + dev: true + + /@types/braces/3.0.2: + resolution: {integrity: sha512-U5tlMYa0U/2eFTmJgKcPWQOEICP173sJDa6OjHbj5Tv+NVaYcrq2xmdWpNXOwWYGwJu+jER/pfTLdoQ31q8PzA==} dev: true - /@types/chai-subset@1.3.3: + /@types/chai-subset/1.3.3: resolution: {integrity: sha512-frBecisrNGz+F4T6bcc+NLeolfiojh5FxW2klu669+8BARtyQv2C/GkNW6FUodVe4BroGMP/wER/YDGc7rEllw==} dependencies: '@types/chai': 4.3.5 dev: false - /@types/chai@4.3.5: + /@types/chai/4.3.5: resolution: {integrity: sha512-mEo1sAde+UCE6b2hxn332f1g1E8WfYRu6p5SvTKr2ZKC1f7gFJXk4h5PyGP9Dt6gCaG8y8XhwnXWC6Iy2cmBng==} dev: false - /@types/cheerio@0.22.31: + /@types/cheerio/0.22.31: resolution: {integrity: sha512-Kt7Cdjjdi2XWSfrZ53v4Of0wG3ZcmaegFXjMmz9tfNrZSkzzo36G0AL1YqSdcIA78Etjt6E609pt5h1xnQkPUw==} dependencies: '@types/node': 20.4.1 dev: true - /@types/codemirror@5.60.8: + /@types/codemirror/5.60.8: resolution: {integrity: sha512-VjFgDF/eB+Aklcy15TtOTLQeMjTo07k7KAjql8OK5Dirr7a6sJY4T1uVBDuTVG9VEmn1uUsohOpYnVfgC6/jyw==} dependencies: '@types/tern': 0.23.4 dev: true - /@types/cookie@0.4.1: + /@types/connect/3.4.35: + resolution: {integrity: sha512-cdeYyv4KWoEgpBISTxWvqYsVy444DOqehiF3fM3ne10AmJ62RSyNkUnxMJXHQWRQQX2eR94m5y1IZyDwBjV9FQ==} + dependencies: + '@types/node': 20.4.1 + dev: true + + /@types/cookie/0.4.1: resolution: {integrity: sha512-XW/Aa8APYr6jSVVA1y/DEIZX0/GMKLEVekNG727R8cs56ahETkRAy/3DR7+fJyh7oUgGwNQaRfXCun0+KbWY7Q==} dev: true - /@types/cookie@0.5.1: + /@types/cookie/0.5.1: resolution: {integrity: sha512-COUnqfB2+ckwXXSFInsFdOAWQzCCx+a5hq2ruyj+Vjund94RJQd4LG2u9hnvJrTgunKAaax7ancBYlDrNYxA0g==} dev: true - /@types/d3-force@3.0.4: + /@types/d3-array/3.0.5: + resolution: {integrity: sha512-Qk7fpJ6qFp+26VeQ47WY0mkwXaiq8+76RJcncDEfMc2ocRzXLO67bLFRNI4OX1aGBoPzsM5Y2T+/m1pldOgD+A==} + dev: false + + /@types/d3-color/3.1.0: + resolution: {integrity: sha512-HKuicPHJuvPgCD+np6Se9MQvS6OCbJmOjGvylzMJRlDwUXjKTTXs6Pwgk79O09Vj/ho3u1ofXnhFOaEWWPrlwA==} + dev: false + + /@types/d3-ease/3.0.0: + resolution: {integrity: sha512-aMo4eaAOijJjA6uU+GIeW018dvy9+oH5Y2VPPzjjfxevvGQ/oRDs+tfYC9b50Q4BygRR8yE2QCLsrT0WtAVseA==} + dev: false + + /@types/d3-force/3.0.4: resolution: {integrity: sha512-q7xbVLrWcXvSBBEoadowIUJ7sRpS1yvgMWnzHJggFy5cUZBq2HZL5k/pBSm0GdYWS1vs5/EDwMjSKF55PDY4Aw==} dev: true - /@types/d3-selection@3.0.5: + /@types/d3-interpolate/3.0.1: + resolution: {integrity: sha512-jx5leotSeac3jr0RePOH1KdR9rISG91QIE4Q2PYTu4OymLTZfA3SrnURSLzKH48HmXVUru50b8nje4E79oQSQw==} + dependencies: + '@types/d3-color': 3.1.0 + dev: false + + /@types/d3-path/3.0.0: + resolution: {integrity: sha512-0g/A+mZXgFkQxN3HniRDbXMN79K3CdTpLsevj+PXiTcb2hVyvkZUBg37StmgCQkaD84cUJ4uaDAWq7UJOQy2Tg==} + dev: false + + /@types/d3-scale/4.0.3: + resolution: {integrity: sha512-PATBiMCpvHJSMtZAMEhc2WyL+hnzarKzI6wAHYjhsonjWJYGq5BXTzQjv4l8m2jO183/4wZ90rKvSeT7o72xNQ==} + dependencies: + '@types/d3-time': 3.0.0 + dev: false + + /@types/d3-selection/3.0.5: resolution: {integrity: sha512-xCB0z3Hi8eFIqyja3vW8iV01+OHGYR2di/+e+AiOcXIOrY82lcvWW8Ke1DYE/EUVMsBl4Db9RppSBS3X1U6J0w==} dev: true - /@types/debug@4.1.8: + /@types/d3-shape/3.1.1: + resolution: {integrity: sha512-6Uh86YFF7LGg4PQkuO2oG6EMBRLuW9cbavUW46zkIO5kuS2PfTqo2o9SkgtQzguBHbLgNnU90UNsITpsX1My+A==} + dependencies: + '@types/d3-path': 3.0.0 + dev: false + + /@types/d3-time/3.0.0: + resolution: {integrity: sha512-sZLCdHvBUcNby1cB6Fd3ZBrABbjz3v1Vm90nysCQ6Vt7vd6e/h9Lt7SiJUoEX0l4Dzc7P5llKyhqSi1ycSf1Hg==} + dev: false + + /@types/d3-timer/3.0.0: + resolution: {integrity: sha512-HNB/9GHqu7Fo8AQiugyJbv6ZxYz58wef0esl4Mv828w1ZKpAshw/uFWVDUcIB9KKFeFKoxS3cHY07FFgtTRZ1g==} + dev: false + + /@types/debug/4.1.8: resolution: {integrity: sha512-/vPO1EPOs306Cvhwv7KfVfYvOJqA/S/AXjaHQiJboCZzcNDb+TIJFN9/2C9DZ//ijSKWioNyUxD792QmDJ+HKQ==} dependencies: '@types/ms': 0.7.31 dev: true - /@types/diff@5.0.3: + /@types/diff/5.0.3: resolution: {integrity: sha512-amrLbRqTU9bXMCc6uX0sWpxsQzRIo9z6MJPkH1pkez/qOxuqSZVuryJAWoBRq94CeG8JxY+VK4Le9HtjQR5T9A==} dev: true - /@types/enzyme@3.10.12: - resolution: {integrity: sha512-xryQlOEIe1TduDWAOphR0ihfebKFSWOXpIsk+70JskCfRfW+xALdnJ0r1ZOTo85F9Qsjk6vtlU7edTYHbls9tA==} + /@types/doctrine/0.0.5: + resolution: {integrity: sha512-JJwEeFy8Sl9ctiugU4h4DGN9hCB47oyhUkM2H8g8xZr4tHTEXtmV4U6krKrU8Ng0S7RlG/J7fkta1rGu3pq+YQ==} + dev: true + + /@types/enzyme/3.10.13: + resolution: {integrity: sha512-FCtoUhmFsud0Yx9fmZk179GkdZ4U9B0GFte64/Md+W/agx0L5SxsIIbhLBOxIb9y2UfBA4WQnaG1Od/UsUQs9Q==} dependencies: '@types/cheerio': 0.22.31 - '@types/react': 18.2.14 + '@types/react': 16.14.43 dev: true - /@types/eslint-scope@3.7.4: + /@types/eslint-scope/3.7.4: resolution: {integrity: sha512-9K4zoImiZc3HlIp6AVUDE4CWYx22a+lhSZMYNpbjW04+YF0KWj4pJXnEMjdnFTiQibFFmElcsasJXDbdI/EPhA==} dependencies: - '@types/eslint': 8.4.6 + '@types/eslint': 8.44.0 '@types/estree': 1.0.1 dev: true - /@types/eslint@8.4.6: - resolution: {integrity: sha512-/fqTbjxyFUaYNO7VcW5g+4npmqVACz1bB7RTHYuLj+PRjw9hrCwrUXVQFpChUS0JsyEFvMZ7U/PfmvWgxJhI9g==} + /@types/eslint/8.44.0: + resolution: {integrity: sha512-gsF+c/0XOguWgaOgvFs+xnnRqt9GwgTvIks36WpE6ueeI4KCEHHd8K/CKHqhOqrJKsYH8m27kRzQEvWXAwXUTw==} dependencies: '@types/estree': 1.0.1 - '@types/json-schema': 7.0.11 + '@types/json-schema': 7.0.12 dev: true - /@types/estree@0.0.39: + /@types/estree/0.0.39: resolution: {integrity: sha512-EYNwp3bU+98cpU4lAWYYL7Zz+2gryWH1qbdDTidVd6hkiR6weksdbMadyXKXNPEkQFhXM+hVO9ZygomHXp+AIw==} - /@types/estree@0.0.51: + /@types/estree/0.0.51: resolution: {integrity: sha512-CuPgU6f3eT/XgKKPqKd/gLZV1Xmvf1a2R5POBOGQa6uv82xpls89HU5zKeVoyR8XzHd1RGNOlQlvUe3CFkjWNQ==} dev: true - /@types/estree@1.0.1: + /@types/estree/1.0.1: resolution: {integrity: sha512-LG4opVs2ANWZ1TJoKc937iMmNstM/d0ae1vNbnBvBhqCSezgVUOzcLCqbI5elV8Vy6WKwKjaqR+zO9VKirBBCA==} - /@types/fs-extra@11.0.1: + /@types/express-serve-static-core/4.17.35: + resolution: {integrity: sha512-wALWQwrgiB2AWTT91CB62b6Yt0sNHpznUXeZEcnPU3DRdlDIz74x8Qg1UUYKSVFi+va5vKOLYRBI1bRKiLLKIg==} + dependencies: + '@types/node': 20.4.1 + '@types/qs': 6.9.7 + '@types/range-parser': 1.2.4 + '@types/send': 0.17.1 + dev: true + + /@types/express/4.17.17: + resolution: {integrity: sha512-Q4FmmuLGBG58btUnfS1c1r/NQdlp3DMfGDGig8WhfpA2YRUtEkxAjkZb0yvplJGYdF1fsQ81iMDcH24sSCNC/Q==} + dependencies: + '@types/body-parser': 1.19.2 + '@types/express-serve-static-core': 4.17.35 + '@types/qs': 6.9.7 + '@types/serve-static': 1.15.2 + dev: true + + /@types/fs-extra/11.0.1: resolution: {integrity: sha512-MxObHvNl4A69ofaTRU8DFqvgzzv8s9yRtaPPm5gud9HDNvpB3GPQFvNuTWAI59B9huVGV5jXYJwbCsmBsOGYWA==} dependencies: '@types/jsonfile': 6.1.1 - '@types/node': 20.4.1 + '@types/node': 18.16.19 dev: true - /@types/fs-extra@9.0.13: + /@types/fs-extra/9.0.13: resolution: {integrity: sha512-nEnwB++1u5lVDM2UI4c1+5R+FYaKfaAzS4OococimjVm3nQw3TuzH5UNsocrcTBbhnerblyHj4A49qXbIiZdpA==} dependencies: '@types/node': 20.4.1 dev: true - /@types/glob@7.2.0: + /@types/glob/7.2.0: resolution: {integrity: sha512-ZUxbzKl0IfJILTS6t7ip5fQQM/J3TJYubDm3nMbgubNNYS62eXeUpoLUC8/7fJNiFYHTrGPQn7hspDUzIHX3UA==} dependencies: - '@types/minimatch': 5.1.1 + '@types/minimatch': 5.1.2 '@types/node': 20.4.1 dev: true - /@types/glob@8.0.0: - resolution: {integrity: sha512-l6NQsDDyQUVeoTynNpC9uRvCUint/gSUXQA2euwmTuWGvPY5LSDUu6tkCtJB2SvGQlJQzLaKqcGZP4//7EDveA==} + /@types/glob/8.1.0: + resolution: {integrity: sha512-IO+MJPVhoqz+28h1qLAcBEH2+xHMK6MTyHJc7MTnnYb6wsoLR29POVGJ7LycmVXIqyy/4/2ShP5sUwTXuOwb/w==} dependencies: - '@types/minimatch': 5.1.1 - '@types/node': 20.4.1 + '@types/minimatch': 5.1.2 + '@types/node': 16.18.38 dev: true - /@types/graceful-fs@4.1.5: - resolution: {integrity: sha512-anKkLmZZ+xm4p8JWBf4hElkM4XR+EZeA2M9BAkkTldmcyDY4mbdIJnRghDJH3Ov5ooY7/UAoENtmdMSkaAd7Cw==} + /@types/graceful-fs/4.1.6: + resolution: {integrity: sha512-Sig0SNORX9fdW+bQuTEovKj3uHcUL6LQKbCrrqb1X7J6/ReAbhCXRAhc+SMejhLELFj2QcyuxmUooZ4bt5ReSw==} dependencies: '@types/node': 20.4.1 dev: true - /@types/hast@2.3.4: - resolution: {integrity: sha512-wLEm0QvaoawEDoTRwzTXp4b4jpwiJDvR5KMnFnVodm3scufTlBOWRD6N1OBf9TZMhjlNsSfcO5V+7AF4+Vy+9g==} + /@types/hast/2.3.5: + resolution: {integrity: sha512-SvQi0L/lNpThgPoleH53cdjB3y9zpLlVjRbqB3rH8hx1jiRSBGAhyjV3H+URFjNVRqt2EdYNrbZE5IsGlNfpRg==} dependencies: - '@types/unist': 2.0.6 + '@types/unist': 2.0.7 dev: true - /@types/html-minifier-terser@5.1.2: + /@types/html-minifier-terser/5.1.2: resolution: {integrity: sha512-h4lTMgMJctJybDp8CQrxTUiiYmedihHWkjnF/8Pxseu2S6Nlfcy8kwboQ8yejh456rP2yWoEVm1sS/FVsfM48w==} dev: true - /@types/http-cache-semantics@4.0.1: + /@types/http-cache-semantics/4.0.1: resolution: {integrity: sha512-SZs7ekbP8CN0txVG2xVRH6EgKmEm31BOxA07vkFaETzZz1xh+cbt8BcI0slpymvwhx5dlFnQG2rTlPVQn+iRPQ==} dev: true - /@types/inquirer@9.0.3: + /@types/http-errors/2.0.1: + resolution: {integrity: sha512-/K3ds8TRAfBvi5vfjuz8y6+GiAYBZ0x4tXv1Av6CWBWn0IlADc+ZX9pMq7oU0fNQPnBwIZl3rmeLp6SBApbxSQ==} + dev: true + + /@types/inquirer/9.0.3: resolution: {integrity: sha512-CzNkWqQftcmk2jaCWdBTf9Sm7xSw4rkI1zpU/Udw3HX5//adEZUIm9STtoRP1qgWj0CWQtJ9UTvqmO2NNjhMJw==} dependencies: '@types/through': 0.0.30 rxjs: 7.8.1 dev: true - /@types/is-function@1.0.1: + /@types/is-function/1.0.1: resolution: {integrity: sha512-A79HEEiwXTFtfY+Bcbo58M2GRYzCr9itHWzbzHVFNEYCcoU/MMGwYYf721gBrnhpj1s6RGVVha/IgNFnR0Iw/Q==} dev: true - /@types/istanbul-lib-coverage@2.0.4: + /@types/istanbul-lib-coverage/2.0.4: resolution: {integrity: sha512-z/QT1XN4K4KYuslS23k62yDIDLwLFkzxOuMplDtObz0+y7VqJCaO2o+SPwHCvLFZh7xazvvoor2tA/hPz9ee7g==} - /@types/istanbul-lib-instrument@1.7.4: + /@types/istanbul-lib-instrument/1.7.4: resolution: {integrity: sha512-1i1VVkU2KrpZCmti+t5J/zBb2KLKxHgU1EYL+0QtnDnVyZ59aSKcpnG6J0I6BZGDON566YzPNIlNfk7m+9l1JA==} dependencies: '@types/babel-types': 7.0.11 @@ -8758,37 +7042,37 @@ packages: source-map: 0.6.1 dev: true - /@types/istanbul-lib-report@3.0.0: + /@types/istanbul-lib-report/3.0.0: resolution: {integrity: sha512-plGgXAPfVKFoYfa9NpYDAkseG+g6Jr294RqeqcqDixSbU34MZVJRi/P+7Y8GDpzkEwLaGZZOpKIEmeVZNtKsrg==} dependencies: '@types/istanbul-lib-coverage': 2.0.4 dev: true - /@types/istanbul-lib-source-maps@4.0.1: + /@types/istanbul-lib-source-maps/4.0.1: resolution: {integrity: sha512-WH6e5naLXI3vB2Px3whNeYxzDgm6S6sk3Ht8e3/BiWwEnzZi72wja3bWzWwcgbFTFp8hBLB7NT2p3lNJgxCxvA==} dependencies: '@types/istanbul-lib-coverage': 2.0.4 source-map: 0.6.1 dev: true - /@types/istanbul-reports@3.0.1: + /@types/istanbul-reports/3.0.1: resolution: {integrity: sha512-c3mAZEuK0lvBp8tmuL74XRKn1+y2dcwOUpH7x4WrF6gk1GIgiluDRgMYQtw2OFcBvAJWlt6ASU3tSqxp0Uu0Aw==} dependencies: '@types/istanbul-lib-report': 3.0.0 dev: true - /@types/jest@29.0.0: - resolution: {integrity: sha512-X6Zjz3WO4cT39Gkl0lZ2baFRaEMqJl5NC1OjElkwtNzAlbkr2K/WJXkBkH5VP0zx4Hgsd2TZYdOEfvp2Dxia+Q==} + /@types/jest/29.5.3: + resolution: {integrity: sha512-1Nq7YrO/vJE/FYnqYyw0FS8LdrjExSgIiHyKg7xPpn+yi8Q4huZryKnkJatN1ZRH89Kw2v33/8ZMB7DuZeSLlA==} dependencies: - expect: 29.0.1 - pretty-format: 29.5.0 + expect: 29.6.1 + pretty-format: 29.6.1 dev: true - /@types/js-levenshtein@1.1.1: + /@types/js-levenshtein/1.1.1: resolution: {integrity: sha512-qC4bCqYGy1y/NP7dDVr7KJarn+PbX1nSpwA7JXdu0HxT3QYjO8MJ+cntENtHFVy2dRAyBV23OZ6MxsW1AM1L8g==} dev: true - /@types/jsdom@21.1.1: + /@types/jsdom/21.1.1: resolution: {integrity: sha512-cZFuoVLtzKP3gmq9eNosUL1R50U+USkbLtUQ1bYVgl/lKp0FZM7Cq4aIHAL8oIvQ17uSHi7jXPtfDOdjPwBE7A==} dependencies: '@types/node': 20.4.1 @@ -8796,319 +7080,330 @@ packages: parse5: 7.1.2 dev: true - /@types/json-schema@7.0.11: - resolution: {integrity: sha512-wOuvG1SN4Us4rez+tylwwwCV1psiNVOkJeM3AUWUNWg/jDQY2+HE/444y5gc+jBmRqASOm2Oeh5c1axHobwRKQ==} + /@types/json-schema/7.0.12: + resolution: {integrity: sha512-Hr5Jfhc9eYOQNPYO5WLDq/n4jqijdHNlDXjuAQkkt+mWdQR+XJToOHrsD4cPaMXpn6KO7y2+wM8AZEs8VpBLVA==} dev: true - /@types/jsonfile@6.1.1: + /@types/jsonfile/6.1.1: resolution: {integrity: sha512-GSgiRCVeapDN+3pqA35IkQwasaCh/0YFH5dEF6S88iDvEn901DjOeH3/QPY+XYP1DFzDZPvIvfeEgk+7br5png==} dependencies: - '@types/node': 20.4.1 + '@types/node': 18.16.19 dev: true - /@types/lodash@4.14.195: + /@types/lodash/4.14.195: resolution: {integrity: sha512-Hwx9EUgdwf2GLarOjQp5ZH8ZmblzcbTBC2wtQWNKARBSxM9ezRIAUpeDTgoQRAFB0+8CNWXVA9+MaSOzOF3nPg==} dev: true - /@types/mdast@3.0.10: - resolution: {integrity: sha512-W864tg/Osz1+9f4lrGTZpCSO5/z4608eUp19tbozkq2HJK6i3z1kT0H9tlADXuYIb1YYOBByU4Jsqkk75q48qA==} + /@types/mdast/3.0.12: + resolution: {integrity: sha512-DT+iNIRNX884cx0/Q1ja7NyUPpZuv0KPyL5rGNxm1WC1OtHstl7n4Jb7nk+xacNShQMbczJjt8uFzznpp6kYBg==} dependencies: - '@types/unist': 2.0.6 + '@types/unist': 2.0.7 dev: true - /@types/micromatch@4.0.2: + /@types/micromatch/4.0.2: resolution: {integrity: sha512-oqXqVb0ci19GtH0vOA/U2TmHTcRY9kuZl4mqUxe0QmJAlIW13kzhuK5pi1i9+ngav8FjpSb9FVS/GE00GLX1VA==} dependencies: - '@types/braces': 3.0.1 + '@types/braces': 3.0.2 + dev: true + + /@types/mime/1.3.2: + resolution: {integrity: sha512-YATxVxgRqNH6nHEIsvg6k2Boc1JHI9ZbH5iWFFv/MTkchz3b1ieGDa5T0a9RznNdI0KhVbdbWSN+KWWrQZRxTw==} dev: true - /@types/minimatch@5.1.1: - resolution: {integrity: sha512-v55NF6Dz0wrj14Rn8iEABTWrhYRmgkJYuokduunSiq++t3hZ9VZ6dvcDt+850Pm5sGJZk8RaHzkFCXPxVINZ+g==} + /@types/mime/3.0.1: + resolution: {integrity: sha512-Y4XFY5VJAuw0FgAqPNd6NNoV44jbq9Bz2L7Rh/J6jLTiHBSBJa9fxqQIvkIld4GsoDOcCbvzOUAbLPsSKKg+uA==} dev: true - /@types/ms@0.7.31: + /@types/minimatch/5.1.2: + resolution: {integrity: sha512-K0VQKziLUWkVKiRVrx4a40iPaxTUefQmjtkQofBkYRcoaaL/8rhwDWww9qWbrgicNOgnpIsMxyNIUM4+n6dUIA==} + dev: true + + /@types/ms/0.7.31: resolution: {integrity: sha512-iiUgKzV9AuaEkZqkOLDIvlQiL6ltuZd9tGcW3gwpnX8JbuiuhFlEGmmFXEXkN50Cvq7Os88IY2v0dkDqXYWVgA==} dev: true - /@types/natural-compare@1.4.1: + /@types/natural-compare/1.4.1: resolution: {integrity: sha512-9dr4UakpvN0QUvwNefk9+o14Sr1pPPIDWkgCxPkHcg3kyjtc9eKK1ng6dZ23vRwByloCqXYtZ1T5nJxkk3Ib3A==} dev: true - /@types/node-fetch@2.6.2: - resolution: {integrity: sha512-DHqhlq5jeESLy19TYhLakJ07kNumXWjcDdxXsLUMJZ6ue8VZJj4kLPQVE/2mdHh3xZziNF1xppu5lwmS53HR+A==} + /@types/node-fetch/2.6.4: + resolution: {integrity: sha512-1ZX9fcN4Rvkvgv4E6PAY5WXUFWFcRWxZa3EW83UjycOB9ljJCedb2CupIP4RZMEwF/M3eTcCihbBRgwtGbg5Rg==} dependencies: - '@types/node': 20.4.1 + '@types/node': 16.18.38 form-data: 3.0.1 dev: true - /@types/node@14.18.26: - resolution: {integrity: sha512-0b+utRBSYj8L7XAp0d+DX7lI4cSmowNaaTkk6/1SKzbKkG+doLuPusB9EOvzLJ8ahJSk03bTLIL6cWaEd4dBKA==} + /@types/node/14.18.53: + resolution: {integrity: sha512-soGmOpVBUq+gaBMwom1M+krC/NNbWlosh4AtGA03SyWNDiqSKtwp7OulO1M6+mg8YkHMvJ/y0AkCeO8d1hNb7A==} dev: true - /@types/node@16.11.56: - resolution: {integrity: sha512-aFcUkv7EddxxOa/9f74DINReQ/celqH8DiB3fRYgVDM2Xm5QJL8sl80QKuAnGvwAsMn+H3IFA6WCrQh1CY7m1A==} + /@types/node/16.18.38: + resolution: {integrity: sha512-6sfo1qTulpVbkxECP+AVrHV9OoJqhzCsfTNp5NIG+enM4HyM3HvZCO798WShIXBN0+QtDIcutJCjsVYnQP5rIQ==} dev: true - /@types/node@18.16.19: + /@types/node/18.16.19: resolution: {integrity: sha512-IXl7o+R9iti9eBW4Wg2hx1xQDig183jj7YLn8F7udNceyfkbn1ZxmzZXuak20gR40D7pIkIY1kYGx5VIGbaHKA==} + dev: true - /@types/node@18.7.13: - resolution: {integrity: sha512-46yIhxSe5xEaJZXWdIBP7GU4HDTG8/eo0qd9atdiL+lFpA03y8KS+lkTN834TWJj5767GbWv4n/P6efyTFt1Dw==} - dev: false - - /@types/node@20.4.1: + /@types/node/20.4.1: resolution: {integrity: sha512-JIzsAvJeA/5iY6Y/OxZbv1lUcc8dNSE77lb2gnBH+/PJ3lFR1Ccvgwl5JWnHAkNHcRsT0TbpVOsiMKZ1F/yyJg==} - dev: true - /@types/normalize-package-data@2.4.1: + /@types/normalize-package-data/2.4.1: resolution: {integrity: sha512-Gj7cI7z+98M282Tqmp2K5EIsoouUEzbBJhQQzDE3jSIRk6r9gsz0oUokqIUR4u1R3dMHo0pDHM7sNOHyhulypw==} dev: true - /@types/npmlog@4.1.4: + /@types/npmlog/4.1.4: resolution: {integrity: sha512-WKG4gTr8przEZBiJ5r3s8ZIAoMXNbOgQ+j/d5O4X3x6kZJRLNvyUJuUK/KoG3+8BaOHPhp2m7WC6JKKeovDSzQ==} dev: true - /@types/parse-json@4.0.0: + /@types/parse-json/4.0.0: resolution: {integrity: sha512-//oorEZjL6sbPcKUaCdIGlIUeH26mgzimjBB77G6XRgnDl/L5wOnpyBGRe/Mmf5CVW3PwEBE1NjiMZ/ssFh4wA==} - /@types/parse5@5.0.3: + /@types/parse5/5.0.3: resolution: {integrity: sha512-kUNnecmtkunAoQ3CnjmMkzNU/gtxG8guhi+Fk2U/kOpIKjIMKnXGp4IJCgQJrXSgMsWYimYG4TGjz/UzbGEBTw==} dev: true - /@types/prettier@2.7.0: - resolution: {integrity: sha512-RI1L7N4JnW5gQw2spvL7Sllfuf1SaHdrZpCHiBlCXjIlufi1SMNnbu2teze3/QE67Fg2tBlH7W+mi4hVNk4p0A==} + /@types/prettier/2.7.3: + resolution: {integrity: sha512-+68kP9yzs4LMp7VNh8gdzMSPZFL44MLGqiHWvttYJe+6qnuVr4Ek9wSBQoveqY/r+LwjCcU29kNVkidwim+kYA==} dev: true - /@types/pretty-hrtime@1.0.1: + /@types/pretty-hrtime/1.0.1: resolution: {integrity: sha512-VjID5MJb1eGKthz2qUerWT8+R4b9N+CHvGCzg9fn4kWZgaF9AhdYikQio3R7wV8YY1NsQKPaCwKz1Yff+aHNUQ==} dev: true - /@types/prompts@2.4.4: + /@types/prompts/2.4.4: resolution: {integrity: sha512-p5N9uoTH76lLvSAaYSZtBCdEXzpOOufsRjnhjVSrZGXikVGHX9+cc9ERtHRV4hvBKHyZb1bg4K+56Bd2TqUn4A==} dependencies: '@types/node': 20.4.1 kleur: 3.0.3 dev: true - /@types/prop-types@15.7.5: + /@types/prop-types/15.7.5: resolution: {integrity: sha512-JCB8C6SnDoQf0cNycqd/35A7MjcnK+ZTqE7judS6o7utxUCg6imJg3QK2qzHKszlTjcj2cn+NwMB2i96ubpj7w==} - /@types/pug@2.0.6: + /@types/pug/2.0.6: resolution: {integrity: sha512-SnHmG9wN1UVmagJOnyo/qkk0Z7gejYxOYYmaAwr5u2yFYfsupN3sg10kyzN8Hep/2zbHxCnsumxOoRIRMBwKCg==} dev: true - /@types/qs@6.9.7: + /@types/qs/6.9.7: resolution: {integrity: sha512-FGa1F62FT09qcrueBA6qYTrJPVDzah9a+493+o2PCXsesWHIn27G98TsSMs3WPNbZIEj4+VJf6saSFpvD+3Zsw==} dev: true - /@types/react-dom@17.0.17: - resolution: {integrity: sha512-VjnqEmqGnasQKV0CWLevqMTXBYG9GbwuE6x3VetERLh0cq2LTptFE73MrQi2S7GkKXCf2GgwItB/melLnxfnsg==} - dependencies: - '@types/react': 17.0.49 + /@types/range-parser/1.2.4: + resolution: {integrity: sha512-EEhsLsD6UsDM1yFhAvy0Cjr6VwmpMWqFBCb9w07wVugF7w9nfajxLuVmngTIpgS6svCnm6Vaw+MZhoDCKnOfsw==} dev: true - /@types/react-dom@18.0.6: - resolution: {integrity: sha512-/5OFZgfIPSwy+YuIBP/FgJnQnsxhZhjjrnxudMddeblOouIodEQ75X14Rr4wGSG/bknL+Omy9iWlLo1u/9GzAA==} + /@types/react-dom/17.0.20: + resolution: {integrity: sha512-4pzIjSxDueZZ90F52mU3aPoogkHIoSIDG+oQ+wQK7Cy2B9S+MvOqY0uEA/qawKz381qrEDkvpwyt8Bm31I8sbA==} dependencies: - '@types/react': 18.2.14 + '@types/react': 17.0.62 dev: true - /@types/react-dom@18.0.8: - resolution: {integrity: sha512-C3GYO0HLaOkk9dDAz3Dl4sbe4AKUGTCfFIZsz3n/82dPNN8Du533HzKatDxeUYWu24wJgMP1xICqkWk1YOLOIw==} + /@types/react-dom/18.2.6: + resolution: {integrity: sha512-2et4PDvg6PVCyS7fuTc4gPoksV58bW0RwSxWKcPRcHZf0PRUGq03TKcD/rUHe3azfV6/5/biUBJw+HhCQjaP0A==} dependencies: '@types/react': 18.2.14 dev: true - /@types/react-is@17.0.3: - resolution: {integrity: sha512-aBTIWg1emtu95bLTLx0cpkxwGW3ueZv71nE2YFBpL8k/z5czEW8yYpOo8Dp+UUAFAtKwNaOsh/ioSeQnWlZcfw==} + /@types/react-is/18.2.1: + resolution: {integrity: sha512-wyUkmaaSZEzFZivD8F2ftSyAfk6L+DfFliVj/mYdOXbVjRcS87fQJLTnhk6dRZPuJjI+9g6RZJO4PNCngUrmyw==} dependencies: '@types/react': 18.2.14 dev: false - /@types/react-test-renderer@17.0.2: + /@types/react-test-renderer/17.0.2: resolution: {integrity: sha512-+F1KONQTBHDBBhbHuT2GNydeMpPuviduXIVJRB7Y4nma4NR5DrTJfMMZ+jbhEHbpwL+Uqhs1WXh4KHiyrtYTPg==} dependencies: - '@types/react': 17.0.49 + '@types/react': 17.0.62 dev: true - /@types/react-transition-group@4.4.5: - resolution: {integrity: sha512-juKD/eiSM3/xZYzjuzH6ZwpP+/lejltmiS3QEzV/vmb/Q8+HfDmxu+Baga8UEMGBqV88Nbg4l2hY/K2DkyaLLA==} + /@types/react-transition-group/4.4.6: + resolution: {integrity: sha512-VnCdSxfcm08KjsJVQcfBmhEQAPnLB8G08hAxn39azX1qYBQ/5RVQuoHuKIcfKOdncuaUvEpFKFzEvbtIMsfVew==} dependencies: '@types/react': 18.2.14 dev: false - /@types/react@17.0.49: - resolution: {integrity: sha512-CCBPMZaPhcKkYUTqFs/hOWqKjPxhTEmnZWjlHHgIMop67DsXywf9B5Os9Hz8KSacjNOgIdnZVJamwl232uxoPg==} + /@types/react/16.14.43: + resolution: {integrity: sha512-7zdjv7jvoLLQg1tTvpQsm+hyNUMT2mPlNV1+d0I8fbGhkJl82spopMyBlu4wb1dviZAxpGdk5eHu/muacknnfw==} dependencies: '@types/prop-types': 15.7.5 - '@types/scheduler': 0.16.2 - csstype: 3.1.0 + '@types/scheduler': 0.16.3 + csstype: 3.1.2 dev: true - /@types/react@18.0.25: - resolution: {integrity: sha512-xD6c0KDT4m7n9uD4ZHi02lzskaiqcBxf4zi+tXZY98a04wvc0hi/TcCPC2FOESZi51Nd7tlUeOJY8RofL799/g==} + /@types/react/17.0.62: + resolution: {integrity: sha512-eANCyz9DG8p/Vdhr0ZKST8JV12PhH2ACCDYlFw6DIO+D+ca+uP4jtEDEpVqXZrh/uZdXQGwk7whJa3ah5DtyLw==} dependencies: '@types/prop-types': 15.7.5 - '@types/scheduler': 0.16.2 - csstype: 3.1.0 + '@types/scheduler': 0.16.3 + csstype: 3.1.2 dev: true - /@types/react@18.2.14: + /@types/react/18.2.14: resolution: {integrity: sha512-A0zjq+QN/O0Kpe30hA1GidzyFjatVvrpIvWLxD+xv67Vt91TWWgco9IvrJBkeyHm1trGaFS/FSGqPlhyeZRm0g==} dependencies: '@types/prop-types': 15.7.5 - '@types/scheduler': 0.16.2 + '@types/scheduler': 0.16.3 csstype: 3.1.2 - /@types/resolve@1.17.1: + /@types/resolve/1.17.1: resolution: {integrity: sha512-yy7HuzQhj0dhGpD8RLXSZWEkLsV9ibvxvi6EiJ3bkqLAO1RGo0WbkWQiwpRlSFymTJRz0d3k5LM3kkx8ArDbLw==} dependencies: '@types/node': 20.4.1 dev: true - /@types/resolve@1.20.2: + /@types/resolve/1.20.2: resolution: {integrity: sha512-60BCwRFOZCQhDncwQdxxeOEEkbc5dIMccYLwbxsS4TUNeVECQ/pBJ0j09mrHOl/JJvpRPGwO9SvE4nR2Nb/a4Q==} dev: true - /@types/scheduler@0.16.2: - resolution: {integrity: sha512-hppQEBDmlwhFAXKJX2KnWLYu5yMfi91yazPb2l+lbJiwW+wdo1gNeRA+3RgNSO39WYX2euey41KEwnqesU2Jew==} + /@types/scheduler/0.16.3: + resolution: {integrity: sha512-5cJ8CB4yAx7BH1oMvdU0Jh9lrEXyPkar6F9G/ERswkCuvP4KQZfZkSjcMbAICCpQTN4OuZn8tz0HiKv9TGZgrQ==} + + /@types/semver/7.5.0: + resolution: {integrity: sha512-G8hZ6XJiHnuhQKR7ZmysCeJWE08o8T0AXtk5darsCaTVsYZhhgUrq53jizaR2FvsoeCwJhlmwTjkXBY5Pn/ZHw==} + dev: true + + /@types/send/0.17.1: + resolution: {integrity: sha512-Cwo8LE/0rnvX7kIIa3QHCkcuF21c05Ayb0ZfxPiv0W8VRiZiNW/WuRupHKpqqGVGf7SUA44QSOUKaEd9lIrd/Q==} + dependencies: + '@types/mime': 1.3.2 + '@types/node': 20.4.1 + dev: true - /@types/semver@7.3.13: - resolution: {integrity: sha512-21cFJr9z3g5dW8B0CVI9g2O9beqaThGQ6ZFBqHfwhzLDKUxaqTIy3vnfah/UPkfOiF2pLq+tGz+W8RyCskuslw==} + /@types/serve-static/1.15.2: + resolution: {integrity: sha512-J2LqtvFYCzaj8pVYKw8klQXrLLk7TBZmQ4ShlcdkELFKGwGMfevMLneMMRkMgZxotOD9wg497LpC7O8PcvAmfw==} + dependencies: + '@types/http-errors': 2.0.1 + '@types/mime': 3.0.1 + '@types/node': 20.4.1 dev: true - /@types/set-cookie-parser@2.4.2: + /@types/set-cookie-parser/2.4.2: resolution: {integrity: sha512-fBZgytwhYAUkj/jC/FAV4RQ5EerRup1YQsXQCh8rZfiHkc4UahC192oH0smGwsXol3cL3A5oETuAHeQHmhXM4w==} dependencies: '@types/node': 20.4.1 dev: true - /@types/sinonjs__fake-timers@8.1.1: + /@types/sinonjs__fake-timers/8.1.1: resolution: {integrity: sha512-0kSuKjAS0TrGLJ0M/+8MaFkGsQhZpB6pxOmvS3K8FYI72K//YmdfoW9X2qPsAKh1mkwxGD5zib9s1FIFed6E8g==} dev: true - /@types/sinonjs__fake-timers@8.1.2: + /@types/sinonjs__fake-timers/8.1.2: resolution: {integrity: sha512-9GcLXF0/v3t80caGs5p2rRfkB+a8VBGLJZVih6CNFkx8IZ994wiKKLSRs9nuFwk1HevWs/1mnUmkApGrSGsShA==} dev: true - /@types/sizzle@2.3.3: + /@types/sizzle/2.3.3: resolution: {integrity: sha512-JYM8x9EGF163bEyhdJBpR2QX1R5naCJHC8ucJylJ3w9/CVBaskdQ8WqBf8MmQrd1kRvp/a4TS8HJ+bxzR7ZJYQ==} dev: true - /@types/source-list-map@0.1.2: + /@types/source-list-map/0.1.2: resolution: {integrity: sha512-K5K+yml8LTo9bWJI/rECfIPrGgxdpeNbj+d53lwN4QjW1MCwlkhUms+gtdzigTeUyBr09+u8BwOIY3MXvHdcsA==} dev: true - /@types/stack-utils@2.0.1: + /@types/stack-utils/2.0.1: resolution: {integrity: sha512-Hl219/BT5fLAaz6NDkSuhzasy49dwQS/DSdu4MdggFB8zcXv7vflBI3xp7FEmkmdDkBUI2bPUNeMttp2knYdxw==} dev: true - /@types/tapable@1.0.8: + /@types/tapable/1.0.8: resolution: {integrity: sha512-ipixuVrh2OdNmauvtT51o3d8z12p6LtFW9in7U79der/kwejjdNchQC5UMn5u/KxNoM7VHHOs/l8KS8uHxhODQ==} dev: true - /@types/tern@0.23.4: + /@types/tern/0.23.4: resolution: {integrity: sha512-JAUw1iXGO1qaWwEOzxTKJZ/5JxVeON9kvGZ/osgZaJImBnyjyn0cjovPsf6FNLmyGY8Vw9DoXZCMlfMkMwHRWg==} dependencies: '@types/estree': 1.0.1 dev: true - /@types/testing-library__jest-dom@5.14.5: - resolution: {integrity: sha512-SBwbxYoyPIvxHbeHxTZX2Pe/74F/tX2/D3mMvzabdeJ25bBojfW0TyB8BHrbq/9zaaKICJZjLP+8r6AeZMFCuQ==} + /@types/testing-library__jest-dom/5.14.8: + resolution: {integrity: sha512-NRfJE9Cgpmu4fx716q9SYmU4jxxhYRU1BQo239Txt/9N3EC745XZX1Yl7h/SBIDlo1ANVOCRB4YDXjaQdoKCHQ==} dependencies: - '@types/jest': 29.0.0 + '@types/jest': 29.5.3 dev: true - /@types/through@0.0.30: + /@types/through/0.0.30: resolution: {integrity: sha512-FvnCJljyxhPM3gkRgWmxmDZyAQSiBQQWLI0A0VFL0K7W1oRUrPJSqNO0NvTnLkBcotdlp3lKvaT0JrnyRDkzOg==} dependencies: '@types/node': 20.4.1 dev: true - /@types/tough-cookie@4.0.2: + /@types/tough-cookie/4.0.2: resolution: {integrity: sha512-Q5vtl1W5ue16D+nIaW8JWebSSraJVlK+EthKn7e7UcD4KWsaSJ8BqGPXNaPghgtcn/fhvrN17Tv8ksUsQpiplw==} dev: true - /@types/trusted-types@2.0.2: - resolution: {integrity: sha512-F5DIZ36YVLE+PN+Zwws4kJogq47hNgX3Nx6WyDJ3kcplxyke3XIzB8uK5n/Lpm1HBsbGzd6nmGehL8cPekP+Tg==} + /@types/trusted-types/2.0.3: + resolution: {integrity: sha512-NfQ4gyz38SL8sDNrSixxU2Os1a5xcdFxipAFxYEuLUlvU2uDwS4NUpsImcf1//SlWItCVMMLiylsxbmNMToV/g==} - /@types/uglify-js@3.17.0: - resolution: {integrity: sha512-3HO6rm0y+/cqvOyA8xcYLweF0TKXlAxmQASjbOi49Co51A1N4nR4bEwBgRoD9kNM+rqFGArjKr654SLp2CoGmQ==} + /@types/uglify-js/3.17.1: + resolution: {integrity: sha512-GkewRA4i5oXacU/n4MA9+bLgt5/L3F1mKrYvFGm7r2ouLXhRKjuWwo9XHNnbx6WF3vlGW21S3fCvgqxvxXXc5g==} dependencies: source-map: 0.6.1 dev: true - /@types/ungap__structured-clone@0.3.0: + /@types/ungap__structured-clone/0.3.0: resolution: {integrity: sha512-eBWREUhVUGPze+bUW22AgUr05k8u+vETzuYdLYSvWqGTUe0KOf+zVnOB1qER5wMcw8V6D9Ar4DfJmVvD1yu0kQ==} dev: true - /@types/unist@2.0.6: - resolution: {integrity: sha512-PBjIUxZHOuj0R15/xuwJYjFi+KZdNFrehocChv4g5hu6aFroHue8m0lBP0POdK2nKzbw0cgV1mws8+V/JAcEkQ==} + /@types/unist/2.0.7: + resolution: {integrity: sha512-cputDpIbFgLUaGQn6Vqg3/YsJwxUwHLO13v3i5ouxT4lat0khip9AEWxtERujXV9wxIB1EyF97BSJFt6vpdI8g==} dev: true - /@types/web-bluetooth@0.0.14: + /@types/web-bluetooth/0.0.14: resolution: {integrity: sha512-5d2RhCard1nQUC3aHcq/gHzWYO6K0WJmAbjO7mQJgCQKtZpgXxv1rOM6O/dBDhDYYVutk1sciOgNSe+5YyfM8A==} dev: false - /@types/web-bluetooth@0.0.17: + /@types/web-bluetooth/0.0.17: resolution: {integrity: sha512-4p9vcSmxAayx72yn70joFoL44c9MO/0+iVEBIQXe3v2h2SiAsEIo/G5v6ObFWvNKRFjbrVadNf9LqEEZeQPzdA==} - /@types/webpack-env@1.18.0: - resolution: {integrity: sha512-56/MAlX5WMsPVbOg7tAxnYvNYMMWr/QJiIp6BxVSW3JJXUVzzOn64qW8TzQyMSqSUFM2+PVI4aUHcHOzIz/1tg==} + /@types/webpack-env/1.18.1: + resolution: {integrity: sha512-D0HJET2/UY6k9L6y3f5BL+IDxZmPkYmPT4+qBrRdmRLYRuV0qNKizMgTvYxXZYn+36zjPeoDZAEYBCM6XB+gww==} dev: true - /@types/webpack-sources@3.2.0: + /@types/webpack-sources/3.2.0: resolution: {integrity: sha512-Ft7YH3lEVRQ6ls8k4Ff1oB4jN6oy/XmU6tQISKdhfh+1mR+viZFphS6WL0IrtDOzvefmJg5a0s7ZQoRXwqTEFg==} dependencies: - '@types/node': 20.4.1 + '@types/node': 16.18.38 '@types/source-list-map': 0.1.2 source-map: 0.7.4 dev: true - /@types/webpack@4.41.32: - resolution: {integrity: sha512-cb+0ioil/7oz5//7tZUSwbrSAN/NWHrQylz5cW8G0dWTcF/g+/dSdMlKVZspBYuMAN1+WnwHrkxiRrLcwd0Heg==} + /@types/webpack/4.41.33: + resolution: {integrity: sha512-PPajH64Ft2vWevkerISMtnZ8rTs4YmRbs+23c402J0INmxDKCrhZNvwZYtzx96gY2wAtXdrK1BS2fiC8MlLr3g==} dependencies: - '@types/node': 20.4.1 + '@types/node': 16.18.38 '@types/tapable': 1.0.8 - '@types/uglify-js': 3.17.0 + '@types/uglify-js': 3.17.1 '@types/webpack-sources': 3.2.0 - anymatch: 3.1.2 + anymatch: 3.1.3 source-map: 0.6.1 dev: true - /@types/which@2.0.2: + /@types/which/2.0.2: resolution: {integrity: sha512-113D3mDkZDjo+EeUEHCFy0qniNc1ZpecGiAU7WSo7YDoSzolZIQKpYFHrPpjkB2nuyahcKfrmLXeQlh7gqJYdw==} dev: true - /@types/ws@8.5.5: + /@types/ws/8.5.5: resolution: {integrity: sha512-lwhs8hktwxSjf9UaZ9tG5M03PGogvFaH8gUgLNbN9HKIg0dvv6q+gkSuJ8HN4/VbyxkuLzCjlN7GquQ0gUJfIg==} dependencies: '@types/node': 20.4.1 dev: true - /@types/yargs-parser@21.0.0: + /@types/yargs-parser/21.0.0: resolution: {integrity: sha512-iO9ZQHkZxHn4mSakYV0vFHAVDyEOIJQrV2uZ06HxEPcx+mt8swXoZHIbaaJ2crJYFfErySgktuTZ3BeLz+XmFA==} dev: true - /@types/yargs@15.0.14: - resolution: {integrity: sha512-yEJzHoxf6SyQGhBhIYGXQDSCkJjB6HohDShto7m8vaKg9Yp0Yn8+71J9eakh2bnPg6BfsH9PRMhiRTZnd4eXGQ==} - dependencies: - '@types/yargs-parser': 21.0.0 - dev: true - - /@types/yargs@16.0.5: - resolution: {integrity: sha512-AxO/ADJOBFJScHbWhq2xAhlWP24rY4aCEG/NFaMvbT3X2MgRsLjhjQwsn0Zi5zn0LG9jUhCCZMeX9Dkuw6k+vQ==} + /@types/yargs/15.0.15: + resolution: {integrity: sha512-IziEYMU9XoVj8hWg7k+UJrXALkGFjWJhn5QFEv9q4p+v40oZhSuC135M38st8XPjICL7Ey4TV64ferBGUoJhBg==} dependencies: '@types/yargs-parser': 21.0.0 dev: true - /@types/yargs@17.0.12: - resolution: {integrity: sha512-Nz4MPhecOFArtm81gFQvQqdV7XYCrWKx5uUt6GNHredFHn1i2mtWqXTON7EPXMtNi1qjtjEM/VCHDhcHsAMLXQ==} + /@types/yargs/17.0.24: + resolution: {integrity: sha512-6i0aC7jV6QzQB8ne1joVZ0eSFIstHsCrobmOtghM11yGlH0j43FKL2UhWdELkyps0zuf7qVTUVCCR+tgSlyLLw==} dependencies: '@types/yargs-parser': 21.0.0 dev: true - /@types/yauzl@2.10.0: + /@types/yauzl/2.10.0: resolution: {integrity: sha512-Cn6WYCm0tXv8p6k+A8PvbDG763EDpBoTzHdA+Q/MF6H3sapGjCm9NzoaJncJS9tUKSuCoDs9XHxYYsQDgxR6kw==} requiresBuild: true dependencies: @@ -9116,8 +7411,8 @@ packages: dev: true optional: true - /@typescript-eslint/eslint-plugin@5.60.0(@typescript-eslint/parser@5.60.0)(eslint@8.44.0)(typescript@5.1.6): - resolution: {integrity: sha512-78B+anHLF1TI8Jn/cD0Q00TBYdMgjdOn980JfAVa9yw5sop8nyTfVOQAv6LWywkOGLclDBtv5z3oxN4w7jxyNg==} + /@typescript-eslint/eslint-plugin/5.62.0_l3h7p4bxv72z3fumgmc6kvfciu: + resolution: {integrity: sha512-TiZzBSJja/LbhNPvk6yc0JrX9XqhQ0hdh6M2svYfsHGejaKFIAGd9MQ+ERIMzLGlN/kZoYIgdxFV0PuljTKXag==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: '@typescript-eslint/parser': ^5.0.0 @@ -9127,25 +7422,25 @@ packages: typescript: optional: true dependencies: - '@eslint-community/regexpp': 4.5.0 - '@typescript-eslint/parser': 5.60.0(eslint@8.44.0)(typescript@5.1.6) - '@typescript-eslint/scope-manager': 5.60.0 - '@typescript-eslint/type-utils': 5.60.0(eslint@8.44.0)(typescript@5.1.6) - '@typescript-eslint/utils': 5.60.0(eslint@8.44.0)(typescript@5.1.6) - debug: 4.3.4(supports-color@8.1.1) + '@eslint-community/regexpp': 4.5.1 + '@typescript-eslint/parser': 5.62.0_iqf7tbmerllfqanu4l3d6aqdn4 + '@typescript-eslint/scope-manager': 5.62.0 + '@typescript-eslint/type-utils': 5.62.0_iqf7tbmerllfqanu4l3d6aqdn4 + '@typescript-eslint/utils': 5.62.0_iqf7tbmerllfqanu4l3d6aqdn4 + debug: 4.3.4 eslint: 8.44.0 - grapheme-splitter: 1.0.4 - ignore: 5.2.0 + graphemer: 1.4.0 + ignore: 5.2.4 natural-compare-lite: 1.4.0 - semver: 7.5.2 - tsutils: 3.21.0(typescript@5.1.6) + semver: 7.5.4 + tsutils: 3.21.0_typescript@5.1.6 typescript: 5.1.6 transitivePeerDependencies: - supports-color dev: true - /@typescript-eslint/parser@5.60.0(eslint@8.44.0)(typescript@5.1.6): - resolution: {integrity: sha512-jBONcBsDJ9UoTWrARkRRCgDz6wUggmH5RpQVlt7BimSwaTkTjwypGzKORXbR4/2Hqjk9hgwlon2rVQAjWNpkyQ==} + /@typescript-eslint/parser/5.62.0_iqf7tbmerllfqanu4l3d6aqdn4: + resolution: {integrity: sha512-VlJEV0fOQ7BExOsHYAGrgbEiZoi8D+Bl2+f6V2RrXerRSylnp+ZBHmPvaIa8cz0Ajx7WO7Z5RqfgYg7ED1nRhA==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: eslint: ^6.0.0 || ^7.0.0 || ^8.0.0 @@ -9154,26 +7449,26 @@ packages: typescript: optional: true dependencies: - '@typescript-eslint/scope-manager': 5.60.0 - '@typescript-eslint/types': 5.60.0 - '@typescript-eslint/typescript-estree': 5.60.0(typescript@5.1.6) - debug: 4.3.4(supports-color@8.1.1) + '@typescript-eslint/scope-manager': 5.62.0 + '@typescript-eslint/types': 5.62.0 + '@typescript-eslint/typescript-estree': 5.62.0_typescript@5.1.6 + debug: 4.3.4 eslint: 8.44.0 typescript: 5.1.6 transitivePeerDependencies: - supports-color dev: true - /@typescript-eslint/scope-manager@5.60.0: - resolution: {integrity: sha512-hakuzcxPwXi2ihf9WQu1BbRj1e/Pd8ZZwVTG9kfbxAMZstKz8/9OoexIwnmLzShtsdap5U/CoQGRCWlSuPbYxQ==} + /@typescript-eslint/scope-manager/5.62.0: + resolution: {integrity: sha512-VXuvVvZeQCQb5Zgf4HAxc04q5j+WrNAtNh9OwCsCgpKqESMTu3tF/jhZ3xG6T4NZwWl65Bg8KuS2uEvhSfLl0w==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dependencies: - '@typescript-eslint/types': 5.60.0 - '@typescript-eslint/visitor-keys': 5.60.0 + '@typescript-eslint/types': 5.62.0 + '@typescript-eslint/visitor-keys': 5.62.0 dev: true - /@typescript-eslint/type-utils@5.60.0(eslint@8.44.0)(typescript@5.1.6): - resolution: {integrity: sha512-X7NsRQddORMYRFH7FWo6sA9Y/zbJ8s1x1RIAtnlj6YprbToTiQnM6vxcMu7iYhdunmoC0rUWlca13D5DVHkK2g==} + /@typescript-eslint/type-utils/5.62.0_iqf7tbmerllfqanu4l3d6aqdn4: + resolution: {integrity: sha512-xsSQreu+VnfbqQpW5vnCJdq1Z3Q0U31qiWmRhr98ONQmcp/yhiPJFPq8MXiJVLiksmOKSjIldZzkebzHuCGzew==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: eslint: '*' @@ -9182,23 +7477,23 @@ packages: typescript: optional: true dependencies: - '@typescript-eslint/typescript-estree': 5.60.0(typescript@5.1.6) - '@typescript-eslint/utils': 5.60.0(eslint@8.44.0)(typescript@5.1.6) - debug: 4.3.4(supports-color@8.1.1) + '@typescript-eslint/typescript-estree': 5.62.0_typescript@5.1.6 + '@typescript-eslint/utils': 5.62.0_iqf7tbmerllfqanu4l3d6aqdn4 + debug: 4.3.4 eslint: 8.44.0 - tsutils: 3.21.0(typescript@5.1.6) + tsutils: 3.21.0_typescript@5.1.6 typescript: 5.1.6 transitivePeerDependencies: - supports-color dev: true - /@typescript-eslint/types@5.60.0: - resolution: {integrity: sha512-ascOuoCpNZBccFVNJRSC6rPq4EmJ2NkuoKnd6LDNyAQmdDnziAtxbCGWCbefG1CNzmDvd05zO36AmB7H8RzKPA==} + /@typescript-eslint/types/5.62.0: + resolution: {integrity: sha512-87NVngcbVXUahrRTqIK27gD2t5Cu1yuCXxbLcFtCzZGlfyVWWh8mLHkoxzjsB6DDNnvdL+fW8MiwPEJyGJQDgQ==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dev: true - /@typescript-eslint/typescript-estree@5.60.0(typescript@5.1.6): - resolution: {integrity: sha512-R43thAuwarC99SnvrBmh26tc7F6sPa2B3evkXp/8q954kYL6Ro56AwASYWtEEi+4j09GbiNAHqYwNNZuNlARGQ==} + /@typescript-eslint/typescript-estree/5.62.0_typescript@5.1.6: + resolution: {integrity: sha512-CmcQ6uY7b9y694lKdRB8FEel7JbU/40iSAPomu++SjLMntB+2Leay2LO6i8VnJk58MtE9/nQSFIH6jpyRWyYzA==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: typescript: '*' @@ -9206,30 +7501,30 @@ packages: typescript: optional: true dependencies: - '@typescript-eslint/types': 5.60.0 - '@typescript-eslint/visitor-keys': 5.60.0 - debug: 4.3.4(supports-color@8.1.1) + '@typescript-eslint/types': 5.62.0 + '@typescript-eslint/visitor-keys': 5.62.0 + debug: 4.3.4 globby: 11.1.0 is-glob: 4.0.3 semver: 7.5.4 - tsutils: 3.21.0(typescript@5.1.6) + tsutils: 3.21.0_typescript@5.1.6 typescript: 5.1.6 transitivePeerDependencies: - supports-color dev: true - /@typescript-eslint/utils@5.60.0(eslint@8.44.0)(typescript@5.1.6): - resolution: {integrity: sha512-ba51uMqDtfLQ5+xHtwlO84vkdjrqNzOnqrnwbMHMRY8Tqeme8C2Q8Fc7LajfGR+e3/4LoYiWXUM6BpIIbHJ4hQ==} + /@typescript-eslint/utils/5.62.0_iqf7tbmerllfqanu4l3d6aqdn4: + resolution: {integrity: sha512-n8oxjeb5aIbPFEtmQxQYOLI0i9n5ySBEY/ZEHHZqKQSFnxio1rv6dthascc9dLuwrL0RC5mPCxB7vnAVGAYWAQ==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: eslint: ^6.0.0 || ^7.0.0 || ^8.0.0 dependencies: - '@eslint-community/eslint-utils': 4.4.0(eslint@8.44.0) - '@types/json-schema': 7.0.11 - '@types/semver': 7.3.13 - '@typescript-eslint/scope-manager': 5.60.0 - '@typescript-eslint/types': 5.60.0 - '@typescript-eslint/typescript-estree': 5.60.0(typescript@5.1.6) + '@eslint-community/eslint-utils': 4.4.0_eslint@8.44.0 + '@types/json-schema': 7.0.12 + '@types/semver': 7.5.0 + '@typescript-eslint/scope-manager': 5.62.0 + '@typescript-eslint/types': 5.62.0 + '@typescript-eslint/typescript-estree': 5.62.0_typescript@5.1.6 eslint: 8.44.0 eslint-scope: 5.1.1 semver: 7.5.4 @@ -9238,76 +7533,43 @@ packages: - typescript dev: true - /@typescript-eslint/visitor-keys@5.60.0: - resolution: {integrity: sha512-wm9Uz71SbCyhUKgcaPRauBdTegUyY/ZWl8gLwD/i/ybJqscrrdVSFImpvUz16BLPChIeKBK5Fa9s6KDQjsjyWw==} + /@typescript-eslint/visitor-keys/5.62.0: + resolution: {integrity: sha512-07ny+LHRzQXepkGg6w0mFY41fVUNBrL2Roj/++7V1txKugfjm/Ci/qSND03r2RhlJhJYMcTn9AhhSSqQp0Ysyw==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dependencies: - '@typescript-eslint/types': 5.60.0 + '@typescript-eslint/types': 5.62.0 eslint-visitor-keys: 3.4.1 dev: true - /@ungap/structured-clone@1.2.0: + /@ungap/structured-clone/1.2.0: resolution: {integrity: sha512-zuVdFrMJiuCDQUMCzQaD6KL28MjnqqN8XnAqiEq9PNm/hCPTSGfrXCOfwj1ow4LFb/tNymJPwsNbVePc1xFqrQ==} dev: true - /@unocss/astro@0.53.4(rollup@2.79.1)(vite@4.3.9): - resolution: {integrity: sha512-fR1F0mNktoN79R+t4GD4y3cvfHUVxtV0+9/6vraZTw3SOXTOMdHeisdxDLjJb3N1yer7XoKX+2GHrKCt873IUA==} + /@unocss/astro/0.53.5_vite@4.4.3: + resolution: {integrity: sha512-W4A0uIN4xAzVH6Vwf5ukG8rJpCeIwQZcpZPrEBWsqY5YcHZcLTFGMHcNmxyeG0qoXpXoxtvHyXXhgGU0BY5ZEw==} dependencies: - '@unocss/core': 0.53.4 - '@unocss/reset': 0.53.4 - '@unocss/vite': 0.53.4(rollup@2.79.1)(vite@4.3.9) + '@unocss/core': 0.53.5 + '@unocss/reset': 0.53.5 + '@unocss/vite': 0.53.5_vite@4.4.3 transitivePeerDependencies: - rollup - vite dev: true - /@unocss/astro@0.53.4(rollup@3.26.0)(vite@4.3.9): - resolution: {integrity: sha512-fR1F0mNktoN79R+t4GD4y3cvfHUVxtV0+9/6vraZTw3SOXTOMdHeisdxDLjJb3N1yer7XoKX+2GHrKCt873IUA==} - dependencies: - '@unocss/core': 0.53.4 - '@unocss/reset': 0.53.4 - '@unocss/vite': 0.53.4(rollup@3.26.0)(vite@4.3.9) - transitivePeerDependencies: - - rollup - - vite - dev: true - - /@unocss/cli@0.53.4(rollup@2.79.1): - resolution: {integrity: sha512-nRlmEcApzFbRkvkOauq6z46dcYJaWfkK7VdavSgXbLWCSoKWXY7JkEAON1Zhmk4O8F4zW7hnxTfqZI5jfy09Rw==} - engines: {node: '>=14'} - hasBin: true - dependencies: - '@ampproject/remapping': 2.2.1 - '@rollup/pluginutils': 5.0.2(rollup@2.79.1) - '@unocss/config': 0.53.4 - '@unocss/core': 0.53.4 - '@unocss/preset-uno': 0.53.4 - cac: 6.7.14 - chokidar: 3.5.3 - colorette: 2.0.20 - consola: 3.1.0 - fast-glob: 3.3.0 - magic-string: 0.30.1 - pathe: 1.1.1 - perfect-debounce: 1.0.0 - transitivePeerDependencies: - - rollup - dev: true - - /@unocss/cli@0.53.4(rollup@3.26.0): - resolution: {integrity: sha512-nRlmEcApzFbRkvkOauq6z46dcYJaWfkK7VdavSgXbLWCSoKWXY7JkEAON1Zhmk4O8F4zW7hnxTfqZI5jfy09Rw==} + /@unocss/cli/0.53.5: + resolution: {integrity: sha512-UKi+9BAKh3X5eM4pPQviXMOtN8JkQWKdGy/056rRLQysPB07VBwWr5gYAlJMMJ2wFAIthag43X5I8btQAicFkg==} engines: {node: '>=14'} hasBin: true dependencies: '@ampproject/remapping': 2.2.1 - '@rollup/pluginutils': 5.0.2(rollup@3.26.0) - '@unocss/config': 0.53.4 - '@unocss/core': 0.53.4 - '@unocss/preset-uno': 0.53.4 + '@rollup/pluginutils': 5.0.2 + '@unocss/config': 0.53.5 + '@unocss/core': 0.53.5 + '@unocss/preset-uno': 0.53.5 cac: 6.7.14 chokidar: 3.5.3 colorette: 2.0.20 - consola: 3.1.0 + consola: 3.2.3 fast-glob: 3.3.0 magic-string: 0.30.1 pathe: 1.1.1 @@ -9316,212 +7578,190 @@ packages: - rollup dev: true - /@unocss/config@0.53.4: - resolution: {integrity: sha512-xcawSTpo/+yXUsmfQE0FNAkTS6k2sSSWXQD1grCpeZPY9YNVZTFIJvQXC3xMTgRRBRTBThuGDiUC9YF/XAOcZw==} + /@unocss/config/0.53.5: + resolution: {integrity: sha512-YtpWoIFB1V8Dp3KcVQqislQYQSSBYbjTpoVIkUGrpupwOz9+W1tfL2yKEENDiZc11crJSneGr04wsP2dI1ld0w==} engines: {node: '>=14'} dependencies: - '@unocss/core': 0.53.4 + '@unocss/core': 0.53.5 unconfig: 0.3.9 dev: true - /@unocss/core@0.53.4: - resolution: {integrity: sha512-JvmpuFOiJ8NkGzRmh0dCUmNdYjr8MmMtCX+czCmSnX2kvKyQjJIw3RIu84/DQbd/M/yxZmPjle8DrcZ1Ql86rQ==} + /@unocss/core/0.53.5: + resolution: {integrity: sha512-jBvk4FeUAALAomGfMFFmrXLy01/5DjugdnWgawFAQpSToFTxbMHS7x+pXKu/18cq+YLS8uyl9S0Ywy1jNbfS3Q==} dev: true - /@unocss/extractor-arbitrary-variants@0.53.4: - resolution: {integrity: sha512-ydkfObZALqRqe/M68hBsIfT6KsUFm3nBD/4xUf4hvOiIySwptzUWYliVSoPHqhEq8L122oAEG1i5Yg8kQUUJZQ==} + /@unocss/extractor-arbitrary-variants/0.53.5: + resolution: {integrity: sha512-rSS3Q8/+lEwxXfXzEOFuhAQGMpaaZcBAYDiNCYS/9BqKrTzhSYG82Qy80ISpqSZr0BTLET4X3dC6B6Rd4GU5vQ==} dependencies: - '@unocss/core': 0.53.4 + '@unocss/core': 0.53.5 dev: true - /@unocss/inspector@0.53.4: - resolution: {integrity: sha512-PW5+dAYKCipOmqtT3W407JZmjswcxQvifFEzdamhxjYrH0aFi5xhbH4PX5ArXeywebdg6inm343K0Gg/4I6GuA==} + /@unocss/inspector/0.53.5: + resolution: {integrity: sha512-gWUhgsoB3LyjIAdw6n/eMcLGmUNwuSTrgwcRubIDFhHOC5/E6ppdUQmS8a4oH4qjunfvBgoTHwcGlXvlvb3S5w==} dependencies: gzip-size: 6.0.0 sirv: 2.0.3 dev: true - /@unocss/postcss@0.53.4(postcss@8.4.24): - resolution: {integrity: sha512-G7ZWqUszJiXrQVOzLBzOFZwGIVGwH695lE75NufQi8tXQF9QphGKT0t7AX1NRxA3IZpZW2Twxa/tZYRh2PJQAg==} + /@unocss/postcss/0.53.5: + resolution: {integrity: sha512-IfZl4GxrpegP/861bp3e0X3VcQJ9/M3VxC9UQ7zzxkOz/E8R09iMpbnznVLrTiLp2r96p5k/ggXLoadFm1FxGA==} engines: {node: '>=14'} - peerDependencies: - postcss: ^8.4.21 dependencies: - '@unocss/config': 0.53.4 - '@unocss/core': 0.53.4 + '@unocss/config': 0.53.5 + '@unocss/core': 0.53.5 css-tree: 2.3.1 fast-glob: 3.3.0 magic-string: 0.30.1 - postcss: 8.4.24 + postcss: 8.4.25 dev: true - /@unocss/preset-attributify@0.53.4: - resolution: {integrity: sha512-/lYH0SHFEkROOMHJ5td3txHnR93RRt/ZtsJ4brH3ptJixiEiShl5oNGS8cHBV/jV/KYsBW4gqeVomzUGCGWu9w==} + /@unocss/preset-attributify/0.53.5: + resolution: {integrity: sha512-0TJD9hVUWu0T4dtdURApyFiliqbckYYGZe2PZBgUrHCypbI0zq7k3MdXFYmIuYxqDPErJVm8rO9lwMpKfTsvuA==} dependencies: - '@unocss/core': 0.53.4 + '@unocss/core': 0.53.5 dev: true - /@unocss/preset-icons@0.53.4: - resolution: {integrity: sha512-PSc1svzDq/o7lKLrZohFIMf0ZqOypYdBY1Wvfp+Gd6Zc4uybnCTVme3pnlgYIcjSO24ilt/PeWgx3SxD8ypMcw==} + /@unocss/preset-icons/0.53.5: + resolution: {integrity: sha512-zlO0fLJiJtITta3BnE3y5Yc0hajjovCB/woos4MR5gvcFXHW9Hfy7pXuj90GvHLfaRj0JRWXa1WRaqJXS4tzOw==} dependencies: '@iconify/utils': 2.1.7 - '@unocss/core': 0.53.4 + '@unocss/core': 0.53.5 ofetch: 1.1.1 transitivePeerDependencies: - supports-color dev: true - /@unocss/preset-mini@0.53.4: - resolution: {integrity: sha512-m9SMA9m1VhC0xAXtw07lke9GltuLTZONWlad79KkYi/2YaywZsJAk8Y4+MVo4B4azh1Jxz2LOtEEBgqIYhbqJg==} + /@unocss/preset-mini/0.53.5: + resolution: {integrity: sha512-aeVctTW0M41RXyCyQvhRawIh+ylhl7mlWfAjv7cP3ALvIRWbB6jUw1C8Ke6rU2vg0s0yaJKRuFPFmLMqGwzoSg==} dependencies: - '@unocss/core': 0.53.4 - '@unocss/extractor-arbitrary-variants': 0.53.4 + '@unocss/core': 0.53.5 + '@unocss/extractor-arbitrary-variants': 0.53.5 dev: true - /@unocss/preset-tagify@0.53.4: - resolution: {integrity: sha512-ucdYjSdop2MZcnZ56+ViQweVaZatYaAAnD33C++nJn8d/GK2e96PHZJjtpq5/Oh00izr7/5bQJ5c4uhKAmSmUA==} + /@unocss/preset-tagify/0.53.5: + resolution: {integrity: sha512-0HpWU85Pz1RbFqf/QtlP992ISSqWZ3JT2rWI7ekBLai463ptdBUks/PfH22M+uBSwPig5XNJ0DtyS7hm8TEWhg==} dependencies: - '@unocss/core': 0.53.4 + '@unocss/core': 0.53.5 dev: true - /@unocss/preset-typography@0.53.4: - resolution: {integrity: sha512-I15PCD7gomoewyub8iVt7x6hCXiPk/2Qt6QeWC4r0UgSq8wtQQlHm2T9E6jv03F00ISwMB5VYYivnHOxnrmm8w==} + /@unocss/preset-typography/0.53.5: + resolution: {integrity: sha512-roZXiJ14wuXcpLN5YodAN1wKYlwCDJ8L/TQlUphyM487i0QbKwXAZg8dA1SWCQIl5V9Qcq/3EXAQmLnhRdwBMA==} dependencies: - '@unocss/core': 0.53.4 - '@unocss/preset-mini': 0.53.4 + '@unocss/core': 0.53.5 + '@unocss/preset-mini': 0.53.5 dev: true - /@unocss/preset-uno@0.53.4: - resolution: {integrity: sha512-3VWdc0kOZnOO1HGHwVbIzRjUvn4IfxZPwdohgCpISeUCIGI1ohYRsrzlJgSrHXD4BmD9UInRZHymb1ytrKRLgA==} + /@unocss/preset-uno/0.53.5: + resolution: {integrity: sha512-DRJMBkSqfz0EOzf5cwefkPF8J6lNvrhBp4ztw9blewDc2wTQqL/lAj/I/nbyOdXhJUOxhj/qj7gJjsNZctud0A==} dependencies: - '@unocss/core': 0.53.4 - '@unocss/preset-mini': 0.53.4 - '@unocss/preset-wind': 0.53.4 + '@unocss/core': 0.53.5 + '@unocss/preset-mini': 0.53.5 + '@unocss/preset-wind': 0.53.5 dev: true - /@unocss/preset-web-fonts@0.53.4: - resolution: {integrity: sha512-4qqhUjzP5NbLNnRU9WaN2SLBjwY+qtvN4JN2vKD1o9HOPauIzGWq3SyaR8VoviQ9D8vg/L80Fl/pqGAvV/xvaw==} + /@unocss/preset-web-fonts/0.53.5: + resolution: {integrity: sha512-yVkOOECyOQqahRGSefcBKtNYAUnYFqqFedGy0SBBjadPWn80vjVg7ojljKlJsgSQdrpcJ38wwWr3Oh4UWwBuQQ==} dependencies: - '@unocss/core': 0.53.4 + '@unocss/core': 0.53.5 ofetch: 1.1.1 dev: true - /@unocss/preset-wind@0.53.4: - resolution: {integrity: sha512-8PF3wZW8MvzjN562wOCfZzxlhqyd9f4Ay/wQborYY+P3BfIm5ORZ6GIdXsA7do+CE+yXytQ5NmtkBdd5eHdMdA==} + /@unocss/preset-wind/0.53.5: + resolution: {integrity: sha512-hSMF11Gx8oMDtePvXLmpArSNpQRHb098P8+qYpwvyNfS29i6agfjGBuIDk/f+j8mhqcfrEEuEmPIl2yojT9nxA==} dependencies: - '@unocss/core': 0.53.4 - '@unocss/preset-mini': 0.53.4 + '@unocss/core': 0.53.5 + '@unocss/preset-mini': 0.53.5 dev: true - /@unocss/reset@0.53.4: - resolution: {integrity: sha512-NMqntd9CE9EpdtI2ELGCZg9Z2ySMdo/ljepP8QwfRmWbYaXUf3T/GJsOTqewbhNgJUGYinbs1OtiN0yG5xZjJQ==} + /@unocss/reset/0.53.5: + resolution: {integrity: sha512-tH8K4jw76mbWA67UUHKV6zxiwOsiG+byrHoG3lz8hr+cm6OgEJ3WjNNp7dZINmr7S7ylWO6igbxGQpsAuIQZCw==} dev: true - /@unocss/scope@0.53.4: - resolution: {integrity: sha512-vomyjd6i27V5G2awPoo9FoUit6qYyDyO0kroLzYPPNgq5M5jQFrZuQYc24dQ+JeJAQ3hlCGl8VM2v3Aj0PyUFg==} + /@unocss/scope/0.53.5: + resolution: {integrity: sha512-KBwemWNJIbu3+BWp0X4o5ERN0/nzF7hXBnjYNSb0s8phrydC6oJrp52XYlIHHTe7O4KzwkqGgf/xOMXMFpviDg==} dev: true - /@unocss/transformer-attributify-jsx-babel@0.53.4: - resolution: {integrity: sha512-XR+u21GoZsdUDZXMgToH087uJCPJMIGLEv+ISb3fE40wOTiah+4wzTSjJpjzj8ReNG9lvrw5H6NBQcX0db1XCQ==} + /@unocss/transformer-attributify-jsx-babel/0.53.5: + resolution: {integrity: sha512-z9ar2IaZmcNVTZhK9ZuRUd3LqA/iUG/JMF0OA92RNclo8SazWdu7eJAdV86SHXqAf7eSB/t0evsde14DtEREjA==} dependencies: - '@unocss/core': 0.53.4 + '@unocss/core': 0.53.5 dev: true - /@unocss/transformer-attributify-jsx@0.53.4: - resolution: {integrity: sha512-JYhwv3bZnFldXLfNKq7bmOLqNkFbvG/FyCojUz9G8+oj9jhQicwE33hDGddtbmoBUO660sBtqqLOtp8DlIY/oA==} + /@unocss/transformer-attributify-jsx/0.53.5: + resolution: {integrity: sha512-ynAElIi9DxtHyKCW+OXPcLxje2ghVzKo80eaAVRAdVpyawsjtE4iHWjHRbESkiTsHW5CiJupdXo2vx1obXFLnQ==} dependencies: - '@unocss/core': 0.53.4 + '@unocss/core': 0.53.5 dev: true - /@unocss/transformer-compile-class@0.53.4: - resolution: {integrity: sha512-Eq9dD7eWbhNpOF5WY69uYtfGSKlBWjTN2+m+KpOBvtxwe++VIHoRXHwDWC0gKEPaWTvhfRa+RdSCXVRLOygYFg==} + /@unocss/transformer-compile-class/0.53.5: + resolution: {integrity: sha512-7Z0/40T4EuHMGpXb2XlamkResaASMRm07csCl7REGUTg9ccDRWlnSLzGD8UUgKoygsmqXp2cxKMJLMb5YJ9LLA==} dependencies: - '@unocss/core': 0.53.4 + '@unocss/core': 0.53.5 dev: true - /@unocss/transformer-directives@0.53.4: - resolution: {integrity: sha512-21dCt3u0WHqXFMfRkkPgjKGyDtghhqItCInr/vB9uKnJFLUdFWlqJu/wRHCUDVypeykwtaLVeCPwpvphCP+VHg==} + /@unocss/transformer-directives/0.53.5: + resolution: {integrity: sha512-u1OIZZUAXux9Q0mb58X3infxY2Iq6pY7uJB7IhMc2I1ntpyx875spwyvvfUHqOgIPTNR4XxfxKFGPHpjPNbNeQ==} dependencies: - '@unocss/core': 0.53.4 + '@unocss/core': 0.53.5 css-tree: 2.3.1 dev: true - /@unocss/transformer-variant-group@0.53.4: - resolution: {integrity: sha512-ir3FMZV1PQ1oUZU0mYTZ5kIrsn68vwUJtOiCcqq2XMSAM4NK8EBdqRqd0mg7he3AjhPzd//Rdx8XpfVFbw7EVw==} - dependencies: - '@unocss/core': 0.53.4 - dev: true - - /@unocss/vite@0.53.4(rollup@2.79.1)(vite@4.3.9): - resolution: {integrity: sha512-s2t7Es2L788MSyPAJUksUaiTLBGyISiyESelyGxBwDpAR6ddHiKB9LU2MVLTU289rmnhebWHFvw7lbE+Trs/Dw==} - peerDependencies: - vite: ^2.9.0 || ^3.0.0-0 || ^4.0.0 + /@unocss/transformer-variant-group/0.53.5: + resolution: {integrity: sha512-+xDx6JojGkcKwx87sX0y4xM/RuTI0QyPJAKebXUSyuKnctXrTH/p+WNGFIVWiY8suUMnnMesAZpw6O2Oln921w==} dependencies: - '@ampproject/remapping': 2.2.1 - '@rollup/pluginutils': 5.0.2(rollup@2.79.1) - '@unocss/config': 0.53.4 - '@unocss/core': 0.53.4 - '@unocss/inspector': 0.53.4 - '@unocss/scope': 0.53.4 - '@unocss/transformer-directives': 0.53.4 - chokidar: 3.5.3 - fast-glob: 3.3.0 - magic-string: 0.30.1 - vite: 4.3.9(@types/node@18.16.19) - transitivePeerDependencies: - - rollup + '@unocss/core': 0.53.5 dev: true - /@unocss/vite@0.53.4(rollup@3.26.0)(vite@4.3.9): - resolution: {integrity: sha512-s2t7Es2L788MSyPAJUksUaiTLBGyISiyESelyGxBwDpAR6ddHiKB9LU2MVLTU289rmnhebWHFvw7lbE+Trs/Dw==} + /@unocss/vite/0.53.5_vite@4.4.3: + resolution: {integrity: sha512-ez0MVRatewLUQq79LI+XRAVRbXWaGbK1K1ht2B8vGyL9OrL6uieEwzxjHV7+rUa8i+FEHfD4Ntmtdpb3WuQSAA==} peerDependencies: vite: ^2.9.0 || ^3.0.0-0 || ^4.0.0 dependencies: '@ampproject/remapping': 2.2.1 - '@rollup/pluginutils': 5.0.2(rollup@3.26.0) - '@unocss/config': 0.53.4 - '@unocss/core': 0.53.4 - '@unocss/inspector': 0.53.4 - '@unocss/scope': 0.53.4 - '@unocss/transformer-directives': 0.53.4 + '@rollup/pluginutils': 5.0.2 + '@unocss/config': 0.53.5 + '@unocss/core': 0.53.5 + '@unocss/inspector': 0.53.5 + '@unocss/scope': 0.53.5 + '@unocss/transformer-directives': 0.53.5 chokidar: 3.5.3 fast-glob: 3.3.0 magic-string: 0.30.1 - vite: 4.3.9(@types/node@18.16.19) + vite: 4.4.3 transitivePeerDependencies: - rollup dev: true - /@vite-pwa/assets-generator@0.0.3: + /@vite-pwa/assets-generator/0.0.3: resolution: {integrity: sha512-rGjzFTGAZsY9fIf9qGbvXbo38Yj0MbAtTxAaL/GBlEU0+q/m6upw+4HKE58p2MnjUAOOBHf0871u3onHtkPWlQ==} engines: {node: '>=16.14.0'} hasBin: true dependencies: cac: 6.7.14 colorette: 2.0.20 - consola: 3.1.0 - sharp: 0.32.1 + consola: 3.2.3 + sharp: 0.32.2 sharp-ico: 0.1.5 unconfig: 0.3.9 dev: true - /@vite-pwa/vitepress@0.2.0(vite-plugin-pwa@0.16.4): + /@vite-pwa/vitepress/0.2.0_vite-plugin-pwa@0.16.4: resolution: {integrity: sha512-dVQVaP6NB9woCFe4UASUqRp7uwBQJOVXlJlqK4krqXcbb3NuXIXIWOnU7HLpJnHqZj5U/81gKtLN6gs5gJBwiQ==} peerDependencies: vite-plugin-pwa: '>=0.16.3 <1' dependencies: - vite-plugin-pwa: 0.16.4(vite@4.3.9)(workbox-build@7.0.0)(workbox-window@7.0.0) + vite-plugin-pwa: 0.16.4_cqwyifvz3q2qdw6r4piqd2mqaa dev: true - /@vitejs/plugin-react@1.3.2: + /@vitejs/plugin-react/1.3.2: resolution: {integrity: sha512-aurBNmMo0kz1O4qRoY+FM4epSA39y3ShWGuqfLRA/3z0oEJAdtoSfgA3aO98/PCCHAqMaduLxIxErWrVKIFzXA==} engines: {node: '>=12.0.0'} dependencies: - '@babel/core': 7.22.5 - '@babel/plugin-transform-react-jsx': 7.18.10(@babel/core@7.22.5) - '@babel/plugin-transform-react-jsx-development': 7.18.6(@babel/core@7.22.5) - '@babel/plugin-transform-react-jsx-self': 7.22.5(@babel/core@7.22.5) - '@babel/plugin-transform-react-jsx-source': 7.22.5(@babel/core@7.22.5) + '@babel/core': 7.22.8 + '@babel/plugin-transform-react-jsx': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-react-jsx-development': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-react-jsx-self': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-react-jsx-source': 7.22.5_@babel+core@7.22.8 '@rollup/pluginutils': 4.2.1 react-refresh: 0.13.0 resolve: 1.22.2 @@ -9529,78 +7769,92 @@ packages: - supports-color dev: true - /@vitejs/plugin-react@4.0.3(vite@4.3.9): + /@vitejs/plugin-react/4.0.3: resolution: {integrity: sha512-pwXDog5nwwvSIzwrvYYmA2Ljcd/ZNlcsSG2Q9CNDBwnsd55UGAyr2doXtB5j+2uymRCnCfExlznzzSFbBRcoCg==} engines: {node: ^14.18.0 || >=16.0.0} peerDependencies: vite: ^4.2.0 dependencies: - '@babel/core': 7.22.5 - '@babel/plugin-transform-react-jsx-self': 7.22.5(@babel/core@7.22.5) - '@babel/plugin-transform-react-jsx-source': 7.22.5(@babel/core@7.22.5) + '@babel/core': 7.22.8 + '@babel/plugin-transform-react-jsx-self': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-react-jsx-source': 7.22.5_@babel+core@7.22.8 react-refresh: 0.14.0 - vite: 4.3.9(@types/node@20.4.1) transitivePeerDependencies: - supports-color dev: true - /@vitejs/plugin-vue-jsx@3.0.1(vite@4.3.9)(vue@3.3.4): - resolution: {integrity: sha512-+Jb7ggL48FSPS1uhPnJbJwWa9Sr90vQ+d0InW+AhBM22n+cfuYqJZDckBc+W3QSHe1WDvewMZfa4wZOtk5pRgw==} + /@vitejs/plugin-react/4.0.3_vite@4.4.3: + resolution: {integrity: sha512-pwXDog5nwwvSIzwrvYYmA2Ljcd/ZNlcsSG2Q9CNDBwnsd55UGAyr2doXtB5j+2uymRCnCfExlznzzSFbBRcoCg==} engines: {node: ^14.18.0 || >=16.0.0} peerDependencies: - vite: ^4.0.0 - vue: ^3.0.0 + vite: ^4.2.0 dependencies: - '@babel/core': 7.22.5 - '@babel/plugin-transform-typescript': 7.21.3(@babel/core@7.22.5) - '@vue/babel-plugin-jsx': 1.1.1(@babel/core@7.22.5) - vite: 4.3.9(@types/node@18.16.19) - vue: 3.3.4 + '@babel/core': 7.22.8 + '@babel/plugin-transform-react-jsx-self': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-react-jsx-source': 7.22.5_@babel+core@7.22.8 + react-refresh: 0.14.0 + vite: 4.4.3 transitivePeerDependencies: - supports-color dev: true - /@vitejs/plugin-vue2@1.1.2(vite@4.3.9)(vue@2.7.10): - resolution: {integrity: sha512-y6OEA+2UdJ0xrEQHodq20v9r3SpS62IOHrgN92JPLvVpNkhcissu7yvD5PXMzMESyazj0XNWGsc8UQk8+mVrjQ==} - engines: {node: '>=14.6.0'} + /@vitejs/plugin-vue-jsx/3.0.1_vite@4.4.3+vue@3.3.4: + resolution: {integrity: sha512-+Jb7ggL48FSPS1uhPnJbJwWa9Sr90vQ+d0InW+AhBM22n+cfuYqJZDckBc+W3QSHe1WDvewMZfa4wZOtk5pRgw==} + engines: {node: ^14.18.0 || >=16.0.0} peerDependencies: - vite: '>=2.5.10' - vue: ^2.7.0-0 + vite: ^4.0.0 + vue: ^3.0.0 dependencies: - vite: 4.3.9(@types/node@18.16.19) - vue: 2.7.10 + '@babel/core': 7.22.8 + '@babel/plugin-transform-typescript': 7.22.5_@babel+core@7.22.8 + '@vue/babel-plugin-jsx': 1.1.5_@babel+core@7.22.8 + vite: 4.4.3 + vue: 3.3.4 + transitivePeerDependencies: + - supports-color dev: true - /@vitejs/plugin-vue@4.2.3(vite@4.3.9)(vue@3.3.4): + /@vitejs/plugin-vue/4.2.3_vite@4.4.3+vue@3.3.4: resolution: {integrity: sha512-R6JDUfiZbJA9cMiguQ7jxALsgiprjBeHL5ikpXfJCH62pPHtI+JdJ5xWj6Ev73yXSlYl86+blXn1kZHQ7uElxw==} engines: {node: ^14.18.0 || >=16.0.0} peerDependencies: vite: ^4.0.0 vue: ^3.2.25 dependencies: - vite: 4.3.9(@types/node@18.16.19) + vite: 4.4.3 vue: 3.3.4 dev: true - /@volar/code-gen@0.40.13: + /@vitejs/plugin-vue2/1.1.2_vite@4.4.3+vue@2.7.14: + resolution: {integrity: sha512-y6OEA+2UdJ0xrEQHodq20v9r3SpS62IOHrgN92JPLvVpNkhcissu7yvD5PXMzMESyazj0XNWGsc8UQk8+mVrjQ==} + engines: {node: '>=14.6.0'} + peerDependencies: + vite: '>=2.5.10' + vue: ^2.7.0-0 + dependencies: + vite: 4.4.3 + vue: 2.7.14 + dev: true + + /@volar/code-gen/0.40.13: resolution: {integrity: sha512-4gShBWuMce868OVvgyA1cU5WxHbjfEme18Tw6uVMfweZCF5fB2KECG0iPrA9D54vHk3FeHarODNwgIaaFfUBlA==} dependencies: '@volar/source-map': 0.40.13 dev: true - /@volar/source-map@0.40.13: + /@volar/source-map/0.40.13: resolution: {integrity: sha512-dbdkAB2Nxb0wLjAY5O64o3ywVWlAGONnBIoKAkXSf6qkGZM+nJxcizsoiI66K+RHQG0XqlyvjDizfnTxr+6PWg==} dependencies: '@vue/reactivity': 3.2.38 dev: true - /@volar/typescript-faster@0.40.13: + /@volar/typescript-faster/0.40.13: resolution: {integrity: sha512-uy+TlcFkKoNlKEnxA4x5acxdxLyVDIXGSc8cYDNXpPKjBKXrQaetzCzlO3kVBqu1VLMxKNGJMTKn35mo+ILQmw==} dependencies: - semver: 7.5.2 + semver: 7.5.4 dev: true - /@volar/vue-language-core@0.40.13: + /@volar/vue-language-core/0.40.13: resolution: {integrity: sha512-QkCb8msi2KUitTdM6Y4kAb7/ZlEvuLcbBFOC2PLBlFuoZwyxvSP7c/dBGmKGtJlEvMX0LdCyrg5V2aBYxD38/Q==} dependencies: '@volar/code-gen': 0.40.13 @@ -9612,7 +7866,7 @@ packages: '@vue/shared': 3.3.4 dev: true - /@volar/vue-typescript@0.40.13: + /@volar/vue-typescript/0.40.13: resolution: {integrity: sha512-o7bNztwjs8JmbQjVkrnbZUOfm7q4B8ZYssETISN1tRaBdun6cfNqgpkvDYd+VUBh1O4CdksvN+5BUNnwAz4oCQ==} dependencies: '@volar/code-gen': 0.40.13 @@ -9620,80 +7874,54 @@ packages: '@volar/vue-language-core': 0.40.13 dev: true - /@vue/babel-helper-vue-transform-on@1.0.2: - resolution: {integrity: sha512-hz4R8tS5jMn8lDq6iD+yWL6XNB699pGIVLk7WSJnn1dbpjaazsjZQkieJoRX6gW5zpYSCFqQ7jUquPNY65tQYA==} + /@vue/babel-helper-vue-transform-on/1.1.5: + resolution: {integrity: sha512-SgUymFpMoAyWeYWLAY+MkCK3QEROsiUnfaw5zxOVD/M64KQs8D/4oK6Q5omVA2hnvEOE0SCkH2TZxs/jnnUj7w==} dev: true - /@vue/babel-plugin-jsx@1.1.1(@babel/core@7.22.5): - resolution: {integrity: sha512-j2uVfZjnB5+zkcbc/zsOc0fSNGCMMjaEXP52wdwdIfn0qjFfEYpYZBFKFg+HHnQeJCVrjOeO0YxgaL7DMrym9w==} + /@vue/babel-plugin-jsx/1.1.5_@babel+core@7.22.8: + resolution: {integrity: sha512-nKs1/Bg9U1n3qSWnsHhCVQtAzI6aQXqua8j/bZrau8ywT1ilXQbK4FwEJGmU8fV7tcpuFvWmmN7TMmV1OBma1g==} + peerDependencies: + '@babel/core': ^7.0.0-0 dependencies: + '@babel/core': 7.22.8 '@babel/helper-module-imports': 7.22.5 - '@babel/plugin-syntax-jsx': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-syntax-jsx': 7.22.5_@babel+core@7.22.8 '@babel/template': 7.22.5 - '@babel/traverse': 7.22.5 + '@babel/traverse': 7.22.8 '@babel/types': 7.22.5 - '@vue/babel-helper-vue-transform-on': 1.0.2 + '@vue/babel-helper-vue-transform-on': 1.1.5 camelcase: 6.3.0 - html-tags: 3.2.0 + html-tags: 3.3.1 svg-tags: 1.0.0 transitivePeerDependencies: - - '@babel/core' - supports-color dev: true - /@vue/compiler-core@3.2.39: - resolution: {integrity: sha512-mf/36OWXqWn0wsC40nwRRGheR/qoID+lZXbIuLnr4/AngM0ov8Xvv8GHunC0rKRIkh60bTqydlqTeBo49rlbqw==} - dependencies: - '@babel/parser': 7.22.5 - '@vue/shared': 3.2.39 - estree-walker: 2.0.2 - source-map: 0.6.1 - - /@vue/compiler-core@3.3.4: + /@vue/compiler-core/3.3.4: resolution: {integrity: sha512-cquyDNvZ6jTbf/+x+AgM2Arrp6G4Dzbb0R64jiG804HRMfRiFXWI6kqUVqZ6ZR0bQhIoQjB4+2bhNtVwndW15g==} dependencies: - '@babel/parser': 7.22.5 + '@babel/parser': 7.22.7 '@vue/shared': 3.3.4 estree-walker: 2.0.2 source-map-js: 1.0.2 - /@vue/compiler-dom@3.2.39: - resolution: {integrity: sha512-HMFI25Be1C8vLEEv1hgEO1dWwG9QQ8LTTPmCkblVJY/O3OvWx6r1+zsox5mKPMGvqYEZa6l8j+xgOfUspgo7hw==} - dependencies: - '@vue/compiler-core': 3.2.39 - '@vue/shared': 3.2.39 - - /@vue/compiler-dom@3.3.4: + /@vue/compiler-dom/3.3.4: resolution: {integrity: sha512-wyM+OjOVpuUukIq6p5+nwHYtj9cFroz9cwkfmP9O1nzH68BenTTv0u7/ndggT8cIQlnBeOo6sUT/gvHcIkLA5w==} dependencies: '@vue/compiler-core': 3.3.4 '@vue/shared': 3.3.4 - /@vue/compiler-sfc@2.7.10: - resolution: {integrity: sha512-55Shns6WPxlYsz4WX7q9ZJBL77sKE1ZAYNYStLs6GbhIOMrNtjMvzcob6gu3cGlfpCR4bT7NXgyJ3tly2+Hx8Q==} - dependencies: - '@babel/parser': 7.22.5 - postcss: 8.4.24 - source-map: 0.6.1 - - /@vue/compiler-sfc@3.2.39: - resolution: {integrity: sha512-fqAQgFs1/BxTUZkd0Vakn3teKUt//J3c420BgnYgEOoVdTwYpBTSXCMJ88GOBCylmUBbtquGPli9tVs7LzsWIA==} + /@vue/compiler-sfc/2.7.14: + resolution: {integrity: sha512-aNmNHyLPsw+sVvlQFQ2/8sjNuLtK54TC6cuKnVzAY93ks4ZBrvwQSnkkIh7bsbNhum5hJBS00wSDipQ937f5DA==} dependencies: - '@babel/parser': 7.22.5 - '@vue/compiler-core': 3.2.39 - '@vue/compiler-dom': 3.2.39 - '@vue/compiler-ssr': 3.2.39 - '@vue/reactivity-transform': 3.2.39 - '@vue/shared': 3.2.39 - estree-walker: 2.0.2 - magic-string: 0.25.9 - postcss: 8.4.24 + '@babel/parser': 7.22.7 + postcss: 8.4.25 source-map: 0.6.1 - /@vue/compiler-sfc@3.3.4: + /@vue/compiler-sfc/3.3.4: resolution: {integrity: sha512-6y/d8uw+5TkCuzBkgLS0v3lSM3hJDntFEiUORM11pQ/hKvkhSKZrXW6i69UyXlJQisJxuUEJKAWEqWbWsLeNKQ==} dependencies: - '@babel/parser': 7.22.5 + '@babel/parser': 7.22.7 '@vue/compiler-core': 3.3.4 '@vue/compiler-dom': 3.3.4 '@vue/compiler-ssr': 3.3.4 @@ -9701,95 +7929,53 @@ packages: '@vue/shared': 3.3.4 estree-walker: 2.0.2 magic-string: 0.30.1 - postcss: 8.4.24 + postcss: 8.4.25 source-map-js: 1.0.2 - /@vue/compiler-ssr@3.2.39: - resolution: {integrity: sha512-EoGCJ6lincKOZGW+0Ky4WOKsSmqL7hp1ZYgen8M7u/mlvvEQUaO9tKKOy7K43M9U2aA3tPv0TuYYQFrEbK2eFQ==} - dependencies: - '@vue/compiler-dom': 3.2.39 - '@vue/shared': 3.2.39 - - /@vue/compiler-ssr@3.3.4: + /@vue/compiler-ssr/3.3.4: resolution: {integrity: sha512-m0v6oKpup2nMSehwA6Uuu+j+wEwcy7QmwMkVNVfrV9P2qE5KshC6RwOCq8fjGS/Eak/uNb8AaWekfiXxbBB6gQ==} dependencies: '@vue/compiler-dom': 3.3.4 '@vue/shared': 3.3.4 - /@vue/devtools-api@6.5.0: + /@vue/devtools-api/6.5.0: resolution: {integrity: sha512-o9KfBeaBmCKl10usN4crU53fYtC1r7jJwdGKjPT24t348rHxgfpZ0xL3Xm/gLUYnc0oTp8LAmrxOeLyu6tbk2Q==} dev: true - /@vue/reactivity-transform@3.2.39: - resolution: {integrity: sha512-HGuWu864zStiWs9wBC6JYOP1E00UjMdDWIG5W+FpUx28hV3uz9ODOKVNm/vdOy/Pvzg8+OcANxAVC85WFBbl3A==} - dependencies: - '@babel/parser': 7.22.5 - '@vue/compiler-core': 3.2.39 - '@vue/shared': 3.2.39 - estree-walker: 2.0.2 - magic-string: 0.25.9 - - /@vue/reactivity-transform@3.3.4: + /@vue/reactivity-transform/3.3.4: resolution: {integrity: sha512-MXgwjako4nu5WFLAjpBnCj/ieqcjE2aJBINUNQzkZQfzIZA4xn+0fV1tIYBJvvva3N3OvKGofRLvQIwEQPpaXw==} dependencies: - '@babel/parser': 7.22.5 + '@babel/parser': 7.22.7 '@vue/compiler-core': 3.3.4 '@vue/shared': 3.3.4 estree-walker: 2.0.2 magic-string: 0.30.1 - /@vue/reactivity@3.2.38: + /@vue/reactivity/3.2.38: resolution: {integrity: sha512-6L4myYcH9HG2M25co7/BSo0skKFHpAN8PhkNPM4xRVkyGl1K5M3Jx4rp5bsYhvYze2K4+l+pioN4e6ZwFLUVtw==} dependencies: '@vue/shared': 3.2.38 dev: true - /@vue/reactivity@3.2.39: - resolution: {integrity: sha512-vlaYX2a3qMhIZfrw3Mtfd+BuU+TZmvDrPMa+6lpfzS9k/LnGxkSuf0fhkP0rMGfiOHPtyKoU9OJJJFGm92beVQ==} - dependencies: - '@vue/shared': 3.2.39 - - /@vue/reactivity@3.3.4: + /@vue/reactivity/3.3.4: resolution: {integrity: sha512-kLTDLwd0B1jG08NBF3R5rqULtv/f8x3rOFByTDz4J53ttIQEDmALqKqXY0J+XQeN0aV2FBxY8nJDf88yvOPAqQ==} dependencies: '@vue/shared': 3.3.4 - /@vue/runtime-core@3.2.39: - resolution: {integrity: sha512-xKH5XP57JW5JW+8ZG1khBbuLakINTgPuINKL01hStWLTTGFOrM49UfCFXBcFvWmSbci3gmJyLl2EAzCaZWsx8g==} - dependencies: - '@vue/reactivity': 3.2.39 - '@vue/shared': 3.2.39 - - /@vue/runtime-core@3.3.4: + /@vue/runtime-core/3.3.4: resolution: {integrity: sha512-R+bqxMN6pWO7zGI4OMlmvePOdP2c93GsHFM/siJI7O2nxFRzj55pLwkpCedEY+bTMgp5miZ8CxfIZo3S+gFqvA==} dependencies: '@vue/reactivity': 3.3.4 '@vue/shared': 3.3.4 - /@vue/runtime-dom@3.2.39: - resolution: {integrity: sha512-4G9AEJP+sLhsqf5wXcyKVWQKUhI+iWfy0hWQgea+CpaTD7BR0KdQzvoQdZhwCY6B3oleSyNLkLAQwm0ya/wNoA==} - dependencies: - '@vue/runtime-core': 3.2.39 - '@vue/shared': 3.2.39 - csstype: 2.6.20 - - /@vue/runtime-dom@3.3.4: + /@vue/runtime-dom/3.3.4: resolution: {integrity: sha512-Aj5bTJ3u5sFsUckRghsNjVTtxZQ1OyMWCr5dZRAPijF/0Vy4xEoRCwLyHXcj4D0UFbJ4lbx3gPTgg06K/GnPnQ==} dependencies: '@vue/runtime-core': 3.3.4 '@vue/shared': 3.3.4 csstype: 3.1.2 - /@vue/server-renderer@3.2.39(vue@3.2.39): - resolution: {integrity: sha512-1yn9u2YBQWIgytFMjz4f/t0j43awKytTGVptfd3FtBk76t1pd8mxbek0G/DrnjJhd2V7mSTb5qgnxMYt8Z5iSQ==} - peerDependencies: - vue: 3.2.39 - dependencies: - '@vue/compiler-ssr': 3.2.39 - '@vue/shared': 3.2.39 - vue: 3.2.39 - - /@vue/server-renderer@3.3.4(vue@3.3.4): + /@vue/server-renderer/3.3.4_vue@3.3.4: resolution: {integrity: sha512-Q6jDDzR23ViIb67v+vM1Dqntu+HUexQcsWKhhQa4ARVzxOY2HbC7QRW/ggkDBd5BU+uM1sV6XOAP0b216o34JQ==} peerDependencies: vue: 3.3.4 @@ -9798,18 +7984,15 @@ packages: '@vue/shared': 3.3.4 vue: 3.3.4 - /@vue/shared@3.2.38: + /@vue/shared/3.2.38: resolution: {integrity: sha512-dTyhTIRmGXBjxJE+skC8tTWCGLCVc4wQgRRLt8+O9p5ewBAjoBwtCAkLPrtToSr1xltoe3st21Pv953aOZ7alg==} dev: true - /@vue/shared@3.2.39: - resolution: {integrity: sha512-D3dl2ZB9qE6mTuWPk9RlhDeP1dgNRUKC3NJxji74A4yL8M2MwlhLKUC/49WHjrNzSPug58fWx/yFbaTzGAQSBw==} - - /@vue/shared@3.3.4: + /@vue/shared/3.3.4: resolution: {integrity: sha512-7OjdcV8vQ74eiz1TZLzZP4JwqM5fA94K6yntPS5Z25r9HDuGNzaGdgvwKYq6S+MxwF0TFRwe50fIR/MYnakdkQ==} - /@vue/test-utils@1.3.0(vue-template-compiler@2.7.10)(vue@2.7.10): - resolution: {integrity: sha512-Xk2Xiyj2k5dFb8eYUKkcN9PzqZSppTlx7LaQWBbdA8tqh3jHr/KHX2/YLhNFc/xwDrgeLybqd+4ZCPJSGPIqeA==} + /@vue/test-utils/1.3.6_rhqkolmkwunxzlyyxxsuwaiuri: + resolution: {integrity: sha512-udMmmF1ts3zwxUJEIAj5ziioR900reDrt6C9H3XpWPsLBx2lpHKoA4BTdd9HNIYbkGltWw+JjWJ+5O6QBwiyEw==} peerDependencies: vue: 2.x vue-template-compiler: ^2.x @@ -9817,50 +8000,39 @@ packages: dom-event-types: 1.1.0 lodash: 4.17.21 pretty: 2.0.0 - vue: 2.7.10 - vue-template-compiler: 2.7.10 - dev: true - - /@vue/test-utils@2.0.0(vue@3.3.4): - resolution: {integrity: sha512-zL5kygNq7hONrO1CzaUGprEAklAX+pH8J1MPMCU3Rd2xtSYkZ+PmKU3oEDRg8VAGdL5lNJHzDgrud5amFPtirw==} - peerDependencies: - vue: ^3.0.1 - dependencies: - vue: 3.3.4 + vue: 2.7.14 + vue-template-compiler: 2.7.14 dev: true - /@vue/test-utils@2.0.2(vue@3.3.4): - resolution: {integrity: sha512-E2P4oXSaWDqTZNbmKZFVLrNN/siVN78YkEqs7pHryWerrlZR9bBFLWdJwRoguX45Ru6HxIflzKl4vQvwRMwm5g==} - peerDependencies: - vue: ^3.0.1 - dependencies: - vue: 3.3.4 - dev: true - - /@vue/test-utils@2.3.2(vue@3.3.4): - resolution: {integrity: sha512-hJnVaYhbrIm0yBS0+e1Y0Sj85cMyAi+PAbK4JHqMRUZ6S622Goa+G7QzkRSyvCteG8wop7tipuEbHoZo26wsSA==} + /@vue/test-utils/2.4.0_vue@3.3.4: + resolution: {integrity: sha512-BKB9aj1yky63/I3IwSr1FjUeHYsKXI7D6S9F378AHt7a5vC0dLkOBtSsFXoRGC/7BfHmiB9HRhT+i9xrUHoAKw==} peerDependencies: + '@vue/compiler-dom': ^3.0.1 + '@vue/server-renderer': ^3.0.1 vue: ^3.0.1 + peerDependenciesMeta: + '@vue/compiler-dom': + optional: true + '@vue/server-renderer': + optional: true dependencies: js-beautify: 1.14.6 vue: 3.3.4 - optionalDependencies: - '@vue/compiler-dom': 3.3.4 - '@vue/server-renderer': 3.3.4(vue@3.3.4) + vue-component-type-helpers: 1.6.5 dev: true - /@vueuse/core@10.2.1(vue@3.3.4): + /@vueuse/core/10.2.1_vue@3.3.4: resolution: {integrity: sha512-c441bfMbkAwTNwVRHQ0zdYZNETK//P84rC01aP2Uy/aRFCiie9NE/k9KdIXbno0eDYP5NPUuWv0aA/I4Unr/7w==} dependencies: '@types/web-bluetooth': 0.0.17 '@vueuse/metadata': 10.2.1 - '@vueuse/shared': 10.2.1(vue@3.3.4) - vue-demi: 0.14.5(vue@3.3.4) + '@vueuse/shared': 10.2.1_vue@3.3.4 + vue-demi: 0.14.5_vue@3.3.4 transitivePeerDependencies: - '@vue/composition-api' - vue - /@vueuse/core@8.9.4(vue@3.2.39): + /@vueuse/core/8.9.4_vue@3.3.4: resolution: {integrity: sha512-B/Mdj9TK1peFyWaPof+Zf/mP9XuGAngaJZBwPaXBvU3aCTZlx3ltlrFFFyMV4iGBwsjSCeUCgZrtkEj9dS2Y3Q==} peerDependencies: '@vue/composition-api': ^1.1.0 @@ -9873,12 +8045,12 @@ packages: dependencies: '@types/web-bluetooth': 0.0.14 '@vueuse/metadata': 8.9.4 - '@vueuse/shared': 8.9.4(vue@3.2.39) - vue: 3.2.39 - vue-demi: 0.14.0(vue@3.2.39) + '@vueuse/shared': 8.9.4_vue@3.3.4 + vue: 3.3.4 + vue-demi: 0.14.5_vue@3.3.4 dev: false - /@vueuse/integrations@10.2.1(focus-trap@7.4.3)(vue@3.3.4): + /@vueuse/integrations/10.2.1_focus-trap@7.5.2+vue@3.3.4: resolution: {integrity: sha512-FDP5lni+z9FjHE9H3xuvwSjoRV9U8jmDvJpmHPCBjUgPGYRynwb60eHWXCFJXLUtb4gSIHy0e+iaEbrKdalCkQ==} peerDependencies: async-validator: '*' @@ -9919,16 +8091,16 @@ packages: universal-cookie: optional: true dependencies: - '@vueuse/core': 10.2.1(vue@3.3.4) - '@vueuse/shared': 10.2.1(vue@3.3.4) - focus-trap: 7.4.3 - vue-demi: 0.14.5(vue@3.3.4) + '@vueuse/core': 10.2.1_vue@3.3.4 + '@vueuse/shared': 10.2.1_vue@3.3.4 + focus-trap: 7.5.2 + vue-demi: 0.14.5_vue@3.3.4 transitivePeerDependencies: - '@vue/composition-api' - vue dev: true - /@vueuse/integrations@8.9.4(axios@0.26.1)(vue@3.2.39): + /@vueuse/integrations/8.9.4_axios@0.26.1+vue@3.3.4: resolution: {integrity: sha512-Nk7mH0ThTdiuiiuB+1lyC+5ihnywrr+9h9IA4R4Ry8Mli/cZL38zc3qZWIsCVPm66Lr+7kEp3nnHdSxKi7ivrg==} peerDependencies: async-validator: '*' @@ -9963,31 +8135,31 @@ packages: universal-cookie: optional: true dependencies: - '@vueuse/core': 8.9.4(vue@3.2.39) - '@vueuse/shared': 8.9.4(vue@3.2.39) + '@vueuse/core': 8.9.4_vue@3.3.4 + '@vueuse/shared': 8.9.4_vue@3.3.4 axios: 0.26.1 - vue-demi: 0.13.11(vue@3.2.39) + vue-demi: 0.14.5_vue@3.3.4 transitivePeerDependencies: - '@vue/composition-api' - vue dev: false - /@vueuse/metadata@10.2.1: + /@vueuse/metadata/10.2.1: resolution: {integrity: sha512-3Gt68mY/i6bQvFqx7cuGBzrCCQu17OBaGWS5JdwISpMsHnMKKjC2FeB5OAfMcCQ0oINfADP3i9A4PPRo0peHdQ==} - /@vueuse/metadata@8.9.4: + /@vueuse/metadata/8.9.4: resolution: {integrity: sha512-IwSfzH80bnJMzqhaapqJl9JRIiyQU0zsRGEgnxN6jhq7992cPUJIRfV+JHRIZXjYqbwt07E1gTEp0R0zPJ1aqw==} dev: false - /@vueuse/shared@10.2.1(vue@3.3.4): + /@vueuse/shared/10.2.1_vue@3.3.4: resolution: {integrity: sha512-QWHq2bSuGptkcxx4f4M/fBYC3Y8d3M2UYyLsyzoPgEoVzJURQ0oJeWXu79OiLlBb8gTKkqe4mO85T/sf39mmiw==} dependencies: - vue-demi: 0.14.5(vue@3.3.4) + vue-demi: 0.14.5_vue@3.3.4 transitivePeerDependencies: - '@vue/composition-api' - vue - /@vueuse/shared@8.9.4(vue@3.2.39): + /@vueuse/shared/8.9.4_vue@3.3.4: resolution: {integrity: sha512-wt+T30c4K6dGRMVqPddexEVLa28YwxW5OFIPmzUHICjphfAuBFTTdDoyqREZNDOFJZ44ARH1WWQNCUK8koJ+Ag==} peerDependencies: '@vue/composition-api': ^1.1.0 @@ -9998,11 +8170,11 @@ packages: vue: optional: true dependencies: - vue: 3.2.39 - vue-demi: 0.14.0(vue@3.2.39) + vue: 3.3.4 + vue-demi: 0.14.5_vue@3.3.4 dev: false - /@wdio/config@8.12.1: + /@wdio/config/8.12.1: resolution: {integrity: sha512-6DfTU+5Ugg6HKMSqVNCLEgdFd7l+QnaMoDe2/tZ8zoYNdJlFu0NfClXLL4qnTCCjebmz3eu0/O+aRPJyxo6GGQ==} engines: {node: ^16.13 || >=18} dependencies: @@ -10010,41 +8182,41 @@ packages: '@wdio/types': 8.10.4 '@wdio/utils': 8.12.1 decamelize: 6.0.0 - deepmerge-ts: 5.0.0 - glob: 10.2.7 + deepmerge-ts: 5.1.0 + glob: 10.3.3 import-meta-resolve: 3.0.0 read-pkg-up: 9.1.0 dev: true - /@wdio/logger@8.11.0: + /@wdio/logger/8.11.0: resolution: {integrity: sha512-IsuKSaYi7NKEdgA57h8muzlN/MVp1dQG+V4C//7g4m03YJUnNQLvDhJzLjdeNTfvZy61U7foQSyt+3ktNzZkXA==} engines: {node: ^16.13 || >=18} dependencies: - chalk: 5.2.0 + chalk: 5.3.0 loglevel: 1.8.1 loglevel-plugin-prefix: 0.8.4 strip-ansi: 7.1.0 dev: true - /@wdio/protocols@8.11.0: + /@wdio/protocols/8.11.0: resolution: {integrity: sha512-eXTMYt/XoaX53H/Q2qmsn1uWthIC5aSTGtX9YyXD/AkagG2hXeX3lLmzNWBaSIvKR+vWXRYbg3Y/7IvL2s25Wg==} dev: true - /@wdio/repl@8.10.1: + /@wdio/repl/8.10.1: resolution: {integrity: sha512-VZ1WFHTNKjR8Ga97TtV2SZM6fvRjWbYI2i/f4pJB4PtusorKvONAMJf2LQcUBIyzbVobqr7KSrcjmSwRolI+yw==} engines: {node: ^16.13 || >=18} dependencies: '@types/node': 20.4.1 dev: true - /@wdio/types@8.10.4: + /@wdio/types/8.10.4: resolution: {integrity: sha512-aLJ1QQW+hhALeRK3bvMLjIrlUVyhOs3Od+91pR4Z4pLwyeNG1bJZCJRD5bAJK/mm7CnFa0NsdixPS9jJxZcRrw==} engines: {node: ^16.13 || >=18} dependencies: '@types/node': 20.4.1 dev: true - /@wdio/utils@8.12.1: + /@wdio/utils/8.12.1: resolution: {integrity: sha512-VmF6O++84FTH3AKaVFyqn0MJA65/1G6dbm6p61KBqkD25LxaWo4398lCCbt264hzBIobtXRZoQ87bSxdfnlUKQ==} engines: {node: ^16.13 || >=18} dependencies: @@ -10054,14 +8226,14 @@ packages: p-iteration: 1.1.8 dev: true - /@webassemblyjs/ast@1.11.1: - resolution: {integrity: sha512-ukBh14qFLjxTQNTXocdyksN5QdM28S1CxHt2rdskFyL+xFV7VremuBLVbmCePj+URalXBENx/9Lm7lnhihtCSw==} + /@webassemblyjs/ast/1.11.6: + resolution: {integrity: sha512-IN1xI7PwOvLPgjcf180gC1bqn3q/QaOCwYUahIOhbYUu8KA/3tw2RT/T0Gidi1l7Hhj5D/INhJxiICObqpMu4Q==} dependencies: - '@webassemblyjs/helper-numbers': 1.11.1 - '@webassemblyjs/helper-wasm-bytecode': 1.11.1 + '@webassemblyjs/helper-numbers': 1.11.6 + '@webassemblyjs/helper-wasm-bytecode': 1.11.6 dev: true - /@webassemblyjs/ast@1.9.0: + /@webassemblyjs/ast/1.9.0: resolution: {integrity: sha512-C6wW5L+b7ogSDVqymbkkvuW9kruN//YisMED04xzeBBqjHa2FYnmvOlS6Xj68xWQRgWvI9cIglsjFowH/RJyEA==} dependencies: '@webassemblyjs/helper-module-context': 1.9.0 @@ -10069,72 +8241,72 @@ packages: '@webassemblyjs/wast-parser': 1.9.0 dev: true - /@webassemblyjs/floating-point-hex-parser@1.11.1: - resolution: {integrity: sha512-iGRfyc5Bq+NnNuX8b5hwBrRjzf0ocrJPI6GWFodBFzmFnyvrQ83SHKhmilCU/8Jv67i4GJZBMhEzltxzcNagtQ==} + /@webassemblyjs/floating-point-hex-parser/1.11.6: + resolution: {integrity: sha512-ejAj9hfRJ2XMsNHk/v6Fu2dGS+i4UaXBXGemOfQ/JfQ6mdQg/WXtwleQRLLS4OvfDhv8rYnVwH27YJLMyYsxhw==} dev: true - /@webassemblyjs/floating-point-hex-parser@1.9.0: + /@webassemblyjs/floating-point-hex-parser/1.9.0: resolution: {integrity: sha512-TG5qcFsS8QB4g4MhrxK5TqfdNe7Ey/7YL/xN+36rRjl/BlGE/NcBvJcqsRgCP6Z92mRE+7N50pRIi8SmKUbcQA==} dev: true - /@webassemblyjs/helper-api-error@1.11.1: - resolution: {integrity: sha512-RlhS8CBCXfRUR/cwo2ho9bkheSXG0+NwooXcc3PAILALf2QLdFyj7KGsKRbVc95hZnhnERon4kW/D3SZpp6Tcg==} + /@webassemblyjs/helper-api-error/1.11.6: + resolution: {integrity: sha512-o0YkoP4pVu4rN8aTJgAyj9hC2Sv5UlkzCHhxqWj8butaLvnpdc2jOwh4ewE6CX0txSfLn/UYaV/pheS2Txg//Q==} dev: true - /@webassemblyjs/helper-api-error@1.9.0: + /@webassemblyjs/helper-api-error/1.9.0: resolution: {integrity: sha512-NcMLjoFMXpsASZFxJ5h2HZRcEhDkvnNFOAKneP5RbKRzaWJN36NC4jqQHKwStIhGXu5mUWlUUk7ygdtrO8lbmw==} dev: true - /@webassemblyjs/helper-buffer@1.11.1: - resolution: {integrity: sha512-gwikF65aDNeeXa8JxXa2BAk+REjSyhrNC9ZwdT0f8jc4dQQeDQ7G4m0f2QCLPJiMTTO6wfDmRmj/pW0PsUvIcA==} + /@webassemblyjs/helper-buffer/1.11.6: + resolution: {integrity: sha512-z3nFzdcp1mb8nEOFFk8DrYLpHvhKC3grJD2ardfKOzmbmJvEf/tPIqCY+sNcwZIY8ZD7IkB2l7/pqhUhqm7hLA==} dev: true - /@webassemblyjs/helper-buffer@1.9.0: + /@webassemblyjs/helper-buffer/1.9.0: resolution: {integrity: sha512-qZol43oqhq6yBPx7YM3m9Bv7WMV9Eevj6kMi6InKOuZxhw+q9hOkvq5e/PpKSiLfyetpaBnogSbNCfBwyB00CA==} dev: true - /@webassemblyjs/helper-code-frame@1.9.0: + /@webassemblyjs/helper-code-frame/1.9.0: resolution: {integrity: sha512-ERCYdJBkD9Vu4vtjUYe8LZruWuNIToYq/ME22igL+2vj2dQ2OOujIZr3MEFvfEaqKoVqpsFKAGsRdBSBjrIvZA==} dependencies: '@webassemblyjs/wast-printer': 1.9.0 dev: true - /@webassemblyjs/helper-fsm@1.9.0: + /@webassemblyjs/helper-fsm/1.9.0: resolution: {integrity: sha512-OPRowhGbshCb5PxJ8LocpdX9Kl0uB4XsAjl6jH/dWKlk/mzsANvhwbiULsaiqT5GZGT9qinTICdj6PLuM5gslw==} dev: true - /@webassemblyjs/helper-module-context@1.9.0: + /@webassemblyjs/helper-module-context/1.9.0: resolution: {integrity: sha512-MJCW8iGC08tMk2enck1aPW+BE5Cw8/7ph/VGZxwyvGbJwjktKkDK7vy7gAmMDx88D7mhDTCNKAW5tED+gZ0W8g==} dependencies: '@webassemblyjs/ast': 1.9.0 dev: true - /@webassemblyjs/helper-numbers@1.11.1: - resolution: {integrity: sha512-vDkbxiB8zfnPdNK9Rajcey5C0w+QJugEglN0of+kmO8l7lDb77AnlKYQF7aarZuCrv+l0UvqL+68gSDr3k9LPQ==} + /@webassemblyjs/helper-numbers/1.11.6: + resolution: {integrity: sha512-vUIhZ8LZoIWHBohiEObxVm6hwP034jwmc9kuq5GdHZH0wiLVLIPcMCdpJzG4C11cHoQ25TFIQj9kaVADVX7N3g==} dependencies: - '@webassemblyjs/floating-point-hex-parser': 1.11.1 - '@webassemblyjs/helper-api-error': 1.11.1 + '@webassemblyjs/floating-point-hex-parser': 1.11.6 + '@webassemblyjs/helper-api-error': 1.11.6 '@xtuc/long': 4.2.2 dev: true - /@webassemblyjs/helper-wasm-bytecode@1.11.1: - resolution: {integrity: sha512-PvpoOGiJwXeTrSf/qfudJhwlvDQxFgelbMqtq52WWiXC6Xgg1IREdngmPN3bs4RoO83PnL/nFrxucXj1+BX62Q==} + /@webassemblyjs/helper-wasm-bytecode/1.11.6: + resolution: {integrity: sha512-sFFHKwcmBprO9e7Icf0+gddyWYDViL8bpPjJJl0WHxCdETktXdmtWLGVzoHbqUcY4Be1LkNfwTmXOJUFZYSJdA==} dev: true - /@webassemblyjs/helper-wasm-bytecode@1.9.0: + /@webassemblyjs/helper-wasm-bytecode/1.9.0: resolution: {integrity: sha512-R7FStIzyNcd7xKxCZH5lE0Bqy+hGTwS3LJjuv1ZVxd9O7eHCedSdrId/hMOd20I+v8wDXEn+bjfKDLzTepoaUw==} dev: true - /@webassemblyjs/helper-wasm-section@1.11.1: - resolution: {integrity: sha512-10P9No29rYX1j7F3EVPX3JvGPQPae+AomuSTPiF9eBQeChHI6iqjMIwR9JmOJXwpnn/oVGDk7I5IlskuMwU/pg==} + /@webassemblyjs/helper-wasm-section/1.11.6: + resolution: {integrity: sha512-LPpZbSOwTpEC2cgn4hTydySy1Ke+XEu+ETXuoyvuyezHO3Kjdu90KK95Sh9xTbmjrCsUwvWwCOQQNta37VrS9g==} dependencies: - '@webassemblyjs/ast': 1.11.1 - '@webassemblyjs/helper-buffer': 1.11.1 - '@webassemblyjs/helper-wasm-bytecode': 1.11.1 - '@webassemblyjs/wasm-gen': 1.11.1 + '@webassemblyjs/ast': 1.11.6 + '@webassemblyjs/helper-buffer': 1.11.6 + '@webassemblyjs/helper-wasm-bytecode': 1.11.6 + '@webassemblyjs/wasm-gen': 1.11.6 dev: true - /@webassemblyjs/helper-wasm-section@1.9.0: + /@webassemblyjs/helper-wasm-section/1.9.0: resolution: {integrity: sha512-XnMB8l3ek4tvrKUUku+IVaXNHz2YsJyOOmz+MMkZvh8h1uSJpSen6vYnw3IoQ7WwEuAhL8Efjms1ZWjqh2agvw==} dependencies: '@webassemblyjs/ast': 1.9.0 @@ -10143,52 +8315,52 @@ packages: '@webassemblyjs/wasm-gen': 1.9.0 dev: true - /@webassemblyjs/ieee754@1.11.1: - resolution: {integrity: sha512-hJ87QIPtAMKbFq6CGTkZYJivEwZDbQUgYd3qKSadTNOhVY7p+gfP6Sr0lLRVTaG1JjFj+r3YchoqRYxNH3M0GQ==} + /@webassemblyjs/ieee754/1.11.6: + resolution: {integrity: sha512-LM4p2csPNvbij6U1f19v6WR56QZ8JcHg3QIJTlSwzFcmx6WSORicYj6I63f9yU1kEUtrpG+kjkiIAkevHpDXrg==} dependencies: '@xtuc/ieee754': 1.2.0 dev: true - /@webassemblyjs/ieee754@1.9.0: + /@webassemblyjs/ieee754/1.9.0: resolution: {integrity: sha512-dcX8JuYU/gvymzIHc9DgxTzUUTLexWwt8uCTWP3otys596io0L5aW02Gb1RjYpx2+0Jus1h4ZFqjla7umFniTg==} dependencies: '@xtuc/ieee754': 1.2.0 dev: true - /@webassemblyjs/leb128@1.11.1: - resolution: {integrity: sha512-BJ2P0hNZ0u+Th1YZXJpzW6miwqQUGcIHT1G/sf72gLVD9DZ5AdYTqPNbHZh6K1M5VmKvFXwGSWZADz+qBWxeRw==} + /@webassemblyjs/leb128/1.11.6: + resolution: {integrity: sha512-m7a0FhE67DQXgouf1tbN5XQcdWoNgaAuoULHIfGFIEVKA6tu/edls6XnIlkmS6FrXAquJRPni3ZZKjw6FSPjPQ==} dependencies: '@xtuc/long': 4.2.2 dev: true - /@webassemblyjs/leb128@1.9.0: + /@webassemblyjs/leb128/1.9.0: resolution: {integrity: sha512-ENVzM5VwV1ojs9jam6vPys97B/S65YQtv/aanqnU7D8aSoHFX8GyhGg0CMfyKNIHBuAVjy3tlzd5QMMINa7wpw==} dependencies: '@xtuc/long': 4.2.2 dev: true - /@webassemblyjs/utf8@1.11.1: - resolution: {integrity: sha512-9kqcxAEdMhiwQkHpkNiorZzqpGrodQQ2IGrHHxCy+Ozng0ofyMA0lTqiLkVs1uzTRejX+/O0EOT7KxqVPuXosQ==} + /@webassemblyjs/utf8/1.11.6: + resolution: {integrity: sha512-vtXf2wTQ3+up9Zsg8sa2yWiQpzSsMyXj0qViVP6xKGCUT8p8YJ6HqI7l5eCnWx1T/FYdsv07HQs2wTFbbof/RA==} dev: true - /@webassemblyjs/utf8@1.9.0: + /@webassemblyjs/utf8/1.9.0: resolution: {integrity: sha512-GZbQlWtopBTP0u7cHrEx+73yZKrQoBMpwkGEIqlacljhXCkVM1kMQge/Mf+csMJAjEdSwhOyLAS0AoR3AG5P8w==} dev: true - /@webassemblyjs/wasm-edit@1.11.1: - resolution: {integrity: sha512-g+RsupUC1aTHfR8CDgnsVRVZFJqdkFHpsHMfJuWQzWU3tvnLC07UqHICfP+4XyL2tnr1amvl1Sdp06TnYCmVkA==} + /@webassemblyjs/wasm-edit/1.11.6: + resolution: {integrity: sha512-Ybn2I6fnfIGuCR+Faaz7YcvtBKxvoLV3Lebn1tM4o/IAJzmi9AWYIPWpyBfU8cC+JxAO57bk4+zdsTjJR+VTOw==} dependencies: - '@webassemblyjs/ast': 1.11.1 - '@webassemblyjs/helper-buffer': 1.11.1 - '@webassemblyjs/helper-wasm-bytecode': 1.11.1 - '@webassemblyjs/helper-wasm-section': 1.11.1 - '@webassemblyjs/wasm-gen': 1.11.1 - '@webassemblyjs/wasm-opt': 1.11.1 - '@webassemblyjs/wasm-parser': 1.11.1 - '@webassemblyjs/wast-printer': 1.11.1 + '@webassemblyjs/ast': 1.11.6 + '@webassemblyjs/helper-buffer': 1.11.6 + '@webassemblyjs/helper-wasm-bytecode': 1.11.6 + '@webassemblyjs/helper-wasm-section': 1.11.6 + '@webassemblyjs/wasm-gen': 1.11.6 + '@webassemblyjs/wasm-opt': 1.11.6 + '@webassemblyjs/wasm-parser': 1.11.6 + '@webassemblyjs/wast-printer': 1.11.6 dev: true - /@webassemblyjs/wasm-edit@1.9.0: + /@webassemblyjs/wasm-edit/1.9.0: resolution: {integrity: sha512-FgHzBm80uwz5M8WKnMTn6j/sVbqilPdQXTWraSjBwFXSYGirpkSWE2R9Qvz9tNiTKQvoKILpCuTjBKzOIm0nxw==} dependencies: '@webassemblyjs/ast': 1.9.0 @@ -10201,17 +8373,17 @@ packages: '@webassemblyjs/wast-printer': 1.9.0 dev: true - /@webassemblyjs/wasm-gen@1.11.1: - resolution: {integrity: sha512-F7QqKXwwNlMmsulj6+O7r4mmtAlCWfO/0HdgOxSklZfQcDu0TpLiD1mRt/zF25Bk59FIjEuGAIyn5ei4yMfLhA==} + /@webassemblyjs/wasm-gen/1.11.6: + resolution: {integrity: sha512-3XOqkZP/y6B4F0PBAXvI1/bky7GryoogUtfwExeP/v7Nzwo1QLcq5oQmpKlftZLbT+ERUOAZVQjuNVak6UXjPA==} dependencies: - '@webassemblyjs/ast': 1.11.1 - '@webassemblyjs/helper-wasm-bytecode': 1.11.1 - '@webassemblyjs/ieee754': 1.11.1 - '@webassemblyjs/leb128': 1.11.1 - '@webassemblyjs/utf8': 1.11.1 + '@webassemblyjs/ast': 1.11.6 + '@webassemblyjs/helper-wasm-bytecode': 1.11.6 + '@webassemblyjs/ieee754': 1.11.6 + '@webassemblyjs/leb128': 1.11.6 + '@webassemblyjs/utf8': 1.11.6 dev: true - /@webassemblyjs/wasm-gen@1.9.0: + /@webassemblyjs/wasm-gen/1.9.0: resolution: {integrity: sha512-cPE3o44YzOOHvlsb4+E9qSqjc9Qf9Na1OO/BHFy4OI91XDE14MjFN4lTMezzaIWdPqHnsTodGGNP+iRSYfGkjA==} dependencies: '@webassemblyjs/ast': 1.9.0 @@ -10221,16 +8393,16 @@ packages: '@webassemblyjs/utf8': 1.9.0 dev: true - /@webassemblyjs/wasm-opt@1.11.1: - resolution: {integrity: sha512-VqnkNqnZlU5EB64pp1l7hdm3hmQw7Vgqa0KF/KCNO9sIpI6Fk6brDEiX+iCOYrvMuBWDws0NkTOxYEb85XQHHw==} + /@webassemblyjs/wasm-opt/1.11.6: + resolution: {integrity: sha512-cOrKuLRE7PCe6AsOVl7WasYf3wbSo4CeOk6PkrjS7g57MFfVUF9u6ysQBBODX0LdgSvQqRiGz3CXvIDKcPNy4g==} dependencies: - '@webassemblyjs/ast': 1.11.1 - '@webassemblyjs/helper-buffer': 1.11.1 - '@webassemblyjs/wasm-gen': 1.11.1 - '@webassemblyjs/wasm-parser': 1.11.1 + '@webassemblyjs/ast': 1.11.6 + '@webassemblyjs/helper-buffer': 1.11.6 + '@webassemblyjs/wasm-gen': 1.11.6 + '@webassemblyjs/wasm-parser': 1.11.6 dev: true - /@webassemblyjs/wasm-opt@1.9.0: + /@webassemblyjs/wasm-opt/1.9.0: resolution: {integrity: sha512-Qkjgm6Anhm+OMbIL0iokO7meajkzQD71ioelnfPEj6r4eOFuqm4YC3VBPqXjFyyNwowzbMD+hizmprP/Fwkl2A==} dependencies: '@webassemblyjs/ast': 1.9.0 @@ -10239,18 +8411,18 @@ packages: '@webassemblyjs/wasm-parser': 1.9.0 dev: true - /@webassemblyjs/wasm-parser@1.11.1: - resolution: {integrity: sha512-rrBujw+dJu32gYB7/Lup6UhdkPx9S9SnobZzRVL7VcBH9Bt9bCBLEuX/YXOOtBsOZ4NQrRykKhffRWHvigQvOA==} + /@webassemblyjs/wasm-parser/1.11.6: + resolution: {integrity: sha512-6ZwPeGzMJM3Dqp3hCsLgESxBGtT/OeCvCZ4TA1JUPYgmhAx38tTPR9JaKy0S5H3evQpO/h2uWs2j6Yc/fjkpTQ==} dependencies: - '@webassemblyjs/ast': 1.11.1 - '@webassemblyjs/helper-api-error': 1.11.1 - '@webassemblyjs/helper-wasm-bytecode': 1.11.1 - '@webassemblyjs/ieee754': 1.11.1 - '@webassemblyjs/leb128': 1.11.1 - '@webassemblyjs/utf8': 1.11.1 + '@webassemblyjs/ast': 1.11.6 + '@webassemblyjs/helper-api-error': 1.11.6 + '@webassemblyjs/helper-wasm-bytecode': 1.11.6 + '@webassemblyjs/ieee754': 1.11.6 + '@webassemblyjs/leb128': 1.11.6 + '@webassemblyjs/utf8': 1.11.6 dev: true - /@webassemblyjs/wasm-parser@1.9.0: + /@webassemblyjs/wasm-parser/1.9.0: resolution: {integrity: sha512-9+wkMowR2AmdSWQzsPEjFU7njh8HTO5MqO8vjwEHuM+AMHioNqSBONRdr0NQQ3dVQrzp0s8lTcYqzUdb7YgELA==} dependencies: '@webassemblyjs/ast': 1.9.0 @@ -10261,7 +8433,7 @@ packages: '@webassemblyjs/utf8': 1.9.0 dev: true - /@webassemblyjs/wast-parser@1.9.0: + /@webassemblyjs/wast-parser/1.9.0: resolution: {integrity: sha512-qsqSAP3QQ3LyZjNC/0jBJ/ToSxfYJ8kYyuiGvtn/8MK89VrNEfwj7BPQzJVHi0jGTRK2dGdJ5PRqhtjzoww+bw==} dependencies: '@webassemblyjs/ast': 1.9.0 @@ -10272,14 +8444,14 @@ packages: '@xtuc/long': 4.2.2 dev: true - /@webassemblyjs/wast-printer@1.11.1: - resolution: {integrity: sha512-IQboUWM4eKzWW+N/jij2sRatKMh99QEelo3Eb2q0qXkvPRISAj8Qxtmw5itwqK+TTkBuUIE45AxYPToqPtL5gg==} + /@webassemblyjs/wast-printer/1.11.6: + resolution: {integrity: sha512-JM7AhRcE+yW2GWYaKeHL5vt4xqee5N2WcezptmgyhNS+ScggqcT1OtXykhAb13Sn5Yas0j2uv9tHgrjwvzAP4A==} dependencies: - '@webassemblyjs/ast': 1.11.1 + '@webassemblyjs/ast': 1.11.6 '@xtuc/long': 4.2.2 dev: true - /@webassemblyjs/wast-printer@1.9.0: + /@webassemblyjs/wast-printer/1.9.0: resolution: {integrity: sha512-2J0nE95rHXHyQ24cWjMKJ1tqB/ds8z/cyeOZxJhcb+rW+SQASVjuznUSmdz5GpVJTzU8JkhYut0D3siFDD6wsA==} dependencies: '@webassemblyjs/ast': 1.9.0 @@ -10287,100 +8459,107 @@ packages: '@xtuc/long': 4.2.2 dev: true - /@wojtekmaj/enzyme-adapter-react-17@0.6.7(enzyme@3.11.0)(react-dom@17.0.2)(react@17.0.2): + /@wojtekmaj/enzyme-adapter-react-17/0.6.7_7ltvq4e2railvf5uya4ffxpe2a: resolution: {integrity: sha512-B+byiwi/T1bx5hcj9wc0fUL5Hlb5giSXJzcnEfJVl2j6dGV2NJfcxDBYX0WWwIxlzNiFz8kAvlkFWI2y/nscZQ==} peerDependencies: enzyme: ^3.0.0 react: ^17.0.0-0 react-dom: ^17.0.0-0 dependencies: - '@wojtekmaj/enzyme-adapter-utils': 0.1.4(react@17.0.2) + '@wojtekmaj/enzyme-adapter-utils': 0.1.4_react@17.0.2 enzyme: 3.11.0 - enzyme-shallow-equal: 1.0.4 + enzyme-shallow-equal: 1.0.5 has: 1.0.3 prop-types: 15.8.1 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 react-is: 17.0.2 - react-test-renderer: 17.0.2(react@17.0.2) + react-test-renderer: 17.0.2_react@17.0.2 dev: true - /@wojtekmaj/enzyme-adapter-utils@0.1.4(react@17.0.2): + /@wojtekmaj/enzyme-adapter-utils/0.1.4_react@17.0.2: resolution: {integrity: sha512-ARGIQSIIv3oBia1m5Ihn1VU0FGmft6KPe39SBKTb8p7LSXO23YI4kNtc4M/cKoIY7P+IYdrZcgMObvedyjoSQA==} peerDependencies: react: ^17.0.0-0 dependencies: function.prototype.name: 1.1.5 has: 1.0.3 - object.fromentries: 2.0.5 + object.fromentries: 2.0.6 prop-types: 15.8.1 react: 17.0.2 dev: true - /@wry/context@0.6.1: - resolution: {integrity: sha512-LOmVnY1iTU2D8tv4Xf6MVMZZ+juIJ87Kt/plMijjN20NMAXGmH4u8bS1t0uT74cZ5gwpocYueV58YwyI8y+GKw==} + /@wry/context/0.7.3: + resolution: {integrity: sha512-Nl8WTesHp89RF803Se9X3IiHjdmLBrIvPMaJkl+rKVJAYyPsz1TEUbu89943HpvujtSJgDUx9W4vZw3K1Mr3sA==} engines: {node: '>=8'} dependencies: - tslib: 2.5.3 + tslib: 2.6.0 dev: false - /@wry/equality@0.5.3: - resolution: {integrity: sha512-avR+UXdSrsF2v8vIqIgmeTY0UR91UT+IyablCyKe/uk22uOJ8fusKZnH9JH9e1/EtLeNJBtagNmL3eJdnOV53g==} + /@wry/equality/0.5.6: + resolution: {integrity: sha512-D46sfMTngaYlrH+OspKf8mIJETntFnf6Hsjb0V41jAXJ7Bx2kB8Rv8RCUujuVWYttFtHkUNp7g+FwxNQAr6mXA==} engines: {node: '>=8'} dependencies: - tslib: 2.5.3 + tslib: 2.6.0 dev: false - /@wry/trie@0.3.2: + /@wry/trie/0.3.2: resolution: {integrity: sha512-yRTyhWSls2OY/pYLfwff867r8ekooZ4UI+/gxot5Wj8EFwSf2rG+n+Mo/6LoLQm1TKA4GRj2+LCpbfS937dClQ==} engines: {node: '>=8'} dependencies: - tslib: 2.5.3 + tslib: 2.6.0 + dev: false + + /@wry/trie/0.4.3: + resolution: {integrity: sha512-I6bHwH0fSf6RqQcnnXLJKhkSXG45MFral3GxPaY4uAl0LYDZM+YDVDAiU9bYwjTuysy1S0IeecWtmq1SZA3M1w==} + engines: {node: '>=8'} + dependencies: + tslib: 2.6.0 dev: false - /@xmldom/xmldom@0.8.6: - resolution: {integrity: sha512-uRjjusqpoqfmRkTaNuLJ2VohVr67Q5YwDATW3VU7PfzTj6IRaihGrYI7zckGZjxQPBIp63nfvJbM+Yu5ICh0Bg==} + /@xmldom/xmldom/0.8.8: + resolution: {integrity: sha512-0LNz4EY8B/8xXY86wMrQ4tz6zEHZv9ehFMJPm8u2gq5lQ71cfRKdaKyxfJAx5aUoyzx0qzgURblTisPGgz3d+Q==} engines: {node: '>=10.0.0'} dev: true - /@xtuc/ieee754@1.2.0: + /@xtuc/ieee754/1.2.0: resolution: {integrity: sha512-DX8nKgqcGwsc0eJSqYt5lwP4DH5FlHnmuWWBRy7X0NcaGR0ZtuyeESgMwTYVEtxmsNGY+qit4QYT/MIYTOTPeA==} dev: true - /@xtuc/long@4.2.2: + /@xtuc/long/4.2.2: resolution: {integrity: sha512-NuHqBY1PB/D8xU6s/thBgOAiAP7HOYDQ32+BFZILJ8ivkUkAHQnWfn6WhL79Owj1qmUnoN/YPhktdIoucipkAQ==} dev: true - /@yeger/debounce@1.0.66: + /@yeger/debounce/1.0.66: resolution: {integrity: sha512-uG9dJufP1iV9msj78v/kPGW3AFemU6QndULKgL6KJ+EbjBVo/2dgBgRZ1XduasCtkrFxEuf3DAqFDF4XTSsZ0g==} dev: true - /@zxing/text-encoding@0.9.0: + /@zxing/text-encoding/0.9.0: resolution: {integrity: sha512-U/4aVJ2mxI0aDNI8Uq0wEhMgY+u4CNtEb0om3+y3+niDAsoTCOB33UF0sxpzqzdqXLqmvc+vZyAt4O8pPdfkwA==} requiresBuild: true dev: true optional: true - /abab@2.0.6: + /abab/2.0.6: resolution: {integrity: sha512-j2afSsaIENvHZN2B8GOpF566vZ5WVk5opAiMTvWgaQT8DkbOqsTfvNAvHoRGU2zzP8cPoqys+xHTRDWW8L+/BA==} dev: true - /abbrev@1.1.1: + /abbrev/1.1.1: resolution: {integrity: sha512-nne9/IiQ/hzIhY6pdDnbBtz7DjPTKrY00P/zvPSm5pOFkl6xuGrGnXn/VtTNNfNtAfZ9/1RtehkszU9qcTii0Q==} dev: true - /abort-controller@3.0.0: + /abort-controller/3.0.0: resolution: {integrity: sha512-h8lQ8tacZYnR3vNQTgibj+tODHI5/+l06Au2Pcriv/Gmet0eaj4TwWH41sO9wnHDiQsEj19q0drzdWdeAHtweg==} engines: {node: '>=6.5'} dependencies: event-target-shim: 5.0.1 dev: true - /abstract-logging@2.0.1: + /abstract-logging/2.0.1: resolution: {integrity: sha512-2BjRTZxTPvheOvGbBslFSYOUkr+SjPtOnrLP33f+VIWLzezQpZcqVg7ja3L4dBXmzzgwT+a029jRx5PCi3JuiA==} dev: true - /accepts@1.3.8: + /accepts/1.3.8: resolution: {integrity: sha512-PYAthTa2m2VKxuvSD3DPC/Gy+U+sOA1LAuT8mkmRuvw+NACSaeXEQ+NHcVF7rONl6qcaxV3Uuemwawk+7+SJLw==} engines: {node: '>= 0.6'} dependencies: @@ -10388,29 +8567,22 @@ packages: negotiator: 0.6.3 dev: true - /acorn-globals@6.0.0: - resolution: {integrity: sha512-ZQl7LOWaF5ePqqcX4hLuv/bLXYQNfNWw2c0/yX/TsPRKamzHcTGQnlCjHT3TsmkOUVEPS3crCxiPfdzE/Trlhg==} - dependencies: - acorn: 7.4.1 - acorn-walk: 7.2.0 - dev: true - - /acorn-globals@7.0.1: + /acorn-globals/7.0.1: resolution: {integrity: sha512-umOSDSDrfHbTNPuNpC2NSnnA3LUrqpevPb4T9jRx4MagXNS0rs+gwiTcAvqCRmsD6utzsrzNt+ebm00SNWiC3Q==} dependencies: - acorn: 8.9.0 + acorn: 8.10.0 acorn-walk: 8.2.0 dev: true - /acorn-import-assertions@1.8.0(acorn@8.9.0): - resolution: {integrity: sha512-m7VZ3jwz4eK6A4Vtt8Ew1/mNbP24u0FhdyfA7fSvnJR6LMdfOYnmuIrrJAgrYfYJ10F/otaHTtrtrtmHdMNzEw==} + /acorn-import-assertions/1.9.0_acorn@8.10.0: + resolution: {integrity: sha512-cmMwop9x+8KFhxvKrKfPYmN6/pKTYYHBqLa0DfvVZcKMJWNyWLnaqND7dx/qn66R7ewM1UX5XMaDVP5wlVTaVA==} peerDependencies: acorn: ^8 dependencies: - acorn: 8.9.0 + acorn: 8.10.0 dev: true - /acorn-jsx@5.3.2(acorn@7.4.1): + /acorn-jsx/5.3.2_acorn@7.4.1: resolution: {integrity: sha512-rq9s+JNhf0IChjtDXxllJ7g41oZk5SlXtp0LHwyA5cejwn7vKmKp4pPri6YEePv2PU65sAsegbXtIinmDFDXgQ==} peerDependencies: acorn: ^6.0.0 || ^7.0.0 || ^8.0.0 @@ -10418,61 +8590,55 @@ packages: acorn: 7.4.1 dev: true - /acorn-jsx@5.3.2(acorn@8.9.0): + /acorn-jsx/5.3.2_acorn@8.10.0: resolution: {integrity: sha512-rq9s+JNhf0IChjtDXxllJ7g41oZk5SlXtp0LHwyA5cejwn7vKmKp4pPri6YEePv2PU65sAsegbXtIinmDFDXgQ==} peerDependencies: acorn: ^6.0.0 || ^7.0.0 || ^8.0.0 dependencies: - acorn: 8.9.0 + acorn: 8.10.0 dev: true - /acorn-walk@7.2.0: + /acorn-walk/7.2.0: resolution: {integrity: sha512-OPdCF6GsMIP+Az+aWfAAOEt2/+iVDKE7oy6lJ098aoe59oAmK76qV6Gw60SbZ8jHuG2wH058GF4pLFbYamYrVA==} engines: {node: '>=0.4.0'} dev: true - /acorn-walk@8.2.0: + /acorn-walk/8.2.0: resolution: {integrity: sha512-k+iyHEuPgSw6SbuDpGQM+06HQUa04DZ3o+F6CSzXMvvI5KMvnaEqXe+YVe555R9nn6GPt404fos4wcgpw12SDA==} engines: {node: '>=0.4.0'} - /acorn@6.4.2: + /acorn/6.4.2: resolution: {integrity: sha512-XtGIhXwF8YM8bJhGxG5kXgjkEuNGLTkoYqVE+KMR+aspr4KGYmKYg7yUe3KghyQ9yheNwLnjmzh/7+gfDBmHCQ==} engines: {node: '>=0.4.0'} hasBin: true dev: true - /acorn@7.4.1: + /acorn/7.4.1: resolution: {integrity: sha512-nQyp0o1/mNdbTO1PO6kHkwSrmgZ0MT/jCCpNiwbUjGoRN4dlBhqJtoQuCnEOKzgTVwg0ZWiCoQy6SxMebQVh8A==} engines: {node: '>=0.4.0'} hasBin: true dev: true - /acorn@8.8.2: - resolution: {integrity: sha512-xjIYgE8HBrkpd/sJqOGNspf8uHG+NOHGOw6a/Urj8taM2EXfdNAH2oFcPeIFfsv3+kz/mJrS5VuMqbNLjCa2vw==} - engines: {node: '>=0.4.0'} - hasBin: true - dev: true - - /acorn@8.9.0: - resolution: {integrity: sha512-jaVNAFBHNLXspO543WnNNPZFRtavh3skAkITqD0/2aeMkKZTN+254PyhwxFYrk3vQ1xfY+2wbesJMs/JC8/PwQ==} + /acorn/8.10.0: + resolution: {integrity: sha512-F0SAmZ8iUtS//m8DmCTA0jlh6TDKkHQyK6xc6V4KDTyZKA9dnvX9/3sRTVQrWm79glUAZbnmmNcdYwUIHWVybw==} engines: {node: '>=0.4.0'} hasBin: true - /address@1.2.0: - resolution: {integrity: sha512-tNEZYz5G/zYunxFm7sfhAxkXEuLj3K6BKwv6ZURlsF6yiUQ65z0Q2wZW9L5cPUl9ocofGvXOdFYbFHp0+6MOig==} + /address/1.2.2: + resolution: {integrity: sha512-4B/qKCfeE/ODUaAUpSwfzazo5x29WD4r3vXiWsB7I2mSDAihwEqKO+g8GELZUQSSAo5e1XTYh3ZVfLyxBc12nA==} engines: {node: '>= 10.0.0'} dev: true - /agent-base@6.0.2: + /agent-base/6.0.2: resolution: {integrity: sha512-RZNwNclF7+MS/8bDg70amg32dyeZGZxiDuQmZxKLAlQjr3jGyLx+4Kkk58UO7D2QdgFIQCovuSuZESne6RG6XQ==} engines: {node: '>= 6.0.0'} dependencies: - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 transitivePeerDependencies: - supports-color dev: true - /aggregate-error@3.1.0: + /aggregate-error/3.1.0: resolution: {integrity: sha512-4I7Td01quW/RpocfNayFdFVk1qSuoh0E7JrbRJ16nH01HhKFQ88INq9Sd+nd72zqRySlr9BmDA8xlEJ6vJMrYA==} engines: {node: '>=8'} dependencies: @@ -10480,29 +8646,29 @@ packages: indent-string: 4.0.0 dev: true - /airbnb-js-shims@2.2.1: + /airbnb-js-shims/2.2.1: resolution: {integrity: sha512-wJNXPH66U2xjgo1Zwyjf9EydvJ2Si94+vSdk6EERcBfB2VZkeltpqIats0cqIZMLCXP3zcyaUKGYQeIBT6XjsQ==} dependencies: array-includes: 3.1.6 array.prototype.flat: 1.3.1 array.prototype.flatmap: 1.3.1 es5-shim: 4.6.7 - es6-shim: 0.35.6 + es6-shim: 0.35.8 function.prototype.name: 1.1.5 globalthis: 1.0.3 - object.entries: 1.1.5 - object.fromentries: 2.0.5 - object.getownpropertydescriptors: 2.1.4 + object.entries: 1.1.6 + object.fromentries: 2.0.6 + object.getownpropertydescriptors: 2.1.6 object.values: 1.1.6 - promise.allsettled: 1.0.5 - promise.prototype.finally: 3.1.3 - string.prototype.matchall: 4.0.7 - string.prototype.padend: 3.1.3 - string.prototype.padstart: 3.1.3 + promise.allsettled: 1.0.6 + promise.prototype.finally: 3.1.4 + string.prototype.matchall: 4.0.8 + string.prototype.padend: 3.1.4 + string.prototype.padstart: 3.1.4 symbol.prototype.description: 1.0.5 dev: true - /ajv-errors@1.0.1(ajv@6.12.6): + /ajv-errors/1.0.1_ajv@6.12.6: resolution: {integrity: sha512-DCRfO/4nQ+89p/RK43i8Ezd41EqdGIU4ld7nGF8OQ14oc/we5rEntLCUa7+jrn3nn83BosfwZA0wb4pon2o8iQ==} peerDependencies: ajv: '>=5.0.0' @@ -10510,18 +8676,16 @@ packages: ajv: 6.12.6 dev: true - /ajv-formats@2.1.1(ajv@8.11.0): + /ajv-formats/2.1.1: resolution: {integrity: sha512-Wx0Kx52hxE7C18hkMEggYlEifqWZtYaRgouJor+WMdPnQyEK13vgEWyVNup7SoeeoLMsr4kf5h6dOW11I15MUA==} - peerDependencies: - ajv: ^8.0.0 peerDependenciesMeta: ajv: optional: true dependencies: - ajv: 8.11.0 + ajv: 8.12.0 dev: true - /ajv-keywords@3.5.2(ajv@6.12.6): + /ajv-keywords/3.5.2_ajv@6.12.6: resolution: {integrity: sha512-5p6WTN0DdTGVQk6VjcEju19IgaHudalcfabD7yhDGeA6bcQnmL+CpveLJq/3hvfwd1aof6L386Ougkx6RfyMIQ==} peerDependencies: ajv: ^6.9.1 @@ -10529,7 +8693,7 @@ packages: ajv: 6.12.6 dev: true - /ajv@6.12.6: + /ajv/6.12.6: resolution: {integrity: sha512-j3fVLgvTo527anyYyJOGTYJbG+vnnQYvE0m5mmkc1TK+nxAppkCLMIL0aZ4dblVCNoGShhm+kzE4ZUykBoMg4g==} dependencies: fast-deep-equal: 3.1.3 @@ -10538,8 +8702,8 @@ packages: uri-js: 4.4.1 dev: true - /ajv@8.11.0: - resolution: {integrity: sha512-wGgprdCvMalC0BztXvitD2hC04YffAvtsUn93JbGXYLAtCUO4xd17mCCZQxUOItiBwZvJScWo8NIvQMQ71rdpg==} + /ajv/8.12.0: + resolution: {integrity: sha512-sRu1kpcO9yLtYxBKvqfTeh9KzZEwO3STyX1HT+4CaDzC6HpTGYhIhPIzj9XuKU7KYDwnaeh5hcOwjy1QuJzBPA==} dependencies: fast-deep-equal: 3.1.3 json-schema-traverse: 1.0.0 @@ -10547,108 +8711,108 @@ packages: uri-js: 4.4.1 dev: true - /algoliasearch@4.14.2: - resolution: {integrity: sha512-ngbEQonGEmf8dyEh5f+uOIihv4176dgbuOZspiuhmTTBRBuzWu3KCGHre6uHj5YyuC7pNvQGzB6ZNJyZi0z+Sg==} + /algoliasearch/4.18.0: + resolution: {integrity: sha512-pCuVxC1SVcpc08ENH32T4sLKSyzoU7TkRIDBMwSLfIiW+fq4znOmWDkAygHZ6pRcO9I1UJdqlfgnV7TRj+MXrA==} dependencies: - '@algolia/cache-browser-local-storage': 4.14.2 - '@algolia/cache-common': 4.14.2 - '@algolia/cache-in-memory': 4.14.2 - '@algolia/client-account': 4.14.2 - '@algolia/client-analytics': 4.14.2 - '@algolia/client-common': 4.14.2 - '@algolia/client-personalization': 4.14.2 - '@algolia/client-search': 4.14.2 - '@algolia/logger-common': 4.14.2 - '@algolia/logger-console': 4.14.2 - '@algolia/requester-browser-xhr': 4.14.2 - '@algolia/requester-common': 4.14.2 - '@algolia/requester-node-http': 4.14.2 - '@algolia/transporter': 4.14.2 + '@algolia/cache-browser-local-storage': 4.18.0 + '@algolia/cache-common': 4.18.0 + '@algolia/cache-in-memory': 4.18.0 + '@algolia/client-account': 4.18.0 + '@algolia/client-analytics': 4.18.0 + '@algolia/client-common': 4.18.0 + '@algolia/client-personalization': 4.18.0 + '@algolia/client-search': 4.18.0 + '@algolia/logger-common': 4.18.0 + '@algolia/logger-console': 4.18.0 + '@algolia/requester-browser-xhr': 4.18.0 + '@algolia/requester-common': 4.18.0 + '@algolia/requester-node-http': 4.18.0 + '@algolia/transporter': 4.18.0 dev: true - /ansi-align@3.0.1: + /ansi-align/3.0.1: resolution: {integrity: sha512-IOfwwBF5iczOjp/WeY4YxyjqAFMQoZufdQWDd19SEExbVLNXqvpzSJ/M7Za4/sCPmQ0+GRquoA7bGcINcxew6w==} dependencies: string-width: 4.2.3 dev: true - /ansi-colors@3.2.4: + /ansi-colors/3.2.4: resolution: {integrity: sha512-hHUXGagefjN2iRrID63xckIvotOXOojhQKWIPUZ4mNUZ9nLZW+7FMNoE1lOkEhNWYsx/7ysGIuJYCiMAA9FnrA==} engines: {node: '>=6'} dev: true - /ansi-colors@4.1.3: + /ansi-colors/4.1.3: resolution: {integrity: sha512-/6w/C21Pm1A7aZitlI5Ni/2J6FFQN8i1Cvz3kHABAAbw93v/NlvKdVOqz7CCWz/3iv/JplRSEEZ83XION15ovw==} engines: {node: '>=6'} dev: true - /ansi-escapes@4.3.2: + /ansi-escapes/4.3.2: resolution: {integrity: sha512-gKXj5ALrKWQLsYG9jlTRmR/xKluxHV+Z9QEwNIgCfM1/uwPMCuzVVnh5mwTd+OuBZcwSIMbqssNWRm1lE51QaQ==} engines: {node: '>=8'} dependencies: type-fest: 0.21.3 dev: true - /ansi-escapes@5.0.0: + /ansi-escapes/5.0.0: resolution: {integrity: sha512-5GFMVX8HqE/TB+FuBJGuO5XG0WrsA6ptUqoODaT/n9mmUaZFkqnBueB4leqGBCmrUHnCnC4PCZTCd0E7QQ83bA==} engines: {node: '>=12'} dependencies: type-fest: 1.4.0 dev: true - /ansi-html-community@0.0.8: + /ansi-html-community/0.0.8: resolution: {integrity: sha512-1APHAyr3+PCamwNw3bXCPp4HFLONZt/yIH0sZp0/469KWNTEy+qN5jQ3GVX6DMZ1UXAi34yVwtTeaG/HpBuuzw==} engines: {'0': node >= 0.8.0} hasBin: true dev: true - /ansi-regex@2.1.1: + /ansi-regex/2.1.1: resolution: {integrity: sha512-TIGnTpdo+E3+pCyAluZvtED5p5wCqLdezCyhPZzKPcxvFplEt4i+W7OONCKgeZFT3+y5NZZfOOS/Bdcanm1MYA==} engines: {node: '>=0.10.0'} dev: true - /ansi-regex@5.0.1: + /ansi-regex/5.0.1: resolution: {integrity: sha512-quJQXlTSUGL2LH9SUXo8VwsY4soanhgo6LNSm84E1LBcE8s3O0wpdiRzyR9z/ZZJMlMWv37qOOb9pdJlMUEKFQ==} engines: {node: '>=8'} dev: true - /ansi-regex@6.0.1: + /ansi-regex/6.0.1: resolution: {integrity: sha512-n5M855fKb2SsfMIiFFoVrABHJC8QtHwVx+mHWP3QcEqBHYienj5dHSgjbxtC0WEZXYt4wcD6zrQElDPhFuZgfA==} engines: {node: '>=12'} dev: true - /ansi-sequence-parser@1.1.0: + /ansi-sequence-parser/1.1.0: resolution: {integrity: sha512-lEm8mt52to2fT8GhciPCGeCXACSz2UwIN4X2e2LJSnZ5uAbn2/dsYdOmUXq0AtWS5cpAupysIneExOgH0Vd2TQ==} dev: true - /ansi-styles@2.2.1: + /ansi-styles/2.2.1: resolution: {integrity: sha512-kmCevFghRiWM7HB5zTPULl4r9bVFSWjz62MhqizDGUrq2NWuNMQyuv4tHHoKJHs69M/MF64lEcHdYIocrdWQYA==} engines: {node: '>=0.10.0'} dev: true - /ansi-styles@3.2.1: + /ansi-styles/3.2.1: resolution: {integrity: sha512-VT0ZI6kZRdTh8YyJw3SMbYm/u+NqfsAxEpWO0Pf9sq8/e94WxxOpPKx9FR1FlyCtOVDNOQ+8ntlqFxiRc+r5qA==} engines: {node: '>=4'} dependencies: color-convert: 1.9.3 - /ansi-styles@4.3.0: + /ansi-styles/4.3.0: resolution: {integrity: sha512-zbB9rCJAT1rbjiVDb2hqKFHNYLxgtk8NURxZ3IZwD3F6NtxbXZQCnnSi1Lkx+IDohdPlFp222wVALIheZJQSEg==} engines: {node: '>=8'} dependencies: color-convert: 2.0.1 dev: true - /ansi-styles@5.2.0: + /ansi-styles/5.2.0: resolution: {integrity: sha512-Cxwpt2SfTzTtXcfOlzGEee8O+c+MmUgGrNiBcXnuWxuFJHe6a5Hz7qwhwe5OgaSYI0IJvkLqWX1ASG+cJOkEiA==} engines: {node: '>=10'} - /ansi-styles@6.2.1: + /ansi-styles/6.2.1: resolution: {integrity: sha512-bN798gFfQX+viw3R7yrGWRqnrN2oRkEkUjjl4JNn4E8GxxbjtG3FbrEIIY3l8/hrwUwIeCZvi4QuOTP4MErVug==} engines: {node: '>=12'} dev: true - /ansi-to-html@0.6.15: + /ansi-to-html/0.6.15: resolution: {integrity: sha512-28ijx2aHJGdzbs+O5SNQF65r6rrKYnkuwTYm8lZlChuoJ9P1vVzIpWO20sQTqTPDXYp6NFwk326vApTtLVFXpQ==} engines: {node: '>=8.0.0'} hasBin: true @@ -10656,7 +8820,7 @@ packages: entities: 2.2.0 dev: true - /ansi-to-html@0.7.2: + /ansi-to-html/0.7.2: resolution: {integrity: sha512-v6MqmEpNlxF+POuyhKkidusCHWWkaLcGRURzivcU3I9tv7k4JVhFcnukrM5Rlk2rUywdZuzYAZ+kbZqWCnfN3g==} engines: {node: '>=8.0.0'} hasBin: true @@ -10664,11 +8828,11 @@ packages: entities: 2.2.0 dev: true - /any-promise@1.3.0: + /any-promise/1.3.0: resolution: {integrity: sha512-7UvmKalWRt1wgjL1RrGxoSJW/0QZFIegpeGvZG9kjp8vrRu55XTHbwnqq2GpXm9uLbcuhxm3IqX9OB4MZR1b2A==} dev: true - /anymatch@2.0.0: + /anymatch/2.0.0: resolution: {integrity: sha512-5teOsQWABXHHBFP9y3skS5P3d/WfWXpv3FUpy+LorMrNYaT9pI4oLMQX7jzQ2KklNpGpWHzdCXTDT2Y3XGlZBw==} dependencies: micromatch: 3.1.10 @@ -10677,40 +8841,40 @@ packages: - supports-color dev: true - /anymatch@3.1.2: - resolution: {integrity: sha512-P43ePfOAIupkguHUycrc4qJ9kz8ZiuOUijaETwX7THt0Y/GNK7v0aa8rY816xWjZ7rJdA5XdMcpVFTKMq+RvWg==} + /anymatch/3.1.3: + resolution: {integrity: sha512-KMReFUr0B4t+D+OBkjR3KYqvocp2XaSzO55UcB6mgQMd3KbcE+mWTyvVV7D/zsdEbNnV6acZUutkiHQXvTr1Rw==} engines: {node: '>= 8'} dependencies: normalize-path: 3.0.0 picomatch: 2.3.1 dev: true - /app-root-dir@1.0.2: + /app-root-dir/1.0.2: resolution: {integrity: sha512-jlpIfsOoNoafl92Sz//64uQHGSyMrD2vYG5d8o2a4qGvyNCvXur7bzIsWtAC/6flI2RYAp3kv8rsfBtaLm7w0g==} dev: true - /appdata-path@1.0.0: + /appdata-path/1.0.0: resolution: {integrity: sha512-ZbH3ezXfnT/YE3NdqduIt4lBV+H0ybvA2Qx3K76gIjQvh8gROpDFdDLpx6B1QJtW7zxisCbpTlCLhKqoR8cDBw==} dev: true - /aproba@1.2.0: + /aproba/1.2.0: resolution: {integrity: sha512-Y9J6ZjXtoYh8RnXVCMOU/ttDmk1aBjunq9vO0ta5x85WDQiQfUF9sIPBITdbiiIVcBo03Hi3jMxigBtsddlXRw==} dev: true - /aproba@2.0.0: + /aproba/2.0.0: resolution: {integrity: sha512-lYe4Gx7QT+MKGbDsA+Z+he/Wtef0BiwDOlK/XkBrdfsh9J/jPPXbX0tE9x9cl27Tmu5gg3QUbUrQYa/y+KOHPQ==} dev: true - /arch@2.2.0: + /arch/2.2.0: resolution: {integrity: sha512-Of/R0wqp83cgHozfIYLbBMnej79U/SVGOOyuB3VVFv1NRM/PSFMK12x9KVtiYzJqmnU5WR2qp0Z5rHb7sWGnFQ==} dev: true - /archiver-utils@2.1.0: + /archiver-utils/2.1.0: resolution: {integrity: sha512-bEL/yUb/fNNiNTuUz979Z0Yg5L+LzLxGJz8x79lYmR54fmTIb6ob/hNQgkQnIUDWIFjZVQwl9Xs356I6BAMHfw==} engines: {node: '>= 6'} dependencies: glob: 7.2.3 - graceful-fs: 4.2.10 + graceful-fs: 4.2.11 lazystream: 1.0.1 lodash.defaults: 4.2.0 lodash.difference: 4.5.0 @@ -10718,202 +8882,187 @@ packages: lodash.isplainobject: 4.0.6 lodash.union: 4.6.0 normalize-path: 3.0.0 - readable-stream: 2.3.7 + readable-stream: 2.3.8 dev: true - /archiver@5.3.1: + /archiver/5.3.1: resolution: {integrity: sha512-8KyabkmbYrH+9ibcTScQ1xCJC/CGcugdVIwB+53f5sZziXgwUh3iXlAlANMxcZyDEfTHMe6+Z5FofV8nopXP7w==} engines: {node: '>= 10'} dependencies: archiver-utils: 2.1.0 async: 3.2.4 buffer-crc32: 0.2.13 - readable-stream: 3.6.0 - readdir-glob: 1.1.2 + readable-stream: 3.6.2 + readdir-glob: 1.1.3 tar-stream: 2.2.0 zip-stream: 4.1.0 dev: true - /archy@1.0.0: + /archy/1.0.0: resolution: {integrity: sha512-Xg+9RwCg/0p32teKdGMPTPnVXKD0w3DfHnFTficozsAgsvq2XenPJq/MYpzzQ/v8zrOyJn6Ds39VA4JIDwFfqw==} dev: true - /are-we-there-yet@2.0.0: + /are-we-there-yet/2.0.0: resolution: {integrity: sha512-Ci/qENmwHnsYo9xKIcUJN5LeDKdJ6R1Z1j9V/J5wyq8nh/mYPEpIKJbBZXtZjG04HiK7zV/p6Vs9952MrMeUIw==} engines: {node: '>=10'} dependencies: delegates: 1.0.0 - readable-stream: 3.6.0 + readable-stream: 3.6.2 dev: true - /arg@4.1.3: + /arg/4.1.3: resolution: {integrity: sha512-58S9QDqG0Xx27YwPSt9fJxivjYl432YCwfDMfZ+71RAqUrZef7LrKQZ3LHLOwCS4FLNBplP533Zx895SeOCHvA==} dev: true - /argparse@1.0.10: + /argparse/1.0.10: resolution: {integrity: sha512-o5Roy6tNG4SL/FOkCAN6RzjiakZS25RLYFrcMttJqbdd8BWrnA+fGz57iN5Pb06pvBGvl5gQ0B48dJlslXvoTg==} dependencies: sprintf-js: 1.0.3 dev: true - /argparse@2.0.1: + /argparse/2.0.1: resolution: {integrity: sha512-8+9WqebbFzpX9OR+Wa6O29asIogeRMzcGtAINdpMHHyAg10f05aSFVBbcEqGf/PXw1EjAZ+q2/bEBg3DvurK3Q==} dev: true - /aria-query@5.0.2: - resolution: {integrity: sha512-eigU3vhqSO+Z8BKDnVLN/ompjhf3pYzecKXz8+whRy+9gZu8n1TCGfwzQUUPnqdHl9ax1Hr9031orZ+UOEYr7Q==} - engines: {node: '>=6.0'} - dev: true - - /aria-query@5.1.3: + /aria-query/5.1.3: resolution: {integrity: sha512-R5iJ5lkuHybztUfuOAznmboyjWq8O6sqNqtK7CLOqdydi54VNbORp49mb14KbWgG1QD3JFO9hJdZ+y4KutfdOQ==} dependencies: - deep-equal: 2.2.1 + deep-equal: 2.2.2 dev: true - /aria-query@5.3.0: + /aria-query/5.3.0: resolution: {integrity: sha512-b0P0sZPKtyu8HkeRAfCq0IfURZK+SuwMjY1UXGBU27wpAiTwQAIlq56IbIO+ytk/JjS1fMR14ee5WBBfKi5J6A==} dependencies: dequal: 2.0.3 dev: true - /arr-diff@4.0.0: + /arr-diff/4.0.0: resolution: {integrity: sha512-YVIQ82gZPGBebQV/a8dar4AitzCQs0jjXwMPZllpXMaGjXPYVUawSxQrRsjhjupyVxEvbHgUmIhKVlND+j02kA==} engines: {node: '>=0.10.0'} dev: true - /arr-flatten@1.1.0: + /arr-flatten/1.1.0: resolution: {integrity: sha512-L3hKV5R/p5o81R7O02IGnwpDmkp6E982XhtbuwSe3O4qOtMMMtodicASA1Cny2U+aCXcNpml+m4dPsvsJ3jatg==} engines: {node: '>=0.10.0'} dev: true - /arr-union@3.1.0: + /arr-union/3.1.0: resolution: {integrity: sha512-sKpyeERZ02v1FeCZT8lrfJq5u6goHCtpTAzPwJYe7c8SPFOboNjNg1vz2L4VTn9T4PQxEx13TbXLmYUcS6Ug7Q==} engines: {node: '>=0.10.0'} dev: true - /array-buffer-byte-length@1.0.0: + /array-buffer-byte-length/1.0.0: resolution: {integrity: sha512-LPuwb2P+NrQw3XhxGc36+XSvuBPopovXYTR9Ew++Du9Yb/bx5AzBfrIsBoj0EZUifjQU+sHL21sseZ3jerWO/A==} dependencies: call-bind: 1.0.2 is-array-buffer: 3.0.2 dev: true - /array-find-index@1.0.2: + /array-find-index/1.0.2: resolution: {integrity: sha512-M1HQyIXcBGtVywBt8WVdim+lrNaK7VHp99Qt5pSNziXznKHViIBbXWtfRTpEFpF/c4FdfxNAsCCwPp5phBYJtw==} engines: {node: '>=0.10.0'} dev: true - /array-flatten@1.1.1: + /array-flatten/1.1.1: resolution: {integrity: sha512-PCVAQswWemu6UdxsDFFX/+gVeYqKAod3D3UVm91jHwynguOwAvYPhx8nNlM++NqRcK6CxxpUafjmhIdKiHibqg==} dev: true - /array-includes@3.1.6: + /array-includes/3.1.6: resolution: {integrity: sha512-sgTbLvL6cNnw24FnbaDyjmvddQ2ML8arZsgaJhoABMoplz/4QRhtrYS+alr1BUM1Bwp6dhx8vVCBSLG+StwOFw==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.20.4 - get-intrinsic: 1.2.0 + es-abstract: 1.21.2 + get-intrinsic: 1.2.1 is-string: 1.0.7 dev: true - /array-union@1.0.2: + /array-union/1.0.2: resolution: {integrity: sha512-Dxr6QJj/RdU/hCaBjOfxW+q6lyuVE6JFWIrAUpuOOhoJJoQ99cUn3igRaHVB5P9WrgFVN0FfArM3x0cueOU8ng==} engines: {node: '>=0.10.0'} dependencies: array-uniq: 1.0.3 dev: true - /array-union@2.1.0: + /array-union/2.1.0: resolution: {integrity: sha512-HGyxoOTYUyCM6stUe6EJgnd4EoewAI7zMdfqO+kGjnlZmBDz/cR5pf8r/cR4Wq60sL/p0IkcjUEEPwS3GFrIyw==} engines: {node: '>=8'} dev: true - /array-uniq@1.0.3: + /array-uniq/1.0.3: resolution: {integrity: sha512-MNha4BWQ6JbwhFhj03YK552f7cb3AzoE8SzeljgChvL1dl3IcvggXVz1DilzySZkCja+CXuZbdW7yATchWn8/Q==} engines: {node: '>=0.10.0'} dev: true - /array-unique@0.3.2: + /array-unique/0.3.2: resolution: {integrity: sha512-SleRWjh9JUud2wH1hPs9rZBZ33H6T9HOiL0uwGnGx9FpE6wKGyfWugmbkEOIs6qWrZhg0LWeLziLrEwQJhs5mQ==} engines: {node: '>=0.10.0'} dev: true - /array.prototype.filter@1.0.1: - resolution: {integrity: sha512-Dk3Ty7N42Odk7PjU/Ci3zT4pLj20YvuVnneG/58ICM6bt4Ij5kZaJTVQ9TSaWaIECX2sFyz4KItkVZqHNnciqw==} + /array.prototype.filter/1.0.2: + resolution: {integrity: sha512-us+UrmGOilqttSOgoWZTpOvHu68vZT2YCjc/H4vhu56vzZpaDFBhB+Se2UwqWzMKbDv7Myq5M5pcZLAtUvTQdQ==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.20.4 + es-abstract: 1.21.2 es-array-method-boxes-properly: 1.0.0 is-string: 1.0.7 dev: true - /array.prototype.flat@1.3.0: - resolution: {integrity: sha512-12IUEkHsAhA4DY5s0FPgNXIdc8VRSqD9Zp78a5au9abH/SOBrsp082JOWFNTjkMozh8mqcdiKuaLGhPeYztxSw==} - engines: {node: '>= 0.4'} - dependencies: - call-bind: 1.0.2 - define-properties: 1.2.0 - es-abstract: 1.20.4 - es-shim-unscopables: 1.0.0 - dev: true - - /array.prototype.flat@1.3.1: + /array.prototype.flat/1.3.1: resolution: {integrity: sha512-roTU0KWIOmJ4DRLmwKd19Otg0/mT3qPNt0Qb3GWW8iObuZXxrjB/pzn0R3hqpRSWg4HCwqx+0vwOnWnvlOyeIA==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.20.4 + es-abstract: 1.21.2 es-shim-unscopables: 1.0.0 dev: true - /array.prototype.flatmap@1.3.1: + /array.prototype.flatmap/1.3.1: resolution: {integrity: sha512-8UGn9O1FDVvMNB0UlLv4voxRMze7+FpHyF5mSMRjWHUMlpoDViniy05870VlxhfgTnLbpuwTzvD76MTtWxB/mQ==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.20.4 + es-abstract: 1.21.2 es-shim-unscopables: 1.0.0 dev: true - /array.prototype.map@1.0.4: - resolution: {integrity: sha512-Qds9QnX7A0qISY7JT5WuJO0NJPE9CMlC6JzHQfhpqAAQQzufVRoeH7EzUY5GcPTx72voG8LV/5eo+b8Qi8hmhA==} + /array.prototype.map/1.0.5: + resolution: {integrity: sha512-gfaKntvwqYIuC7mLLyv2wzZIJqrRhn5PZ9EfFejSx6a78sV7iDsGpG9P+3oUPtm1Rerqm6nrKS4FYuTIvWfo3g==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.20.4 + es-abstract: 1.21.2 es-array-method-boxes-properly: 1.0.0 is-string: 1.0.7 dev: true - /array.prototype.reduce@1.0.4: - resolution: {integrity: sha512-WnM+AjG/DvLRLo4DDl+r+SvCzYtD2Jd9oeBYMcEaI7t3fFrHY9M53/wdLcTvmZNQ70IU6Htj0emFkZ5TS+lrdw==} + /array.prototype.reduce/1.0.5: + resolution: {integrity: sha512-kDdugMl7id9COE8R7MHF5jWk7Dqt/fs4Pv+JXoICnYwqpjjjbUurz6w5fT5IG6brLdJhv6/VoHB0H7oyIBXd+Q==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.20.4 + es-abstract: 1.21.2 es-array-method-boxes-properly: 1.0.0 is-string: 1.0.7 dev: true - /arrify@2.0.1: + /arrify/2.0.1: resolution: {integrity: sha512-3duEwti880xqi4eAMN8AyR4a0ByT90zoYdLlevfrvU43vb0YZwZVfxOgxWrLXXXpyugL0hNZc9G6BiB5B3nUug==} engines: {node: '>=8'} dev: true - /asap@2.0.6: + /asap/2.0.6: resolution: {integrity: sha512-BSHWgDSAiKs50o2Re8ppvp3seVHXSRM44cdSsT9FfNEUUZLOGWVCsiWaRPWM1Znn+mqZ1OfVZ3z3DWEzSp7hRA==} dev: true - /asn1.js@5.4.1: + /asn1.js/5.4.1: resolution: {integrity: sha512-+I//4cYPccV8LdmBLiX8CYvf9Sp3vQsrqu2QNXRcrbiWvcx/UdlFiqUJJzxRQxgsZmvhXhn4cSKeSmoFjVdupA==} dependencies: bn.js: 4.12.0 @@ -10922,80 +9071,80 @@ packages: safer-buffer: 2.1.2 dev: true - /asn1@0.2.6: + /asn1/0.2.6: resolution: {integrity: sha512-ix/FxPn0MDjeyJ7i/yoHGFt/EX6LyNbxSEhPPXODPL+KB0VPk86UYfL0lMdy+KCnv+fmvIzySwaK5COwqVbWTQ==} dependencies: safer-buffer: 2.1.2 dev: true - /assert-plus@1.0.0: + /assert-plus/1.0.0: resolution: {integrity: sha512-NfJ4UzBCcQGLDlQq7nHxH+tv3kyZ0hHQqF5BO6J7tNJeP5do1llPr8dZ8zHonfhAu0PHAdMkSo+8o0wxg9lZWw==} engines: {node: '>=0.8'} dev: true - /assert@1.5.0: + /assert/1.5.0: resolution: {integrity: sha512-EDsgawzwoun2CZkCgtxJbv392v4nbk9XDD06zI+kQYoBM/3RBWLlEyJARDOmhAAosBjWACEkKL6S+lIZtcAubA==} dependencies: object-assign: 4.1.1 util: 0.10.3 dev: true - /assertion-error@1.1.0: + /assertion-error/1.1.0: resolution: {integrity: sha512-jgsaNduz+ndvGyFt3uSuWqvy4lCnIJiovtouQN5JZHOKCS2QuhEdbcQHFhVksz2N2U9hXJo8odG7ETyWlEeuDw==} dev: false - /assign-symbols@1.0.0: + /assign-symbols/1.0.0: resolution: {integrity: sha512-Q+JC7Whu8HhmTdBph/Tq59IoRtoy6KAm5zzPv00WdujX82lbAL8K7WVjne7vdCsAmbF4AYaDOPyO3k0kl8qIrw==} engines: {node: '>=0.10.0'} dev: true - /ast-types@0.14.2: + /ast-types/0.14.2: resolution: {integrity: sha512-O0yuUDnZeQDL+ncNGlJ78BiO4jnYI3bvMsD5prT0/nsgijG/LpNBIr63gTjVTNsiGkgQhiyCShTgxt8oXOrklA==} engines: {node: '>=4'} dependencies: - tslib: 2.5.3 + tslib: 2.6.0 dev: true - /astral-regex@2.0.0: + /astral-regex/2.0.0: resolution: {integrity: sha512-Z7tMw1ytTXt5jqMcOP+OQteU1VuNK9Y02uuJtKQ1Sv69jXQKKg5cibLwGJow8yzZP+eAc18EmLGPal0bp36rvQ==} engines: {node: '>=8'} dev: true - /async-each@1.0.3: - resolution: {integrity: sha512-z/WhQ5FPySLdvREByI2vZiTWwCnF0moMJ1hK9YQwDTHKh6I7/uSckMetoRGb5UBZPC1z0jlw+n/XCgjeH7y1AQ==} + /async-each/1.0.6: + resolution: {integrity: sha512-c646jH1avxr+aVpndVMeAfYw7wAa6idufrlN3LPA4PmKS0QEGp6PIC9nwz0WQkkvBGAMEki3pFdtxaF39J9vvg==} dev: true optional: true - /async@3.2.4: + /async/3.2.4: resolution: {integrity: sha512-iAB+JbDEGXhyIUavoDl9WP/Jj106Kz9DEn1DPgYw5ruDn0e3Wgi3sKFm55sASdGBNOQB8F59d9qQ7deqrHA8wQ==} dev: true - /asynckit@0.4.0: + /asynckit/0.4.0: resolution: {integrity: sha512-Oei9OH4tRh0YqU3GxhX79dM/mwVgvbZJaSNaRk+bshkj0S5cfHcgYakreBjrHwatXKbz+IoIdYLxrKim2MjW0Q==} dev: true - /at-least-node@1.0.0: + /at-least-node/1.0.0: resolution: {integrity: sha512-+q/t7Ekv1EDY2l6Gda6LLiX14rU9TV20Wa3ofeQmwPFZbOMo9DXrLbOjFaaclkXKWidIaopwAObQDqwWtGUjqg==} engines: {node: '>= 4.0.0'} dev: true - /atob@2.1.2: + /atob/2.1.2: resolution: {integrity: sha512-Wm6ukoaOGJi/73p/cl2GvLjTI5JM1k/O14isD73YML8StrH/7/lRFgmg8nICZgD3bZZvjwCGxtMOD3wWNAu8cg==} engines: {node: '>= 4.5.0'} hasBin: true dev: true - /atomic-sleep@1.0.0: + /atomic-sleep/1.0.0: resolution: {integrity: sha512-kNOjDqAh7px0XWNI+4QbzoiR/nTkHAWNud2uvnJquD1/x5a7EQZMJT0AczqK0Qn67oY/TTQ1LbUKajZpp3I9tQ==} engines: {node: '>=8.0.0'} dev: true - /autoprefixer@9.8.8: + /autoprefixer/9.8.8: resolution: {integrity: sha512-eM9d/swFopRt5gdJ7jrpCwgvEMIayITpojhkkSMRsFHYuH5bkSQ4p/9qTEHtmNudUZh22Tehu7I6CxAW0IXTKA==} hasBin: true dependencies: - browserslist: 4.21.3 - caniuse-lite: 1.0.30001385 + browserslist: 4.21.9 + caniuse-lite: 1.0.30001515 normalize-range: 0.1.2 num2fraction: 1.2.2 picocolors: 0.2.1 @@ -11003,96 +9152,80 @@ packages: postcss-value-parser: 4.2.0 dev: true - /available-typed-arrays@1.0.5: + /available-typed-arrays/1.0.5: resolution: {integrity: sha512-DMD0KiN46eipeziST1LPP/STfDU0sufISXmjSgvVsoU2tqxctQeASejWcfNtxYKqETM1UxQ8sp2OrSBWpHY6sw==} engines: {node: '>= 0.4'} dev: true - /avvio@8.2.0: - resolution: {integrity: sha512-bbCQdg7bpEv6kGH41RO/3B2/GMMmJSo2iBK+X8AWN9mujtfUipMDfIjsgHCfpnKqoGEQrrmCDKSa5OQ19+fDmg==} + /avvio/8.2.1: + resolution: {integrity: sha512-TAlMYvOuwGyLK3PfBb5WKBXZmXz2fVCgv23d6zZFdle/q3gPjmxBaeuC0pY0Dzs5PWMSgfqqEZkrye19GlDTgw==} dependencies: archy: 1.0.0 - debug: 4.3.4(supports-color@8.1.1) - fastq: 1.13.0 + debug: 4.3.4 + fastq: 1.15.0 transitivePeerDependencies: - supports-color dev: true - /aws-sign2@0.7.0: + /aws-sign2/0.7.0: resolution: {integrity: sha512-08kcGqnYf/YmjoRhfxyu+CLxBjUtHLXLXX/vUfx9l2LYzG3c1m61nrpyFUZI6zeS+Li/wWMMidD9KgrqtGq3mA==} dev: true - /aws4@1.11.0: - resolution: {integrity: sha512-xh1Rl34h6Fi1DC2WWKfxUTVqRsNnr6LsKz2+hfwDxQJWmrx8+c7ylaqBMcHfl1U1r2dsifOvKX3LQuLNZ+XSvA==} + /aws4/1.12.0: + resolution: {integrity: sha512-NmWvPnx0F1SfrQbYwOi7OeaNGokp9XhzNioJ/CSBs8Qa4vxug81mhJEAVZwxXuBmYB5KDRfMq/F3RR0BIU7sWg==} dev: true - /axios@0.26.1: + /axios/0.26.1: resolution: {integrity: sha512-fPwcX4EvnSHuInCMItEhAGnaSEXRBjtzh9fOtsE6E1G6p7vl7edEeZe11QHf18+6+9gR5PbKV/sGKNaD8YaMeA==} dependencies: - follow-redirects: 1.15.1 + follow-redirects: 1.15.2 transitivePeerDependencies: - debug - /axobject-query@3.2.1: + /axobject-query/3.2.1: resolution: {integrity: sha512-jsyHu61e6N4Vbz/v18DHwWYKK0bSWLqn47eeDSKPB7m8tqMHF9YJ+mhIk2lVteyZrY8tnSj/jHOv4YiTCuCJgg==} dependencies: dequal: 2.0.3 dev: true - /babel-jest@27.5.1(@babel/core@7.22.5): - resolution: {integrity: sha512-cdQ5dXjGRd0IBRATiQ4mZGlGlRE8kJpjPOixdNRdT+m3UcNqmYWN6rK6nvtXYfY3D76cb8s/O1Ss8ea24PIwcg==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - peerDependencies: - '@babel/core': ^7.8.0 - dependencies: - '@babel/core': 7.22.5 - '@jest/transform': 27.5.1 - '@jest/types': 27.5.1 - '@types/babel__core': 7.20.0 - babel-plugin-istanbul: 6.1.1 - babel-preset-jest: 27.5.1(@babel/core@7.22.5) - chalk: 4.1.2 - graceful-fs: 4.2.10 - slash: 3.0.0 - transitivePeerDependencies: - - supports-color - dev: true - - /babel-loader@8.2.5(@babel/core@7.18.13)(webpack@5.74.0): - resolution: {integrity: sha512-OSiFfH89LrEMiWd4pLNqGz4CwJDtbs2ZVc+iGu2HrkRfPxId9F2anQj38IxWpmRfsUY0aBZYi1EFcd3mhtRMLQ==} + /b4a/1.6.4: + resolution: {integrity: sha512-fpWrvyVHEKyeEvbKZTVOeZF3VSKKWtJxFIxX/jaVPf+cLbGUSitjb49pHLqPV2BUNNZ0LcoeEGfE/YCpyDYHIw==} + dev: true + + /babel-loader/8.3.0_@babel+core@7.22.8: + resolution: {integrity: sha512-H8SvsMF+m9t15HNLMipppzkC+Y2Yq+v3SonZyU70RBL/h1gxPkH08Ot8pEE9Z4Kd+czyWJClmFS8qzIP9OZ04Q==} engines: {node: '>= 8.9'} peerDependencies: '@babel/core': ^7.0.0 webpack: '>=2' dependencies: - '@babel/core': 7.18.13 + '@babel/core': 7.22.8 find-cache-dir: 3.3.2 - loader-utils: 2.0.2 + loader-utils: 2.0.4 make-dir: 3.1.0 schema-utils: 2.7.1 - webpack: 5.74.0(esbuild@0.18.11) dev: true - /babel-loader@8.2.5(@babel/core@7.22.5)(webpack@4.46.0): - resolution: {integrity: sha512-OSiFfH89LrEMiWd4pLNqGz4CwJDtbs2ZVc+iGu2HrkRfPxId9F2anQj38IxWpmRfsUY0aBZYi1EFcd3mhtRMLQ==} + /babel-loader/8.3.0_n6tf3ekqtzvxjokzr6jiserpma: + resolution: {integrity: sha512-H8SvsMF+m9t15HNLMipppzkC+Y2Yq+v3SonZyU70RBL/h1gxPkH08Ot8pEE9Z4Kd+czyWJClmFS8qzIP9OZ04Q==} engines: {node: '>= 8.9'} peerDependencies: '@babel/core': ^7.0.0 webpack: '>=2' dependencies: - '@babel/core': 7.22.5 + '@babel/core': 7.22.8 find-cache-dir: 3.3.2 - loader-utils: 2.0.2 + loader-utils: 2.0.4 make-dir: 3.1.0 schema-utils: 2.7.1 webpack: 4.46.0 dev: true - /babel-plugin-add-react-displayname@0.0.5: + /babel-plugin-add-react-displayname/0.0.5: resolution: {integrity: sha512-LY3+Y0XVDYcShHHorshrDbt4KFWL4bSeniCtl4SYZbask+Syngk1uMPCeN9+nSiZo6zX5s0RTq/J9Pnaaf/KHw==} dev: true - /babel-plugin-apply-mdx-type-prop@1.6.22(@babel/core@7.12.9): + /babel-plugin-apply-mdx-type-prop/1.6.22_@babel+core@7.12.9: resolution: {integrity: sha512-VefL+8o+F/DfK24lPZMtJctrCVOfgbqLAGZSkxwhazQv4VxPg3Za/i40fu22KR2m8eEda+IfSOlPLUSIiLcnCQ==} peerDependencies: '@babel/core': ^7.11.6 @@ -11102,19 +9235,13 @@ packages: '@mdx-js/util': 1.6.22 dev: true - /babel-plugin-dynamic-import-node@2.3.3: - resolution: {integrity: sha512-jZVI+s9Zg3IqA/kdi0i6UDCybUI3aSBLnglhYbSSjKlV7yF1F/5LWv8MakQmvYpnbJDS6fcBL2KzHSxNCMtWSQ==} - dependencies: - object.assign: 4.1.4 - dev: true - - /babel-plugin-extract-import-names@1.6.22: + /babel-plugin-extract-import-names/1.6.22: resolution: {integrity: sha512-yJ9BsJaISua7d8zNT7oRG1ZLBJCIdZ4PZqmH8qa9N5AK01ifk3fnkc98AXhtzE7UkfCsEumvoQWgoYLhOnJ7jQ==} dependencies: '@babel/helper-plugin-utils': 7.10.4 dev: true - /babel-plugin-istanbul@6.1.1: + /babel-plugin-istanbul/6.1.1: resolution: {integrity: sha512-Y1IQok9821cC9onCx5otgFfRm7Lm+I+wwxOx738M/WLPZ9Q42m4IG5W0FNX8WLL2gYMZo3JkuXIH2DOpWM+qwA==} engines: {node: '>=8'} dependencies: @@ -11127,121 +9254,76 @@ packages: - supports-color dev: true - /babel-plugin-jest-hoist@27.5.1: - resolution: {integrity: sha512-50wCwD5EMNW4aRpOwtqzyZHIewTYNxLA4nhB+09d8BIssfNfzBRhkBIHiaPv1Si226TQSvp8gxAJm2iY2qs2hQ==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - '@babel/template': 7.22.5 - '@babel/types': 7.22.5 - '@types/babel__core': 7.20.0 - '@types/babel__traverse': 7.18.3 - dev: true - - /babel-plugin-jsx-dom-expressions@0.35.6(@babel/core@7.20.5): - resolution: {integrity: sha512-z8VBym+Scol38MiR97iqQGsANjhsDqscRRemk+po+z3TWKV/fb9kux/gdKOJJSC/ARyUL3HExBFVtr+Efd24uw==} + /babel-plugin-jsx-dom-expressions/0.36.10_@babel+core@7.22.8: + resolution: {integrity: sha512-QA2k/14WGw+RgcGGnEuLWwnu4em6CGhjeXtjvgOYyFHYS2a+CzPeaVQHDOlfuiBcjq/3hWMspHMIMnPEOIzdBg==} peerDependencies: - '@babel/core': ^7.0.0 + '@babel/core': ^7.20.12 dependencies: - '@babel/core': 7.20.5 - '@babel/helper-module-imports': 7.16.0 - '@babel/plugin-syntax-jsx': 7.18.6(@babel/core@7.20.5) + '@babel/core': 7.22.8 + '@babel/helper-module-imports': 7.18.6 + '@babel/plugin-syntax-jsx': 7.22.5_@babel+core@7.22.8 '@babel/types': 7.22.5 - html-entities: 2.3.2 + html-entities: 2.3.3 + validate-html-nesting: 1.2.2 dev: true - /babel-plugin-macros@3.1.0: + /babel-plugin-macros/3.1.0: resolution: {integrity: sha512-Cg7TFGpIr01vOQNODXOOaGz2NpCU5gl8x1qJFbb6hbZxR7XrcE2vtbAsTAbJ7/xwJtUuJEw8K8Zr/AE0LHlesg==} engines: {node: '>=10', npm: '>=6'} dependencies: - '@babel/runtime': 7.18.9 - cosmiconfig: 7.0.1 + '@babel/runtime': 7.22.6 + cosmiconfig: 7.1.0 resolve: 1.22.2 - /babel-plugin-polyfill-corejs2@0.3.2(@babel/core@7.18.13): - resolution: {integrity: sha512-LPnodUl3lS0/4wN3Rb+m+UK8s7lj2jcLRrjho4gLw+OJs+I4bvGXshINesY5xx/apM+biTnQ9reDI8yj+0M5+Q==} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/compat-data': 7.22.5 - '@babel/core': 7.18.13 - '@babel/helper-define-polyfill-provider': 0.3.2(@babel/core@7.18.13) - semver: 6.3.0 - transitivePeerDependencies: - - supports-color - dev: true - - /babel-plugin-polyfill-corejs2@0.3.2(@babel/core@7.22.5): - resolution: {integrity: sha512-LPnodUl3lS0/4wN3Rb+m+UK8s7lj2jcLRrjho4gLw+OJs+I4bvGXshINesY5xx/apM+biTnQ9reDI8yj+0M5+Q==} + /babel-plugin-polyfill-corejs2/0.4.4_@babel+core@7.22.8: + resolution: {integrity: sha512-9WeK9snM1BfxB38goUEv2FLnA6ja07UMfazFHzCXUb3NyDZAwfXvQiURQ6guTTMeHcOsdknULm1PDhs4uWtKyA==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/compat-data': 7.22.5 - '@babel/core': 7.22.5 - '@babel/helper-define-polyfill-provider': 0.3.2(@babel/core@7.22.5) - semver: 6.3.0 + '@babel/compat-data': 7.22.6 + '@babel/core': 7.22.8 + '@babel/helper-define-polyfill-provider': 0.4.1_@babel+core@7.22.8 + '@nicolo-ribaudo/semver-v6': 6.3.3 transitivePeerDependencies: - supports-color dev: true - /babel-plugin-polyfill-corejs3@0.1.7(@babel/core@7.22.5): + /babel-plugin-polyfill-corejs3/0.1.7_@babel+core@7.22.8: resolution: {integrity: sha512-u+gbS9bbPhZWEeyy1oR/YaaSpod/KDT07arZHb80aTpl8H5ZBq+uN1nN9/xtX7jQyfLdPfoqI4Rue/MQSWJquw==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-define-polyfill-provider': 0.1.5(@babel/core@7.22.5) - core-js-compat: 3.25.0 - transitivePeerDependencies: - - supports-color - dev: true - - /babel-plugin-polyfill-corejs3@0.5.3(@babel/core@7.18.13): - resolution: {integrity: sha512-zKsXDh0XjnrUEW0mxIHLfjBfnXSMr5Q/goMe/fxpQnLm07mcOZiIZHBNWCMx60HmdvjxfXcalac0tfFg0wqxyw==} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.18.13 - '@babel/helper-define-polyfill-provider': 0.3.2(@babel/core@7.18.13) - core-js-compat: 3.25.0 - transitivePeerDependencies: - - supports-color - dev: true - - /babel-plugin-polyfill-corejs3@0.5.3(@babel/core@7.22.5): - resolution: {integrity: sha512-zKsXDh0XjnrUEW0mxIHLfjBfnXSMr5Q/goMe/fxpQnLm07mcOZiIZHBNWCMx60HmdvjxfXcalac0tfFg0wqxyw==} - peerDependencies: - '@babel/core': ^7.0.0-0 - dependencies: - '@babel/core': 7.22.5 - '@babel/helper-define-polyfill-provider': 0.3.2(@babel/core@7.22.5) - core-js-compat: 3.25.0 + '@babel/core': 7.22.8 + '@babel/helper-define-polyfill-provider': 0.1.5_@babel+core@7.22.8 + core-js-compat: 3.31.1 transitivePeerDependencies: - supports-color dev: true - /babel-plugin-polyfill-regenerator@0.4.0(@babel/core@7.18.13): - resolution: {integrity: sha512-RW1cnryiADFeHmfLS+WW/G431p1PsW5qdRdz0SDRi7TKcUgc7Oh/uXkT7MZ/+tGsT1BkczEAmD5XjUyJ5SWDTw==} + /babel-plugin-polyfill-corejs3/0.8.2_@babel+core@7.22.8: + resolution: {integrity: sha512-Cid+Jv1BrY9ReW9lIfNlNpsI53N+FN7gE+f73zLAUbr9C52W4gKLWSByx47pfDJsEysojKArqOtOKZSVIIUTuQ==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.18.13 - '@babel/helper-define-polyfill-provider': 0.3.2(@babel/core@7.18.13) + '@babel/core': 7.22.8 + '@babel/helper-define-polyfill-provider': 0.4.1_@babel+core@7.22.8 + core-js-compat: 3.31.1 transitivePeerDependencies: - supports-color dev: true - /babel-plugin-polyfill-regenerator@0.4.0(@babel/core@7.22.5): - resolution: {integrity: sha512-RW1cnryiADFeHmfLS+WW/G431p1PsW5qdRdz0SDRi7TKcUgc7Oh/uXkT7MZ/+tGsT1BkczEAmD5XjUyJ5SWDTw==} + /babel-plugin-polyfill-regenerator/0.5.1_@babel+core@7.22.8: + resolution: {integrity: sha512-L8OyySuI6OSQ5hFy9O+7zFjyr4WhAfRjLIOkhQGYl+emwJkd/S4XXT1JpfrgR1jrQ1NcGiOh+yAdGlF8pnC3Jw==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.5 - '@babel/helper-define-polyfill-provider': 0.3.2(@babel/core@7.22.5) + '@babel/core': 7.22.8 + '@babel/helper-define-polyfill-provider': 0.4.1_@babel+core@7.22.8 transitivePeerDependencies: - supports-color dev: true - /babel-plugin-react-docgen@4.2.1: + /babel-plugin-react-docgen/4.2.1: resolution: {integrity: sha512-UQ0NmGHj/HAqi5Bew8WvNfCk8wSsmdgNd8ZdMjBCICtyCJCq9LiqgqvjCYe570/Wg7AQArSq1VQ60Dd/CHN7mQ==} dependencies: ast-types: 0.14.2 @@ -11251,58 +9333,23 @@ packages: - supports-color dev: true - /babel-preset-current-node-syntax@1.0.1(@babel/core@7.22.5): - resolution: {integrity: sha512-M7LQ0bxarkxQoN+vz5aJPsLBn77n8QgTFmo8WK0/44auK2xlCXrYcUxHFxgU7qW5Yzw/CjmLRK2uJzaCd7LvqQ==} - peerDependencies: - '@babel/core': ^7.0.0 - dependencies: - '@babel/core': 7.22.5 - '@babel/plugin-syntax-async-generators': 7.8.4(@babel/core@7.22.5) - '@babel/plugin-syntax-bigint': 7.8.3(@babel/core@7.22.5) - '@babel/plugin-syntax-class-properties': 7.12.13(@babel/core@7.22.5) - '@babel/plugin-syntax-import-meta': 7.10.4(@babel/core@7.22.5) - '@babel/plugin-syntax-json-strings': 7.8.3(@babel/core@7.22.5) - '@babel/plugin-syntax-logical-assignment-operators': 7.10.4(@babel/core@7.22.5) - '@babel/plugin-syntax-nullish-coalescing-operator': 7.8.3(@babel/core@7.22.5) - '@babel/plugin-syntax-numeric-separator': 7.10.4(@babel/core@7.22.5) - '@babel/plugin-syntax-object-rest-spread': 7.8.3(@babel/core@7.22.5) - '@babel/plugin-syntax-optional-catch-binding': 7.8.3(@babel/core@7.22.5) - '@babel/plugin-syntax-optional-chaining': 7.8.3(@babel/core@7.22.5) - '@babel/plugin-syntax-top-level-await': 7.14.5(@babel/core@7.22.5) - dev: true - - /babel-preset-jest@27.5.1(@babel/core@7.22.5): - resolution: {integrity: sha512-Nptf2FzlPCWYuJg41HBqXVT8ym6bXOevuCTbhxlUpjwtysGaIWFvDEjp4y+G7fl13FgOdjs7P/DmErqH7da0Ag==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - peerDependencies: - '@babel/core': ^7.0.0 - dependencies: - '@babel/core': 7.22.5 - babel-plugin-jest-hoist: 27.5.1 - babel-preset-current-node-syntax: 1.0.1(@babel/core@7.22.5) - dev: true - - /babel-preset-solid@1.6.3(@babel/core@7.20.5): - resolution: {integrity: sha512-AQ6aaKQlDAZc3aAS+nFfXbNBf+NeJwKlRA55clj9PQI+Mkqv8JvTOnAEIGfYa0OW0sntMWhNWx+ih/4PK2s3/w==} + /babel-preset-solid/1.7.7_@babel+core@7.22.8: + resolution: {integrity: sha512-tdxVzx3kgcIjNXAOmGRbzIhFBPeJjSakiN9yM+IYdL/+LtXNnbGqb0Va5tJb8Sjbk+QVEriovCyuzB5T7jeTvg==} peerDependencies: '@babel/core': ^7.0.0 dependencies: - '@babel/core': 7.20.5 - babel-plugin-jsx-dom-expressions: 0.35.6(@babel/core@7.20.5) + '@babel/core': 7.22.8 + babel-plugin-jsx-dom-expressions: 0.36.10_@babel+core@7.22.8 dev: true - /bail@1.0.5: + /bail/1.0.5: resolution: {integrity: sha512-xFbRxM1tahm08yHBP16MMjVUAvDaBMD38zsM9EMAUN61omwLmKlOpB/Zku5QkjZ8TZ4vn53pj+t518cH0S03RQ==} dev: true - /balanced-match@1.0.2: + /balanced-match/1.0.2: resolution: {integrity: sha512-3oSeUO0TMV67hN1AmbXsK4yaqU7tjiHlbxRDZOpH0KW9+CeX4bRAaX0Anxt0tx2MrpRpWwQaPwIlISEJhYU5Pw==} - /base64-js@1.5.1: - resolution: {integrity: sha512-AKpaYlHn8t4SVbOHCy+b5+KKgvR4vrsD8vbvrbiQJps7fKDTkjkDry6ji0rUJjC0kzbNePLwzxq8iypo41qeWA==} - dev: true - - /base@0.11.2: + /base/0.11.2: resolution: {integrity: sha512-5T6P4xPgpp0YDFvSWwEZ4NoE3aM4QBQXDzmVbraCkFj8zHM+mba8SyqB5DbZWyR7mYHo6Y7BdQo3MoA4m0TeQg==} engines: {node: '>=0.10.0'} dependencies: @@ -11315,86 +9362,89 @@ packages: pascalcase: 0.1.1 dev: true - /bcrypt-pbkdf@1.0.2: + /base64-js/1.5.1: + resolution: {integrity: sha512-AKpaYlHn8t4SVbOHCy+b5+KKgvR4vrsD8vbvrbiQJps7fKDTkjkDry6ji0rUJjC0kzbNePLwzxq8iypo41qeWA==} + dev: true + + /bcrypt-pbkdf/1.0.2: resolution: {integrity: sha512-qeFIXtP4MSoi6NLqO12WfqARWWuCKi2Rn/9hJLEmtB5yTNr9DqFWkJRCf2qShWzPeAMRnOgCrq0sg/KLv5ES9w==} dependencies: tweetnacl: 0.14.5 dev: true - /better-opn@2.1.1: + /better-opn/2.1.1: resolution: {integrity: sha512-kIPXZS5qwyKiX/HcRvDYfmBQUa8XP17I0mYZZ0y4UhpYOSvtsLHDYqmomS+Mj20aDvD3knEiQ0ecQy2nhio3yA==} engines: {node: '>8.0.0'} dependencies: open: 7.4.2 dev: true - /big-integer@1.6.51: + /big-integer/1.6.51: resolution: {integrity: sha512-GPEid2Y9QU1Exl1rpO9B2IPJGHPSupF5GnVIP0blYvNOMer2bTvSWs1jGOUg04hTmu67nmLsQ9TBo1puaotBHg==} engines: {node: '>=0.6'} - /big.js@5.2.2: + /big.js/5.2.2: resolution: {integrity: sha512-vyL2OymJxmarO8gxMr0mhChsO9QGwhynfuu4+MHTAW6czfq9humCB7rKpUjDd9YUiDPU4mzpyupFSvOClAwbmQ==} dev: true - /binary-extensions@1.13.1: + /binary-extensions/1.13.1: resolution: {integrity: sha512-Un7MIEDdUC5gNpcGDV97op1Ywk748MpHcFTHoYs6qnj1Z3j7I53VG3nwZhKzoBZmbdRNnb6WRdFlwl7tSDuZGw==} engines: {node: '>=0.10.0'} dev: true optional: true - /binary-extensions@2.2.0: + /binary-extensions/2.2.0: resolution: {integrity: sha512-jDctJ/IVQbZoJykoeHbhXpOlNBqGNcwXJKJog42E5HDPUwQTSdjCHdihjj0DlnheQ7blbT6dHOafNAiS8ooQKA==} engines: {node: '>=8'} dev: true - /bindings@1.5.0: + /bindings/1.5.0: resolution: {integrity: sha512-p2q/t/mhvuOj/UeLlV6566GD/guowlr0hHxClI0W9m7MWYkL1F0hLo+0Aexs9HSPCtR1SXQ0TD3MMKrXZajbiQ==} - requiresBuild: true dependencies: file-uri-to-path: 1.0.0 dev: true optional: true - /birpc@0.2.12: + /birpc/0.2.12: resolution: {integrity: sha512-6Wz9FXuJ/FE4gDH+IGQhrYdalAvAQU1Yrtcu1UlMk3+9mMXxIRXiL+MxUcGokso42s+Fy+YoUXGLOdOs0siV3A==} - /bl@4.1.0: + /bl/4.1.0: resolution: {integrity: sha512-1W07cM9gS6DcLperZfFSj+bWLtaPGSOHWhPiGzXmvVJbRLdG82sH/Kn8EtW1VqWVA54AKf2h5k5BbnIbwF3h6w==} dependencies: buffer: 5.7.1 inherits: 2.0.4 - readable-stream: 3.6.0 + readable-stream: 3.6.2 dev: true - /blob-util@2.0.2: + /blob-util/2.0.2: resolution: {integrity: sha512-T7JQa+zsXXEa6/8ZhHcQEW1UFfVM49Ts65uBkFL6fz2QmrElqmbajIDJvuA0tEhRe5eIjpV9ZF+0RfZR9voJFQ==} dev: true - /bluebird@3.7.2: + /bluebird/3.7.2: resolution: {integrity: sha512-XpNj6GDQzdfW+r2Wnn7xiSAd7TM3jzkxGXBGTtWKuSXv1xUV+azxAm8jdWZN06QTQk+2N2XB9jRDkvbmQmcRtg==} dev: true - /bn.js@4.12.0: + /bn.js/4.12.0: resolution: {integrity: sha512-c98Bf3tPniI+scsdk237ku1Dc3ujXQTSgyiPUDEOe7tRkhrqridvh8klBv0HCEso1OLOYcHuCv/cS6DNxKH+ZA==} dev: true - /bn.js@5.2.1: + /bn.js/5.2.1: resolution: {integrity: sha512-eXRvHzWyYPBuB4NBy0cmYQjGitUrtqwbvlzP3G6VFnNRbsZQIxQ10PbKKHt8gZ/HW/D/747aDl+QkDqg3KQLMQ==} dev: true - /body-parser@1.20.0: - resolution: {integrity: sha512-DfJ+q6EPcGKZD1QWUjSpqp+Q7bDQTsQIF4zfUAtZ6qk+H/3/QRhg9CEp39ss+/T2vw0+HaidC0ecJj/DRLIaKg==} + /body-parser/1.20.1: + resolution: {integrity: sha512-jWi7abTbYwajOytWCQc37VulmWiRae5RyTpaCyDcS5/lMdtwSz5lOpDE67srw/HYe35f1z3fDQw+3txg7gNtWw==} engines: {node: '>= 0.8', npm: 1.2.8000 || >= 1.4.16} dependencies: bytes: 3.1.2 - content-type: 1.0.4 + content-type: 1.0.5 debug: 2.6.9 depd: 2.0.0 destroy: 1.2.0 http-errors: 2.0.0 iconv-lite: 0.4.24 on-finished: 2.4.1 - qs: 6.10.3 + qs: 6.11.0 raw-body: 2.5.1 type-is: 1.6.18 unpipe: 1.0.0 @@ -11402,15 +9452,15 @@ packages: - supports-color dev: true - /body-scroll-lock@4.0.0-beta.0: + /body-scroll-lock/4.0.0-beta.0: resolution: {integrity: sha512-a7tP5+0Mw3YlUJcGAKUqIBkYYGlYxk2fnCasq/FUph1hadxlTRjF+gAcZksxANnaMnALjxEddmSi/H3OR8ugcQ==} dev: true - /boolbase@1.0.0: + /boolbase/1.0.0: resolution: {integrity: sha512-JZOSA7Mo9sNGB8+UjSgzdLtokWAky1zbztM3WRLCbZ70/3cTANmQmOdR7y2g+J0e2WXywy1yS468tY+IruqEww==} dev: true - /boxen@5.1.2: + /boxen/5.1.2: resolution: {integrity: sha512-9gYgQKXx+1nP8mP7CzFyaUARhg7D3n1dF/FnErWmu9l6JvGpNUN278h0aSb+QjoiKSWG+iZ3uHrcqk0qrY9RQQ==} engines: {node: '>=10'} dependencies: @@ -11424,26 +9474,26 @@ packages: wrap-ansi: 7.0.0 dev: true - /bplist-parser@0.1.1: + /bplist-parser/0.1.1: resolution: {integrity: sha512-2AEM0FXy8ZxVLBuqX0hqt1gDwcnz2zygEkQ6zaD5Wko/sB9paUNwlpawrFtKeHUAQUOzjVy9AO4oeonqIHKA9Q==} dependencies: big-integer: 1.6.51 dev: true optional: true - /brace-expansion@1.1.11: + /brace-expansion/1.1.11: resolution: {integrity: sha512-iCuPHDFgrHX7H2vEI/5xpz07zSHB00TpugqhmYtVmMO6518mCuRMoOYFldEBl0g187ufozdaHgWKcYFb61qGiA==} dependencies: balanced-match: 1.0.2 concat-map: 0.0.1 - /brace-expansion@2.0.1: + /brace-expansion/2.0.1: resolution: {integrity: sha512-XnAIvQ8eM+kC6aULx6wuQiwVsnzsi9d3WxzV3FpWTGA19F621kwdbsAcFKXgKUHZWsy+mY6iL1sHTxWEFCytDA==} dependencies: balanced-match: 1.0.2 dev: true - /braces@2.3.2: + /braces/2.3.2: resolution: {integrity: sha512-aNdbnj9P8PjdXU4ybaWLK2IF3jc/EoDYbC7AazW6to3TRsfXxscC9UXOB5iDiEQrkyIbWp2SLQda4+QAa7nc3w==} engines: {node: '>=0.10.0'} dependencies: @@ -11461,16 +9511,16 @@ packages: - supports-color dev: true - /braces@3.0.2: + /braces/3.0.2: resolution: {integrity: sha512-b8um+L1RzM3WDSzvhm6gIz1yfTbBt6YTlcEKAvsmqCZZFw46z626lVj9j1yEPW33H5H+lBQpZMP1k8l+78Ha0A==} engines: {node: '>=8'} dependencies: fill-range: 7.0.1 - /broadcast-channel@3.7.0: + /broadcast-channel/3.7.0: resolution: {integrity: sha512-cIAKJXAxGJceNZGTZSBzMxzyOn72cVgPnKx4dc6LRjQgbaJUQqhy5rzL3zbMxkMWsGKkv2hSFkPRMEXfoMZ2Mg==} dependencies: - '@babel/runtime': 7.18.9 + '@babel/runtime': 7.22.6 detect-node: 2.1.0 js-sha3: 0.8.0 microseconds: 0.2.0 @@ -11480,15 +9530,11 @@ packages: unload: 2.2.0 dev: false - /brorand@1.1.0: + /brorand/1.1.0: resolution: {integrity: sha512-cKV8tMCEpQs4hK/ik71d6LrPOnpkpGBR0wzxqr68g2m/LB2GxVYQroAjMJZRVM1Y4BCjCKc3vAamxSzOY2RP+w==} dev: true - /browser-process-hrtime@1.0.0: - resolution: {integrity: sha512-9o5UecI3GhkpM6DrXr69PblIuWxPKk9Y0jHBRhdocZ2y7YECBFCsHm79Pr3OyR2AvjhDkabFJaDJMYRazHgsow==} - dev: true - - /browserify-aes@1.2.0: + /browserify-aes/1.2.0: resolution: {integrity: sha512-+7CHXqGuspUn/Sl5aO7Ea0xWGAtETPXNSAjHo48JfLdPWcMng33Xe4znFvQweqc/uzk5zSOI3H52CYnjCfb5hA==} dependencies: buffer-xor: 1.0.3 @@ -11499,7 +9545,7 @@ packages: safe-buffer: 5.2.1 dev: true - /browserify-cipher@1.0.1: + /browserify-cipher/1.0.1: resolution: {integrity: sha512-sPhkz0ARKbf4rRQt2hTpAHqn47X3llLkUGn+xEJzLjwY8LRs2p0v7ljvI5EyoRO/mexrNunNECisZs+gw2zz1w==} dependencies: browserify-aes: 1.2.0 @@ -11507,23 +9553,23 @@ packages: evp_bytestokey: 1.0.3 dev: true - /browserify-des@1.0.2: + /browserify-des/1.0.2: resolution: {integrity: sha512-BioO1xf3hFwz4kc6iBhI3ieDFompMhrMlnDFC4/0/vd5MokpuAc3R+LYbwTA9A5Yc9pq9UYPqffKpW2ObuwX5A==} dependencies: cipher-base: 1.0.4 - des.js: 1.0.1 + des.js: 1.1.0 inherits: 2.0.4 safe-buffer: 5.2.1 dev: true - /browserify-rsa@4.1.0: + /browserify-rsa/4.1.0: resolution: {integrity: sha512-AdEER0Hkspgno2aR97SAf6vi0y0k8NuOpGnVH3O99rcA5Q6sh8QxcngtHuJ6uXwnfAXNM4Gn1Gb7/MV1+Ymbog==} dependencies: bn.js: 5.2.1 randombytes: 2.1.0 dev: true - /browserify-sign@4.2.1: + /browserify-sign/4.2.1: resolution: {integrity: sha512-/vrA5fguVAKKAVTNJjgSm1tRQDHUU6DbwO9IROu/0WAzC8PKhucDSh18J0RMvVeHAn5puMd+QHC2erPRNf8lmg==} dependencies: bn.js: 5.2.1 @@ -11533,45 +9579,45 @@ packages: elliptic: 6.5.4 inherits: 2.0.4 parse-asn1: 5.1.6 - readable-stream: 3.6.0 + readable-stream: 3.6.2 safe-buffer: 5.2.1 dev: true - /browserify-zlib@0.2.0: + /browserify-zlib/0.2.0: resolution: {integrity: sha512-Z942RysHXmJrhqk88FmKBVq/v5tqmSkDz7p54G/MGyjMnCFFnC79XWNbg+Vta8W6Wb2qtSZTSxIGkJrRpCFEiA==} dependencies: pako: 1.0.11 dev: true - /browserslist@4.21.3: - resolution: {integrity: sha512-898rgRXLAyRkM1GryrrBHGkqA5hlpkV5MhtZwg9QXeiyLUYs2k00Un05aX5l2/yJIOObYKOpS2JNo8nJDE7fWQ==} + /browserslist/4.21.9: + resolution: {integrity: sha512-M0MFoZzbUrRU4KNfCrDLnvyE7gub+peetoTid3TBIqtunaDJyXlwhakT+/VkvSXcfIzFfK/nkCs4nmyTmxdNSg==} engines: {node: ^6 || ^7 || ^8 || ^9 || ^10 || ^11 || ^12 || >=13.7} hasBin: true dependencies: - caniuse-lite: 1.0.30001385 - electron-to-chromium: 1.4.237 - node-releases: 2.0.6 - update-browserslist-db: 1.0.5(browserslist@4.21.3) + caniuse-lite: 1.0.30001515 + electron-to-chromium: 1.4.457 + node-releases: 2.0.13 + update-browserslist-db: 1.0.11_browserslist@4.21.9 - /bser@2.1.1: + /bser/2.1.1: resolution: {integrity: sha512-gQxTNE/GAfIIrmHLUE3oJyp5FO6HRBfhjnw4/wMmA63ZGDJnWBmgY/lyQBpnDUkGmAhbSe39tx2d/iTOAfglwQ==} dependencies: node-int64: 0.4.0 dev: true - /buffer-crc32@0.2.13: + /buffer-crc32/0.2.13: resolution: {integrity: sha512-VO9Ht/+p3SN7SKWqcrgEzjGbRSJYTx+Q1pTQC0wrWqHx0vpJraQ6GtHx8tvcg1rlK1byhU5gccxgOgj7B0TDkQ==} dev: true - /buffer-from@1.1.2: + /buffer-from/1.1.2: resolution: {integrity: sha512-E+XQCRwSbaaiChtv6k6Dwgc+bx+Bs6vuKJHHl5kox/BaKbhiXzqQOwK4cO22yElGp2OCmjwVhT3HmxgyPGnJfQ==} dev: true - /buffer-xor@1.0.3: + /buffer-xor/1.0.3: resolution: {integrity: sha512-571s0T7nZWK6vB67HI5dyUF7wXiNcfaPPPTl6zYCNApANjIvYJTg7hlud/+cJpdAhS7dVzqMLmfhfHR3rAcOjQ==} dev: true - /buffer@4.9.2: + /buffer/4.9.2: resolution: {integrity: sha512-xq+q3SRMOxGivLhBNaUdC64hDTQwejJ+H0T/NB1XMtTVEwNTrfFF3gAxiyW0Bu/xWEGhjVKgUcMhCrUy2+uCWg==} dependencies: base64-js: 1.5.1 @@ -11579,89 +9625,96 @@ packages: isarray: 1.0.0 dev: true - /buffer@5.7.1: + /buffer/5.7.1: resolution: {integrity: sha512-EHcyIPBQ4BSGlvjB16k5KgAJ27CIsHY/2JBmCRReo48y9rQ3MaUzWX3KVlBa4U7MyX02HdVj0K7C3WaB3ju7FQ==} dependencies: base64-js: 1.5.1 ieee754: 1.2.1 dev: true - /builtin-modules@3.3.0: + /buffer/6.0.3: + resolution: {integrity: sha512-FTiCpNxtwiZZHEZbcbTIcZjERVICn9yq/pDFkTl95/AxzD1naBctN7YO68riM/gLSDY7sdrMby8hofADYuuqOA==} + dependencies: + base64-js: 1.5.1 + ieee754: 1.2.1 + dev: true + + /builtin-modules/3.3.0: resolution: {integrity: sha512-zhaCDicdLuWN5UbN5IMnFqNMhNfo919sH85y2/ea+5Yg9TsTkeZxpL+JLbp6cgYFS4sRLp3YV4S6yDuqVWHYOw==} engines: {node: '>=6'} dev: true - /builtin-status-codes@3.0.0: + /builtin-status-codes/3.0.0: resolution: {integrity: sha512-HpGFw18DgFWlncDfjTa2rcQ4W88O1mC8e8yZ2AvQY5KDaktSTwo+KRf6nHK6FRI5FyRyb/5T6+TSxfP7QyGsmQ==} dev: true - /builtins@5.0.1: + /builtins/5.0.1: resolution: {integrity: sha512-qwVpFEHNfhYJIzNRBvd2C1kyo6jz3ZSMPyyuR47OPdiKWlbYnZNyDWuyR175qDnAJLiCo5fBBqPb3RiXgWlkOQ==} dependencies: semver: 7.5.4 dev: true - /bumpp@9.1.1: + /bumpp/9.1.1: resolution: {integrity: sha512-T7/2QmRNhHRkH2+HgDs/xk4keom3nlCjwQn6kHdz0I0dQMVrs+YMOH5HyuhV0R3tha/tTYP030RG9uQKpQ9CRg==} engines: {node: '>=10'} hasBin: true dependencies: '@jsdevtools/ez-spawn': 3.0.4 - c12: 1.4.1 + c12: 1.4.2 cac: 6.7.14 fast-glob: 3.3.0 prompts: 2.4.2 - semver: 7.5.2 + semver: 7.5.4 transitivePeerDependencies: - supports-color dev: true - /bundle-require@4.0.1(esbuild@0.17.18): + /bundle-require/4.0.1_esbuild@0.17.19: resolution: {integrity: sha512-9NQkRHlNdNpDBGmLpngF3EFDcwodhMUuLz9PaWYciVcQF9SE4LFjM2DB/xV1Li5JiuDMv7ZUWuC3rGbqR0MAXQ==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} peerDependencies: esbuild: '>=0.17' dependencies: - esbuild: 0.17.18 - load-tsconfig: 0.2.3 + esbuild: 0.17.19 + load-tsconfig: 0.2.5 dev: true - /busboy@1.6.0: + /busboy/1.6.0: resolution: {integrity: sha512-8SFQbg/0hQ9xy3UNTB0YEnsNBbWfhf7RtnzpL7TkBiTBRfrQ9Fxcnz7VJsleJpyp6rVLvXiuORqjlHi5q+PYuA==} engines: {node: '>=10.16.0'} dependencies: streamsearch: 1.1.0 dev: true - /bytes@3.0.0: + /bytes/3.0.0: resolution: {integrity: sha512-pMhOfFDPiv9t5jjIXkHosWmkSyQbvsgEVNkz0ERHbuLh2T/7j4Mqqpz523Fe8MVY89KC6Sh/QfS2sM+SjgFDcw==} engines: {node: '>= 0.8'} dev: true - /bytes@3.1.2: + /bytes/3.1.2: resolution: {integrity: sha512-/Nf7TyzTx6S3yRJObOAV7956r8cr2+Oj8AC5dt8wSP3BQAoeX58NoHyCU8P8zGkNXStjTSi6fzO6F0pBdcYbEg==} engines: {node: '>= 0.8'} dev: true - /c12@1.4.1: - resolution: {integrity: sha512-0x7pWfLZpZsgtyotXtuepJc0rZYE0Aw8PwNAXs0jSG9zq6Sl5xmbWnFqfmRY01ieZLHNbvneSFm9/x88CvzAuw==} + /c12/1.4.2: + resolution: {integrity: sha512-3IP/MuamSVRVw8W8+CHWAz9gKN4gd+voF2zm/Ln6D25C2RhytEZ1ABbC8MjKr4BR9rhoV1JQ7jJA158LDiTkLg==} dependencies: chokidar: 3.5.3 defu: 6.1.2 - dotenv: 16.0.3 + dotenv: 16.3.1 giget: 1.1.2 - jiti: 1.18.2 + jiti: 1.19.1 mlly: 1.4.0 ohash: 1.1.2 pathe: 1.1.1 - perfect-debounce: 0.1.3 + perfect-debounce: 1.0.0 pkg-types: 1.0.3 - rc9: 2.1.0 + rc9: 2.1.1 transitivePeerDependencies: - supports-color dev: true - /c8@7.14.0: + /c8/7.14.0: resolution: {integrity: sha512-i04rtkkcNcCf7zsQcSv/T9EbUn4RXQ6mropeMcjFOsQXQ0iGLAr/xT6TImQg4+U9hmNpN9XdvPkjUL1IzbgxJw==} engines: {node: '>=10.12.0'} hasBin: true @@ -11680,31 +9733,31 @@ packages: yargs-parser: 20.2.9 dev: true - /cac@6.7.14: + /cac/6.7.14: resolution: {integrity: sha512-b6Ilus+c3RrdDk+JhLKUAQfzzgLEPy6wcXqS7f/xe1EETvsDP6GORG7SFuOs6cID5YkqchW/LXZbX5bc8j7ZcQ==} engines: {node: '>=8'} - /cacache@12.0.4: + /cacache/12.0.4: resolution: {integrity: sha512-a0tMB40oefvuInr4Cwb3GerbL9xTj1D5yg0T5xrjGCGyfvbxseIXX7BAO/u/hIXdafzOI5JC3wDwHyf24buOAQ==} dependencies: bluebird: 3.7.2 chownr: 1.1.4 figgy-pudding: 3.5.2 glob: 7.2.3 - graceful-fs: 4.2.10 + graceful-fs: 4.2.11 infer-owner: 1.0.4 lru-cache: 5.1.1 mississippi: 3.0.0 mkdirp: 0.5.6 move-concurrently: 1.0.1 - promise-inflight: 1.0.1(bluebird@3.7.2) + promise-inflight: 1.0.1_bluebird@3.7.2 rimraf: 2.7.1 ssri: 6.0.2 unique-filename: 1.1.1 y18n: 4.0.3 dev: true - /cacache@15.3.0: + /cacache/15.3.0: resolution: {integrity: sha512-VVdYzXEn+cnbXpFgWs5hTT7OScegHVmLhJIR8Ufqk3iFD6A6j5iSX1KuBTfNEv4tdJWE2PzA6IVFtcLC7fN9wQ==} engines: {node: '>= 10'} dependencies: @@ -11715,22 +9768,22 @@ packages: glob: 7.2.3 infer-owner: 1.0.4 lru-cache: 6.0.0 - minipass: 3.3.4 + minipass: 3.3.6 minipass-collect: 1.0.2 minipass-flush: 1.0.5 minipass-pipeline: 1.2.4 mkdirp: 1.0.4 p-map: 4.0.0 - promise-inflight: 1.0.1(bluebird@3.7.2) + promise-inflight: 1.0.1 rimraf: 3.0.2 ssri: 8.0.1 - tar: 6.1.13 + tar: 6.1.15 unique-filename: 1.1.1 transitivePeerDependencies: - bluebird dev: true - /cache-base@1.0.1: + /cache-base/1.0.1: resolution: {integrity: sha512-AKcdTnFSWATd5/GCPRxr2ChwIJ85CeyrEyjRHlKxQ56d4XJMGym0uAiKn0xbLOGOl3+yRpOTi484dVCEc5AUzQ==} engines: {node: '>=0.10.0'} dependencies: @@ -11745,13 +9798,13 @@ packages: unset-value: 1.0.0 dev: true - /cacheable-lookup@7.0.0: + /cacheable-lookup/7.0.0: resolution: {integrity: sha512-+qJyx4xiKra8mZrcwhjMRMUhD5NR1R8esPkzIYxX96JiecFoxAXFuz/GpR3+ev4PE1WamHip78wV0vcmPQtp8w==} engines: {node: '>=14.16'} dev: true - /cacheable-request@10.2.8: - resolution: {integrity: sha512-IDVO5MJ4LItE6HKFQTqT2ocAQsisOoCTUDu1ddCmnhyiwFQjXNPp4081Xj23N4tO+AFEFNzGuNEf/c8Gwwt15A==} + /cacheable-request/10.2.12: + resolution: {integrity: sha512-qtWGB5kn2OLjx47pYUkWicyOpK1vy9XZhq8yRTXOy+KAmjjESSRLx6SiExnnaGGUP1NM6/vmygMu0fGylNh9tw==} engines: {node: '>=14.16'} dependencies: '@types/http-cache-semantics': 4.0.1 @@ -11763,39 +9816,39 @@ packages: responselike: 3.0.0 dev: true - /cachedir@2.3.0: + /cachedir/2.3.0: resolution: {integrity: sha512-A+Fezp4zxnit6FanDmv9EqXNAi3vt9DWp51/71UEhXukb7QUuvtv9344h91dyAxuTLoSYJFU299qzR3tzwPAhw==} engines: {node: '>=6'} dev: true - /call-bind@1.0.2: + /call-bind/1.0.2: resolution: {integrity: sha512-7O+FbCihrB5WGbFYesctwmTKae6rOiIzmz1icreWJ+0aA7LJfuqhEso2T9ncpcFtzMQtzXf2QGGueWJGTYsqrA==} dependencies: function-bind: 1.1.1 - get-intrinsic: 1.2.0 + get-intrinsic: 1.2.1 dev: true - /call-me-maybe@1.0.2: + /call-me-maybe/1.0.2: resolution: {integrity: sha512-HpX65o1Hnr9HH25ojC1YGs7HCQLq0GCOibSaWER0eNpgJ/Z1MZv2mTc7+xh6WOPxbRVcmgbv4hGU+uSQ/2xFZQ==} dev: true - /callsites@3.1.0: + /callsites/3.1.0: resolution: {integrity: sha512-P8BjAsXvZS+VIDUI11hHCQEv74YT67YUi5JJFNWIqL235sBmjX4+qx9Muvls5ivyNENctx46xQLQ3aTuE7ssaQ==} engines: {node: '>=6'} - /camel-case@4.1.2: + /camel-case/4.1.2: resolution: {integrity: sha512-gxGWBrTT1JuMx6R+o5PTXMmUnhnVzLQ9SNutD4YqKtI6ap897t3tKECYla6gCWEkplXnlNybEkZg9GEGxKFCgw==} dependencies: pascal-case: 3.1.2 - tslib: 2.5.3 + tslib: 2.6.0 dev: true - /camelcase-css@2.0.1: + /camelcase-css/2.0.1: resolution: {integrity: sha512-QOSvevhslijgYwRx6Rv7zKdMF8lbRmx+uQGx2+vDc+KI/eBnsy9kit5aj23AgGu3pa4t9AgwbnXWqS+iOY+2aA==} engines: {node: '>= 6'} dev: true - /camelcase-keys@2.1.0: + /camelcase-keys/2.1.0: resolution: {integrity: sha512-bA/Z/DERHKqoEOrp+qeGKw1QlvEQkGZSc0XaY6VnTxZr+Kv1G5zFwttpjv8qxZ/sBPT4nthwZaAcsAZTJlSKXQ==} engines: {node: '>=0.10.0'} dependencies: @@ -11804,51 +9857,51 @@ packages: dev: true optional: true - /camelcase@2.1.1: + /camelcase/2.1.1: resolution: {integrity: sha512-DLIsRzJVBQu72meAKPkWQOLcujdXT32hwdfnkI1frSiSRMK1MofjKHf+MEx0SB6fjEFXL8fBDv1dKymBlOp4Qw==} engines: {node: '>=0.10.0'} dev: true optional: true - /camelcase@5.3.1: + /camelcase/5.3.1: resolution: {integrity: sha512-L28STB170nwWS63UjtlEOE3dldQApaJXZkOI1uMFfzf3rRuPegHaHesyee+YxQ+W6SvRDQV6UrdOdRiR153wJg==} engines: {node: '>=6'} dev: true - /camelcase@6.3.0: + /camelcase/6.3.0: resolution: {integrity: sha512-Gmy6FhYlCY7uOElZUSbxo2UCDH8owEk996gkbrpsgGtrJLM3J7jGxl9Ic7Qwwj4ivOE5AWZWRMecDdF7hqGjFA==} engines: {node: '>=10'} dev: true - /caniuse-lite@1.0.30001385: - resolution: {integrity: sha512-MpiCqJGhBkHgpyimE9GWmZTnyHyEEM35u115bD3QBrXpjvL/JgcP8cUhKJshfmg4OtEHFenifcK5sZayEw5tvQ==} + /caniuse-lite/1.0.30001515: + resolution: {integrity: sha512-eEFDwUOZbE24sb+Ecsx3+OvNETqjWIdabMy52oOkIgcUtAsQifjUG9q4U9dgTHJM2mfk4uEPxc0+xuFdJ629QA==} - /capture-exit@2.0.0: + /capture-exit/2.0.0: resolution: {integrity: sha512-PiT/hQmTonHhl/HFGN+Lx3JJUznrVYJ3+AQsnthneZbvW7x+f08Tk7yLJTLEOUvBTbduLeeBkxEaYXUOUrRq6g==} engines: {node: 6.* || 8.* || >= 10.*} dependencies: rsvp: 4.8.5 dev: true - /case-sensitive-paths-webpack-plugin@2.4.0: + /case-sensitive-paths-webpack-plugin/2.4.0: resolution: {integrity: sha512-roIFONhcxog0JSSWbvVAh3OocukmSgpqOH6YpMkCvav/ySIV3JKg4Dc8vYtQjYi/UxpNE36r/9v+VqTQqgkYmw==} engines: {node: '>=4'} dev: true - /caseless@0.12.0: + /caseless/0.12.0: resolution: {integrity: sha512-4tYFyifaFfGacoiObjJegolkwSU4xQNGbVgUiNYVUxbQ2x2lUsFvY4hVgVzGiIe6WLOPqycWXA40l+PWsxthUw==} dev: true - /ccount@1.1.0: + /ccount/1.1.0: resolution: {integrity: sha512-vlNK021QdI7PNeiUh/lKkC/mNHHfV0m/Ad5JoI0TYtlBnJAslM/JIkm/tGC88bkLIwO6OQ5uV6ztS6kVAtCDlg==} dev: true - /chai-subset@1.6.0: + /chai-subset/1.6.0: resolution: {integrity: sha512-K3d+KmqdS5XKW5DWPd5sgNffL3uxdDe+6GdnJh3AYPhwnBGRY5urfvfcbRtWIvvpz+KxkL9FeBB6MZewLUNwug==} engines: {node: '>=4'} dev: true - /chai@4.3.7: + /chai/4.3.7: resolution: {integrity: sha512-HLnAzZ2iupm25PlN0xFreAlBA5zaBSv3og0DdeGA4Ar6h6rJ3A0rolRUKJhSF2V10GZKDgWF/VmAEsNWjCRB+A==} engines: {node: '>=4'} dependencies: @@ -11861,7 +9914,7 @@ packages: type-detect: 4.0.8 dev: false - /chalk@1.1.3: + /chalk/1.1.3: resolution: {integrity: sha512-U3lRVLMSlsCfjqYPbLyVv11M9CPW4I728d6TCKMAOJueEeB9/8o+eSsMnxPJD+Q+K909sdESg7C+tIkoH6on1A==} engines: {node: '>=0.10.0'} dependencies: @@ -11872,7 +9925,7 @@ packages: supports-color: 2.0.0 dev: true - /chalk@2.4.2: + /chalk/2.4.2: resolution: {integrity: sha512-Mti+f9lpJNcwF4tWV8/OrTTtF1gZi+f8FqlyAdouralcFWFQWF2+NgCHShjkCb+IFBLq9buZwE1xckQU4peSuQ==} engines: {node: '>=4'} dependencies: @@ -11880,7 +9933,7 @@ packages: escape-string-regexp: 1.0.5 supports-color: 5.5.0 - /chalk@3.0.0: + /chalk/3.0.0: resolution: {integrity: sha512-4D3B6Wf41KOYRFdszmDqMCGq5VV/uMAB273JILmO+3jAlh8X4qDtdtgCR3fxtbLEMzSx22QdhnDcJvu2u1fVwg==} engines: {node: '>=8'} dependencies: @@ -11888,7 +9941,7 @@ packages: supports-color: 7.2.0 dev: true - /chalk@4.1.1: + /chalk/4.1.1: resolution: {integrity: sha512-diHzdDKxcU+bAsUboHLPEDQiw0qEe0qd7SYUn3HgcFlWgbDcfLGswOHYeGrHKzG9z6UYf01d9VFMfZxPM1xZSg==} engines: {node: '>=10'} dependencies: @@ -11896,7 +9949,7 @@ packages: supports-color: 7.2.0 dev: true - /chalk@4.1.2: + /chalk/4.1.2: resolution: {integrity: sha512-oKnbhFyRIXpUuez8iBMmyEa4nbj4IOQyuhc/wy9kY7/WVPcwIO9VA668Pu8RkO7+0G76SLROeyw9CpQ061i4mA==} engines: {node: '>=10'} dependencies: @@ -11904,42 +9957,42 @@ packages: supports-color: 7.2.0 dev: true - /chalk@5.2.0: + /chalk/5.2.0: resolution: {integrity: sha512-ree3Gqw/nazQAPuJJEy+avdl7QfZMcUvmHIKgEZkGL+xOBzRvup5Hxo6LHuMceSxOabuJLJm5Yp/92R9eMmMvA==} engines: {node: ^12.17.0 || ^14.13 || >=16.0.0} dev: true - /char-regex@1.0.2: - resolution: {integrity: sha512-kWWXztvZ5SBQV+eRgKFeh8q5sLuZY2+8WUIzlxWVTg+oGwY14qylx1KbKzHd8P6ZYkAg0xyIDU9JMHhyJMZ1jw==} - engines: {node: '>=10'} + /chalk/5.3.0: + resolution: {integrity: sha512-dLitG79d+GV1Nb/VYcCDFivJeK1hiukt9QjRNVOsUtTy1rR1YJsmpGGTZ3qJos+uw7WmWF4wUwBd9jxjocFC2w==} + engines: {node: ^12.17.0 || ^14.13 || >=16.0.0} dev: true - /character-entities-legacy@1.1.4: + /character-entities-legacy/1.1.4: resolution: {integrity: sha512-3Xnr+7ZFS1uxeiUDvV02wQ+QDbc55o97tIV5zHScSPJpcLm/r0DFPcoY3tYRp+VZukxuMeKgXYmsXQHO05zQeA==} dev: true - /character-entities@1.2.4: + /character-entities/1.2.4: resolution: {integrity: sha512-iBMyeEHxfVnIakwOuDXpVkc54HijNgCyQB2w0VfGQThle6NXn50zU6V/u+LDhxHcDUPojn6Kpga3PTAD8W1bQw==} dev: true - /character-reference-invalid@1.1.4: + /character-reference-invalid/1.1.4: resolution: {integrity: sha512-mKKUkUbhPpQlCOfIuZkvSEgktjPFIsZKRRbC6KWVEMvlzblj3i3asQv5ODsrwt0N3pHAEvjP8KTQPHkp0+6jOg==} dev: true - /chardet@0.7.0: + /chardet/0.7.0: resolution: {integrity: sha512-mT8iDcrh03qDGRRmoA2hmBJnxpllMR+0/0qlzjqZES6NdiWDcZkCNAk4rPFZ9Q85r27unkiNNg8ZOiwZXBHwcA==} dev: true - /check-error@1.0.2: + /check-error/1.0.2: resolution: {integrity: sha512-BrgHpW9NURQgzoNyjfq0Wu6VFO6D7IZEmJNdtgNqpzGG8RuNFHt2jQxWlAs4HMe119chBnv+34syEZtc6IhLtA==} dev: false - /check-more-types@2.24.0: + /check-more-types/2.24.0: resolution: {integrity: sha512-Pj779qHxV2tuapviy1bSZNEL1maXr13bPYpsvSDB68HlYcYuhlDrmGd63i0JHMCLKzc7rUSNIrpdJlhVlNwrxA==} engines: {node: '>= 0.8.0'} dev: true - /cheerio-select@2.1.0: + /cheerio-select/2.1.0: resolution: {integrity: sha512-9v9kG0LvzrlcungtnJtpGNxY+fzECQKhK4EGJX2vByejiMX84MFNQw4UxPJl3bFbTMw+Dfs37XaIkCwTZfLh4g==} dependencies: boolbase: 1.0.0 @@ -11947,28 +10000,28 @@ packages: css-what: 6.1.0 domelementtype: 2.3.0 domhandler: 5.0.3 - domutils: 3.0.1 + domutils: 3.1.0 dev: true - /cheerio@1.0.0-rc.12: + /cheerio/1.0.0-rc.12: resolution: {integrity: sha512-VqR8m68vM46BNnuZ5NtnGBKIE/DfN0cRIzg9n40EIq9NOv90ayxLBXA8fXC5gquFRGJSTRqBq25Jt2ECLR431Q==} engines: {node: '>= 6'} dependencies: cheerio-select: 2.1.0 dom-serializer: 2.0.0 domhandler: 5.0.3 - domutils: 3.0.1 - htmlparser2: 8.0.1 + domutils: 3.1.0 + htmlparser2: 8.0.2 parse5: 7.1.2 parse5-htmlparser2-tree-adapter: 7.0.0 dev: true - /chokidar@2.1.8: + /chokidar/2.1.8: resolution: {integrity: sha512-ZmZUazfOzf0Nve7duiCKD23PFSCs4JPoYyccjUFF3aQkQadqBhfzhjkwBH2mNOG9cTBwhamM37EIsIkZw3nRgg==} deprecated: Chokidar 2 does not receive security updates since 2019. Upgrade to chokidar 3 with 15x fewer dependencies dependencies: anymatch: 2.0.0 - async-each: 1.0.3 + async-each: 1.0.6 braces: 2.3.2 glob-parent: 3.1.0 inherits: 2.0.4 @@ -11985,11 +10038,11 @@ packages: dev: true optional: true - /chokidar@3.5.3: + /chokidar/3.5.3: resolution: {integrity: sha512-Dr3sfKRP6oTcjf2JmUmFJfeVMvXBdegxB0iVQ5eb2V10uFJUCAS8OByZdVAyVb8xXNz3GjjTgj9kLWsZTqE6kw==} engines: {node: '>= 8.10.0'} dependencies: - anymatch: 3.1.2 + anymatch: 3.1.3 braces: 3.0.2 glob-parent: 5.1.2 is-binary-path: 2.1.0 @@ -12000,34 +10053,34 @@ packages: fsevents: 2.3.2 dev: true - /chownr@1.1.4: + /chownr/1.1.4: resolution: {integrity: sha512-jJ0bqzaylmJtVnNgzTeSOs8DPavpbYgEr/b0YL8/2GO3xJEhInFmhKMUnEJQjZumK7KXGFhUy89PrsJWlakBVg==} dev: true - /chownr@2.0.0: + /chownr/2.0.0: resolution: {integrity: sha512-bIomtDF5KGpdogkLd9VspvFzk9KfpyyGlS8YFVZl7TGPBHL5snIOnxeshwVgPteQ9b4Eydl+pVbIyE1DcvCWgQ==} engines: {node: '>=10'} dev: true - /chrome-launcher@0.15.1: - resolution: {integrity: sha512-UugC8u59/w2AyX5sHLZUHoxBAiSiunUhZa3zZwMH6zPVis0C3dDKiRWyUGIo14tTbZHGVviWxv3PQWZ7taZ4fg==} + /chrome-launcher/0.15.2: + resolution: {integrity: sha512-zdLEwNo3aUVzIhKhTtXfxhdvZhUghrnmkvcAq2NoDd+LeOHKf03H5jwZ8T/STsAlzyALkBVK552iaG1fGf1xVQ==} engines: {node: '>=12.13.0'} hasBin: true dependencies: '@types/node': 20.4.1 escape-string-regexp: 4.0.0 is-wsl: 2.2.0 - lighthouse-logger: 1.3.0 + lighthouse-logger: 1.4.2 transitivePeerDependencies: - supports-color dev: true - /chrome-trace-event@1.0.3: + /chrome-trace-event/1.0.3: resolution: {integrity: sha512-p3KULyQg4S7NIHixdwbGX+nFHkoBiA4YQmyWtjb8XngSKV124nJmRysgAeujbUVb15vh+RvFUfCPqU7rXk+hZg==} engines: {node: '>=6.0'} dev: true - /chromium-bidi@0.4.9(devtools-protocol@0.0.1120988): + /chromium-bidi/0.4.9_5222unh4tkeylqma7dhccidrk4: resolution: {integrity: sha512-u3DC6XwgLCA9QJ5ak1voPslCmacQdulZNCPsI3qNXxSnEcZS7DFIbww+5RM2bznMEje7cc0oydavRLRvOIZtHw==} peerDependencies: devtools-protocol: '*' @@ -12036,32 +10089,23 @@ packages: mitt: 3.0.0 dev: true - /ci-info@2.0.0: + /ci-info/2.0.0: resolution: {integrity: sha512-5tK7EtrZ0N+OLFMthtqOj4fI2Jeb88C4CAZPu25LDVUgXJ0A3Js4PMGqrn0JU1W0Mh1/Z8wZzYPxqUrXeBboCQ==} dev: true - /ci-info@3.7.0: - resolution: {integrity: sha512-2CpRNYmImPx+RXKLq6jko/L07phmS9I02TyqkcNU20GCF/GgaWvc58hPtjxDX8lPpkdwc9sNh72V9k00S7ezog==} - engines: {node: '>=8'} - dev: true - - /ci-info@3.8.0: + /ci-info/3.8.0: resolution: {integrity: sha512-eXTggHWSooYhq49F2opQhuHWgzucfF2YgODK4e1566GQs5BIfP30B0oenwBJHfWxAs2fyPB1s7Mg949zLf61Yw==} engines: {node: '>=8'} dev: true - /cipher-base@1.0.4: + /cipher-base/1.0.4: resolution: {integrity: sha512-Kkht5ye6ZGmwv40uUDZztayT2ThLQGfnj/T71N/XzeZeo3nf8foyW7zGTsPYkEya3m5f3cAypH+qe7YOrM1U2Q==} dependencies: inherits: 2.0.4 safe-buffer: 5.2.1 dev: true - /cjs-module-lexer@1.2.2: - resolution: {integrity: sha512-cOU9usZw8/dXIXKtwa8pM0OTJQuJkxMN6w30csNRUerHfeQ5R6U3kkU/FtJeIf3M202OHfY2U8ccInBG7/xogA==} - dev: true - - /class-utils@0.3.6: + /class-utils/0.3.6: resolution: {integrity: sha512-qOhPa/Fj7s6TY8H8esGu5QNpMMQxz79h+urzrNYN6mn+9BnxlDGf5QZ+XeCDsxSjPqsSR56XOZOJmpeurnLMeg==} engines: {node: '>=0.10.0'} dependencies: @@ -12071,55 +10115,55 @@ packages: static-extend: 0.1.2 dev: true - /classnames@2.3.1: - resolution: {integrity: sha512-OlQdbZ7gLfGarSqxesMesDa5uz7KFbID8Kpq/SxIoNGDqY8lSYs0D+hhtBXhcdB3rcbXArFr7vlHheLk1voeNA==} + /classnames/2.3.2: + resolution: {integrity: sha512-CSbhY4cFEJRe6/GQzIk5qXZ4Jeg5pcsP7b5peFSDpffpe1cqjASH/n9UTjBwOp6XpMSTwQ8Za2K5V02ueA7Tmw==} dev: false - /clean-css@4.2.4: + /clean-css/4.2.4: resolution: {integrity: sha512-EJUDT7nDVFDvaQgAo2G/PJvxmp1o/c6iXLbswsBbUFXi1Nr+AjA2cKmfbKDMjMvzEe75g3P6JkaDDAKk96A85A==} engines: {node: '>= 4.0'} dependencies: source-map: 0.6.1 dev: true - /clean-regexp@1.0.0: + /clean-regexp/1.0.0: resolution: {integrity: sha512-GfisEZEJvzKrmGWkvfhgzcz/BllN1USeqD2V6tg14OAOgaCD2Z/PUEuxnAZ/nPvmaHRG7a8y77p1T/IRQ4D1Hw==} engines: {node: '>=4'} dependencies: escape-string-regexp: 1.0.5 dev: true - /clean-stack@2.2.0: + /clean-stack/2.2.0: resolution: {integrity: sha512-4diC9HaTE+KRAMWhDhrGOECgWZxoevMc5TlkObMqNSsVU62PYzXZ/SMTjzyGAFF1YusgxGcSWTEXBhp0CPwQ1A==} engines: {node: '>=6'} dev: true - /cli-boxes@2.2.1: + /cli-boxes/2.2.1: resolution: {integrity: sha512-y4coMcylgSCdVinjiDBuR8PCC2bLjyGTwEmPb9NHR/QaNU6EUOXcTY/s6VjGMD6ENSEaeQYHCY0GNGS5jfMwPw==} engines: {node: '>=6'} dev: true - /cli-cursor@3.1.0: + /cli-cursor/3.1.0: resolution: {integrity: sha512-I/zHAwsKf9FqGoXM4WWRACob9+SNukZTd94DWF57E4toouRulbCxcUh6RKUEOQlYTHJnzkPMySvPNaaSLNfLZw==} engines: {node: '>=8'} dependencies: restore-cursor: 3.1.0 dev: true - /cli-cursor@4.0.0: + /cli-cursor/4.0.0: resolution: {integrity: sha512-VGtlMu3x/4DOtIUwEkRezxUZ2lBacNJCHash0N0WeZDBS+7Ux1dm3XWAgWYxLJFMMdOeXMHXorshEFhbMSGelg==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dependencies: restore-cursor: 4.0.0 dev: true - /cli-spinners@2.7.0: - resolution: {integrity: sha512-qu3pN8Y3qHNgE2AFweciB1IfMnmZ/fsNTEE+NOFjmGB2F/7rLhnhzppvpCnN4FovtP26k8lHyy9ptEbNwWFLzw==} + /cli-spinners/2.9.0: + resolution: {integrity: sha512-4/aL9X3Wh0yiMQlE+eeRhWP6vclO3QRtw1JHKIT0FFUs5FjpFmESqtMvYZ0+lbzBw900b95mS0hohy+qn2VK/g==} engines: {node: '>=6'} dev: true - /cli-table3@0.6.2: - resolution: {integrity: sha512-QyavHCaIC80cMivimWu4aWHilIpiDpfm3hGmqAmXVL1UsnbLuBSMd21hTX6VY4ZSDSM73ESLeF8TOYId3rBTbw==} + /cli-table3/0.6.3: + resolution: {integrity: sha512-w5Jac5SykAeZJKntOxJCrm63Eg5/4dhMWIcuTbo9rpE+brgaSZo0RuNJZeOyMgsUdhDeojvgyQLmjI+K50ZGyg==} engines: {node: 10.* || >= 12.*} dependencies: string-width: 4.2.3 @@ -12127,7 +10171,7 @@ packages: '@colors/colors': 1.5.0 dev: true - /cli-truncate@2.1.0: + /cli-truncate/2.1.0: resolution: {integrity: sha512-n8fOixwDD6b/ObinzTrp1ZKFzbgvKZvuz/TvejnLn1aQfC6r52XEx85FmuC+3HI+JM7coBRXUvNqEU2PHVrHpg==} engines: {node: '>=8'} dependencies: @@ -12135,7 +10179,7 @@ packages: string-width: 4.2.3 dev: true - /cli-truncate@3.1.0: + /cli-truncate/3.1.0: resolution: {integrity: sha512-wfOBkjXteqSnI59oPcJkcPl/ZmwvMMOj340qUIY1SKZCv0B9Cf4D4fAucRkIKQmsIuYK3x1rrgU7MeGRruiuiA==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dependencies: @@ -12143,17 +10187,17 @@ packages: string-width: 5.1.2 dev: true - /cli-width@3.0.0: + /cli-width/3.0.0: resolution: {integrity: sha512-FxqpkPPwu1HjuN93Omfm4h8uIanXofW0RxVEW3k5RKx+mJJYSthzNhp32Kzxxy3YAEZ/Dc/EWN1vZRY0+kOhbw==} engines: {node: '>= 10'} dev: true - /cli-width@4.0.0: + /cli-width/4.0.0: resolution: {integrity: sha512-ZksGS2xpa/bYkNzN3BAw1wEjsLV/ZKOf/CCrJ/QOBsxx6fOARIkwTutxp1XIOIohi6HKmOFjMoK/XaqDVUpEEw==} engines: {node: '>= 12'} dev: true - /cliui@7.0.4: + /cliui/7.0.4: resolution: {integrity: sha512-OcRE68cOsVMXp1Yvonl/fzkQOyjLSu/8bhPDfQt0e0/Eb283TKP20Fs2MqoPsr9SwA595rRCA+QMzYc9nBP+JQ==} dependencies: string-width: 4.2.3 @@ -12161,7 +10205,7 @@ packages: wrap-ansi: 7.0.0 dev: true - /cliui@8.0.1: + /cliui/8.0.1: resolution: {integrity: sha512-BSeNnyus75C4//NQ9gQt1/csTXyo/8Sb+afLAkzAptFuMsod9HFokGNudZpi/oQV73hnVK+sR+5PVRMd+Dr7YQ==} engines: {node: '>=12'} dependencies: @@ -12170,7 +10214,7 @@ packages: wrap-ansi: 7.0.0 dev: true - /clone-deep@4.0.1: + /clone-deep/4.0.1: resolution: {integrity: sha512-neHB9xuzh/wk0dIHweyAXv2aPGZIVk3pLMe+/RNzINf17fe0OG96QroktYAUm7SM1PBnzTabaLboqqxDyMU+SQ==} engines: {node: '>=6'} dependencies: @@ -12179,48 +10223,39 @@ packages: shallow-clone: 3.0.1 dev: true - /clone@1.0.4: + /clone/1.0.4: resolution: {integrity: sha512-JQHZ2QMW6l3aH/j6xCqQThY/9OH4D/9ls34cgkUBiEeocRTU04tHfKPBsUK1PqZCUQM7GiA0IIXJSuXHI64Kbg==} engines: {node: '>=0.8'} dev: true - /clsx@1.2.1: + /clsx/1.2.1: resolution: {integrity: sha512-EcR6r5a8bj6pu3ycsa/E/cKVGuTgZJZdsyUYHOksG/UHIiKfjxzRxYJpyVBwYaQeOvghal9fcc4PidlgzugAQg==} engines: {node: '>=6'} dev: false - /co@4.6.0: - resolution: {integrity: sha512-QVb0dM5HvG+uaxitm8wONl7jltx8dqhfU33DcqtOZcLSVIKSDDLDi7+0LbAKiyI8hD9u42m2YxXSkMGWThaecQ==} - engines: {iojs: '>= 1.0.0', node: '>= 0.12.0'} - dev: true - - /code-red@1.0.3: + /code-red/1.0.3: resolution: {integrity: sha512-kVwJELqiILQyG5aeuyKFbdsI1fmQy1Cmf7dQ8eGmVuJoaRVdwey7WaMknr2ZFeVSYSKT0rExsa8EGw0aoI/1QQ==} dependencies: '@jridgewell/sourcemap-codec': 1.4.15 '@types/estree': 1.0.1 - acorn: 8.9.0 + acorn: 8.10.0 estree-walker: 3.0.3 periscopic: 3.1.0 dev: true - /codemirror-theme-vars@0.1.2: + /codemirror-theme-vars/0.1.2: resolution: {integrity: sha512-WTau8X2q58b0SOAY9DO+iQVw8JKVEgyQIqArp2D732tcc+pobbMta3bnVMdQdmgwuvNrOFFr6HoxPRoQOgooFA==} dev: true - /codemirror@5.65.13: + /codemirror/5.65.13: resolution: {integrity: sha512-SVWEzKXmbHmTQQWaz03Shrh4nybG0wXx2MEu3FO4ezbPW8IbnZEd5iGHGEffSUaitKYa3i+pHpBsSvw8sPHtzg==} dev: true - /collapse-white-space@1.0.6: + /collapse-white-space/1.0.6: resolution: {integrity: sha512-jEovNnrhMuqyCcjfEJA56v0Xq8SkIoPKDyaHahwo3POf4qcSXqMYuwNcOTzp74vTsR9Tn08z4MxWqAhcekogkQ==} dev: true - /collect-v8-coverage@1.0.1: - resolution: {integrity: sha512-iBPtljfCNcTKNAto0KEtDfZ3qzjJvqE3aTGZsbhjSBlorqpXJlaWWtPO35D+ZImoC3KWejX64o+yPGxhWSTzfg==} - dev: true - - /collection-visit@1.0.0: + /collection-visit/1.0.0: resolution: {integrity: sha512-lNkKvzEeMBBjUGHZ+q6z9pSJla0KWAQPvtzhEV9+iGyQYG+pBpl7xKDhxoNSOZH2hhv0v5k0y2yAM4o4SjoSkw==} engines: {node: '>=0.10.0'} dependencies: @@ -12228,38 +10263,38 @@ packages: object-visit: 1.0.1 dev: true - /color-convert@1.9.3: + /color-convert/1.9.3: resolution: {integrity: sha512-QfAUtd+vFdAtFQcC8CCyYt1fYWxSqAiK2cSD6zDB8N3cpsEBAvRxp9zOGg6G/SHHJYAT88/az/IuDGALsNVbGg==} dependencies: color-name: 1.1.3 - /color-convert@2.0.1: + /color-convert/2.0.1: resolution: {integrity: sha512-RRECPsj7iu/xb5oKYcsFHSppFNnsj/52OVTRKb4zP5onXwVF3zVmmToNcOfGC+CRDpfK/U584fMg38ZHCaElKQ==} engines: {node: '>=7.0.0'} dependencies: color-name: 1.1.4 dev: true - /color-name@1.1.3: + /color-name/1.1.3: resolution: {integrity: sha512-72fSenhMw2HZMTVHeCA9KCmpEIbzWiQsjN+BHcBbS9vr1mtt+vJjPdksIBNUmKAW8TFUDPJK5SUU3QhE9NEXDw==} - /color-name@1.1.4: + /color-name/1.1.4: resolution: {integrity: sha512-dOy+3AuW3a2wNbZHIuMZpTcgjGuLU/uBL/ubcZF9OXbDo8ff4O8yVp5Bf0efS8uEoYo5q4Fx7dY9OgQGXgAsQA==} dev: true - /color-string@1.9.1: + /color-string/1.9.1: resolution: {integrity: sha512-shrVawQFojnZv6xM40anx4CkoDP+fZsw/ZerEMsW/pyzsRbElpsL/DBVW7q3ExxwusdNXI3lXpuhEZkzs8p5Eg==} dependencies: color-name: 1.1.4 simple-swizzle: 0.2.2 dev: true - /color-support@1.1.3: + /color-support/1.1.3: resolution: {integrity: sha512-qiBjkpbMLO/HL68y+lh4q0/O1MZFj2RX6X/KmMa3+gJD3z+WwI1ZzDHysvqHGS3mP6mznPckpXmw1nI9cJjyRg==} hasBin: true dev: true - /color@4.2.3: + /color/4.2.3: resolution: {integrity: sha512-1rXeuUUiGGrykh+CeBdu5Ie7OJwinCgQY0bc7GCRxy5xVHy+moaqkpL/jqQq0MtQOeYcrqEz4abc5f0KtU7W4A==} engines: {node: '>=12.5.0'} dependencies: @@ -12267,79 +10302,79 @@ packages: color-string: 1.9.1 dev: true - /colorette@2.0.20: + /colorette/2.0.20: resolution: {integrity: sha512-IfEDxwoWIjkeXL1eXcDiow4UbKjhLdq6/EuSVR9GMN7KVH3r9gQ83e73hsz1Nd1T3ijd5xv1wcWRYO+D6kCI2w==} dev: true - /combined-stream@1.0.8: + /combined-stream/1.0.8: resolution: {integrity: sha512-FQN4MRfuJeHf7cBbBMJFXhKSDq+2kAArBlmRBvcvFE5BB1HZKXtSFASDhdlz9zOYwxh8lDdnvmMOe/+5cdoEdg==} engines: {node: '>= 0.8'} dependencies: delayed-stream: 1.0.0 dev: true - /comma-separated-tokens@1.0.8: + /comma-separated-tokens/1.0.8: resolution: {integrity: sha512-GHuDRO12Sypu2cV70d1dkA2EUmXHgntrzbpvOB+Qy+49ypNfGgFQIC2fhhXbnyrJRynDCAARsT7Ou0M6hirpfw==} dev: true - /commander@10.0.0: - resolution: {integrity: sha512-zS5PnTI22FIRM6ylNW8G4Ap0IEOyk62fhLSD0+uHRT9McRCLGpkVNvao4bjimpK/GShynyQkFFxHhwMcETmduA==} + /commander/10.0.1: + resolution: {integrity: sha512-y4Mg2tXshplEbSGzx7amzPwKKOCGuoSRP/CjEdwwk0FOGlUbq6lKuoyDZTNZkmxHdJtp54hdfY/JUrdL7Xfdug==} engines: {node: '>=14'} dev: true - /commander@2.20.3: + /commander/2.20.3: resolution: {integrity: sha512-GpVkmM8vF2vQUkj2LvZmD35JxeJOLCwJ9cUkugyk2nuhbv3+mJvpLYYt+0+USMxE+oj+ey/lJEnhZw75x/OMcQ==} dev: true - /commander@4.1.1: + /commander/4.1.1: resolution: {integrity: sha512-NOKm8xhkzAjzFx8B2v5OAHT+u5pRQc2UCa2Vq9jYL/31o2wi9mxBA7LIFs3sV5VSC49z6pEhfbMULvShKj26WA==} engines: {node: '>= 6'} dev: true - /commander@6.2.1: + /commander/6.2.1: resolution: {integrity: sha512-U7VdrJFnJgo4xjrHpTzu0yrHPGImdsmD95ZlgYSEajAn2JKzDhDTPG9kBTefmObL2w/ngeZnilk+OV9CG3d7UA==} engines: {node: '>= 6'} dev: true - /commenting@1.1.0: + /commenting/1.1.0: resolution: {integrity: sha512-YeNK4tavZwtH7jEgK1ZINXzLKm6DZdEMfsaaieOsCAN0S8vsY7UeuO3Q7d/M018EFgE+IeUAuBOKkFccBZsUZA==} dev: true - /common-path-prefix@3.0.0: + /common-path-prefix/3.0.0: resolution: {integrity: sha512-QE33hToZseCH3jS0qN96O/bSh3kaw/h+Tq7ngyY9eWDUnTlTNUyqfqvCXioLe5Na5jFsL78ra/wuBU4iuEgd4w==} dev: true - /common-tags@1.8.2: + /common-tags/1.8.2: resolution: {integrity: sha512-gk/Z852D2Wtb//0I+kRFNKKE9dIIVirjoqPoA1wJU+XePVXZfGeBpk45+A1rKO4Q43prqWBNY/MiIeRLbPWUaA==} engines: {node: '>=4.0.0'} dev: true - /commondir@1.0.1: + /commondir/1.0.1: resolution: {integrity: sha512-W9pAhw0ja1Edb5GVdIF1mjZw/ASI0AlShXM83UUGe2DVr5TdAPEA1OA8m/g8zWp9x6On7gqufY+FatDbC3MDQg==} dev: true - /component-emitter@1.3.0: + /component-emitter/1.3.0: resolution: {integrity: sha512-Rd3se6QB+sO1TwqZjscQrurpEPIfO0/yYnSin6Q/rD3mOutHvUrCAhJub3r90uNb+SESBuE0QYoB90YdfatsRg==} dev: true - /compress-commons@4.1.1: + /compress-commons/4.1.1: resolution: {integrity: sha512-QLdDLCKNV2dtoTorqgxngQCMA+gWXkM/Nwu7FpeBhk/RdkzimqC3jueb/FDmaZeXh+uby1jkBqE3xArsLBE5wQ==} engines: {node: '>= 10'} dependencies: buffer-crc32: 0.2.13 crc32-stream: 4.0.2 normalize-path: 3.0.0 - readable-stream: 3.6.0 + readable-stream: 3.6.2 dev: true - /compressible@2.0.18: + /compressible/2.0.18: resolution: {integrity: sha512-AF3r7P5dWxL8MxyITRMlORQNaOA2IkAFaTr4k7BUumjPtRpGDTZpl0Pb1XCO6JeDCBdp126Cgs9sMxqSjgYyRg==} engines: {node: '>= 0.6'} dependencies: mime-db: 1.52.0 dev: true - /compression@1.7.4: + /compression/1.7.4: resolution: {integrity: sha512-jaSIDzP9pZVS4ZfQ+TzvtiWhdpFhE2RDHz8QJkpX9SIpLq88VueF5jJw6t+6CUQcAoA6t+x89MLrWAqpfDE8iQ==} engines: {node: '>= 0.8.0'} dependencies: @@ -12354,20 +10389,20 @@ packages: - supports-color dev: true - /concat-map@0.0.1: + /concat-map/0.0.1: resolution: {integrity: sha512-/Srv4dswyQNBfohGpz9o6Yb3Gz3SrUDqBH5rTuhGR7ahtlbYKnVxw2bCFMRljaA7EXHaXZ8wsHdodFvbkhKmqg==} - /concat-stream@1.6.2: + /concat-stream/1.6.2: resolution: {integrity: sha512-27HBghJxjiZtIk3Ycvn/4kbJk/1uZuJFfuPEns6LaEvpvG1f0hTea8lilrouyo9mVc2GWdcEZ8OLoGmSADlrCw==} engines: {'0': node >= 0.8} dependencies: buffer-from: 1.1.2 inherits: 2.0.4 - readable-stream: 2.3.7 + readable-stream: 2.3.8 typedarray: 0.0.6 dev: true - /condense-newlines@0.2.1: + /condense-newlines/0.2.1: resolution: {integrity: sha512-P7X+QL9Hb9B/c8HI5BFFKmjgBu2XpQuF98WZ9XkO+dBGgk5XgwiQz7o1SmpglNWId3581UcS0SFAWfoIhMHPfg==} engines: {node: '>=0.10.0'} dependencies: @@ -12376,68 +10411,64 @@ packages: kind-of: 3.2.2 dev: true - /config-chain@1.1.13: + /config-chain/1.1.13: resolution: {integrity: sha512-qj+f8APARXHrM0hraqXYb2/bOVSV4PvJQlNZ/DVj0QrmNM2q2euizkeuVckQ57J+W0mRH6Hvi+k50M4Jul2VRQ==} dependencies: ini: 1.3.8 proto-list: 1.2.4 dev: true - /consola@3.1.0: - resolution: {integrity: sha512-rrrJE6rP0qzl/Srg+C9x/AE5Kxfux7reVm1Wh0wCjuXvih6DqZgqDZe8auTD28fzJ9TF0mHlSDrPpWlujQRo1Q==} + /consola/3.2.3: + resolution: {integrity: sha512-I5qxpzLv+sJhTVEoLYNcTW+bThDCPsit0vLNKShZx6rLtpilNpmmeTPaeqJb9ZE9dV3DGaeby6Vuhrw38WjeyQ==} + engines: {node: ^14.18.0 || >=16.10.0} dev: true - /console-browserify@1.2.0: + /console-browserify/1.2.0: resolution: {integrity: sha512-ZMkYO/LkF17QvCPqM0gxw8yUzigAOZOSWSHg91FH6orS7vcEj5dVZTidN2fQ14yBSdg97RqhSNwLUXInd52OTA==} dev: true - /console-control-strings@1.1.0: + /console-control-strings/1.1.0: resolution: {integrity: sha512-ty/fTekppD2fIwRvnZAVdeOiGd1c7YXEixbgJTNzqcxJWKQnjJ/V1bNEEE6hygpM3WjwHFUVK6HTjWSzV4a8sQ==} dev: true - /constants-browserify@1.0.0: + /constants-browserify/1.0.0: resolution: {integrity: sha512-xFxOwqIzR/e1k1gLiWEophSCMqXcwVHIH7akf7b/vxcUeGunlj3hvZaaqxwHsTgn+IndtkQJgSztIDWeumWJDQ==} dev: true - /content-disposition@0.5.4: + /content-disposition/0.5.4: resolution: {integrity: sha512-FveZTNuGw04cxlAiWbzi6zTAL/lhehaWbTtgluJh4/E95DqMwTmha3KZN1aAWA8cFIhHzMZUvLevkw5Rqk+tSQ==} engines: {node: '>= 0.6'} dependencies: safe-buffer: 5.2.1 dev: true - /content-type@1.0.4: - resolution: {integrity: sha512-hIP3EEPs8tB9AT1L+NUqtwOAps4mk2Zob89MWXMHjHWg9milF/j4osnnQLXBCBFBk/tvIG/tUc9mOUJiPBhPXA==} + /content-type/1.0.5: + resolution: {integrity: sha512-nTjqfcBFEipKdXCv4YDQWCfmcLZKm81ldF0pAopTvyrFGVbcR6P/VAAd5G7N+0tTr8QqiU0tFadD6FK4NtJwOA==} engines: {node: '>= 0.6'} dev: true - /convert-source-map@1.8.0: - resolution: {integrity: sha512-+OQdjP49zViI/6i7nIJpA8rAl4sV/JdPfU9nZs3VqOwGIgizICvuN2ru6fMd+4llL0tar18UYJXfZ/TWtmhUjA==} - dependencies: - safe-buffer: 5.1.2 - - /convert-source-map@1.9.0: + /convert-source-map/1.9.0: resolution: {integrity: sha512-ASFBup0Mz1uyiIjANan1jzLQami9z1PoYSZCiiYW2FczPbenXc45FZdBZLzOT+r6+iciuEModtmCti+hjaAk0A==} - /cookie-signature@1.0.6: + /cookie-signature/1.0.6: resolution: {integrity: sha512-QADzlaHc8icV8I7vbaJXJwod9HWYp8uCqf1xa4OfNu1T7JVxQIrUgOWtHdNDtPiywmFbiS12VjotIXLrKM3orQ==} dev: true - /cookie@0.4.2: + /cookie/0.4.2: resolution: {integrity: sha512-aSWTXFzaKWkvHO1Ny/s+ePFpvKsPnjc551iI41v3ny/ow6tBG5Vd+FuqGNhh1LxOmVzOlGUriIlOaokOvhaStA==} engines: {node: '>= 0.6'} dev: true - /cookie@0.5.0: + /cookie/0.5.0: resolution: {integrity: sha512-YZ3GUyn/o8gfKJlnlX7g7xq4gyO6OSuhGPKaaGssGB2qgDUS0gPgtTvoyZLTt9Ab6dC4hfc9dV5arkvc/OCmrw==} engines: {node: '>= 0.6'} dev: true - /cookiejar@2.1.3: - resolution: {integrity: sha512-JxbCBUdrfr6AQjOXrxoTvAMJO4HBTUIlBzslcJPAz+/KT8yk53fXun51u+RenNYvad/+Vc2DIz5o9UxlCDymFQ==} + /cookiejar/2.1.4: + resolution: {integrity: sha512-LDx6oHrK+PhzLKJU9j5S7/Y3jM/mUHvD/DeI1WQmJn652iPC5Y4TBzC9l+5OMOXlyTTA+SmVUPm0HQUwpD5Jqw==} dev: true - /copy-concurrently@1.0.5: + /copy-concurrently/1.0.5: resolution: {integrity: sha512-f2domd9fsVDFtaFcbaRZuYXwtdmnzqbADSwhSWYxYB/Q8zsdUUFMXVRwXGDMWmbEzAn1kdRrtI1T/KTFOL4X2A==} dependencies: aproba: 1.2.0 @@ -12448,37 +10479,36 @@ packages: run-queue: 1.0.3 dev: true - /copy-descriptor@0.1.1: + /copy-descriptor/0.1.1: resolution: {integrity: sha512-XgZ0pFcakEUlbwQEVNg3+QAis1FyTL3Qel9FYy8pSkQqoG3PNoT0bOCQtOXcOkur21r2Eq2kI+IE+gsmAEVlYw==} engines: {node: '>=0.10.0'} dev: true - /core-js-compat@3.25.0: - resolution: {integrity: sha512-extKQM0g8/3GjFx9US12FAgx8KJawB7RCQ5y8ipYLbmfzEzmFRWdDjIlxDx82g7ygcNG85qMVUSRyABouELdow==} + /core-js-compat/3.31.1: + resolution: {integrity: sha512-wIDWd2s5/5aJSdpOJHfSibxNODxoGoWOBHt8JSPB41NOE94M7kuTPZCYLOlTtuoXTsBPKobpJ6T+y0SSy5L9SA==} dependencies: - browserslist: 4.21.3 - semver: 7.0.0 + browserslist: 4.21.9 dev: true - /core-js-pure@3.25.0: - resolution: {integrity: sha512-IeHpLwk3uoci37yoI2Laty59+YqH9x5uR65/yiA0ARAJrTrN4YU0rmauLWfvqOuk77SlNJXj2rM6oT/dBD87+A==} + /core-js-pure/3.31.1: + resolution: {integrity: sha512-w+C62kvWti0EPs4KPMCMVv9DriHSXfQOCQ94bGGBiEW5rrbtt/Rz8n5Krhfw9cpFyzXBjf3DB3QnPdEzGDY4Fw==} requiresBuild: true dev: true - /core-js@3.25.0: - resolution: {integrity: sha512-CVU1xvJEfJGhyCpBrzzzU1kjCfgsGUxhEvwUV2e/cOedYWHdmluamx+knDnmhqALddMG16fZvIqvs9aijsHHaA==} + /core-js/3.31.1: + resolution: {integrity: sha512-2sKLtfq1eFST7l7v62zaqXacPc7uG8ZAya8ogijLhTtaKNcpzpB4TMoTw2Si+8GYKRwFPMMtUT0263QFWFfqyQ==} requiresBuild: true dev: true - /core-util-is@1.0.2: + /core-util-is/1.0.2: resolution: {integrity: sha512-3lqz5YjWTYnW6dlDa5TLaTCcShfar1e40rmcJVwCBJC6mWlFuj0eCHIElmG1g5kyuJ/GD+8Wn4FFCcz4gJPfaQ==} dev: true - /core-util-is@1.0.3: + /core-util-is/1.0.3: resolution: {integrity: sha512-ZQBvi1DcpJ4GDqanjucZ2Hj3wEO5pZDS89BWbkcrvdxksJorwUDDZamX9ldFkp9aw2lmBDLgkObEA4DWNJ9FYQ==} dev: true - /cors@2.8.5: + /cors/2.8.5: resolution: {integrity: sha512-KIHbLJqu73RGr/hnbrO9uBeixNGuvSQjul/jdFvS/KFSIH1hWVd1ng7zOHx+YrEfInLG7q4n6GHQ9cDtxv/P6g==} engines: {node: '>= 0.10'} dependencies: @@ -12486,7 +10516,7 @@ packages: vary: 1.1.2 dev: true - /cosmiconfig@6.0.0: + /cosmiconfig/6.0.0: resolution: {integrity: sha512-xb3ZL6+L8b9JLLCx3ZdoZy4+2ECphCMo2PwqgP1tlfVq6M6YReyzBJtvWWtbDSpNr9hn96pkCiZqUcFEc+54Qg==} engines: {node: '>=8'} dependencies: @@ -12497,8 +10527,8 @@ packages: yaml: 1.10.2 dev: true - /cosmiconfig@7.0.1: - resolution: {integrity: sha512-a1YWNUV2HwGimB7dU2s1wUMurNKjpx60HxBB6xUM8Re+2s1g1IIfJvFR0/iCF+XHdE0GMTKTuLR32UQff4TEyQ==} + /cosmiconfig/7.1.0: + resolution: {integrity: sha512-AdmX6xUzdNASswsFtmwSt7Vj8po9IuqXm0UXz7QKPuEUmPB4XyjGfaAr2PSuELMwkRMVH1EpIkX5bTZGRB3eCA==} engines: {node: '>=10'} dependencies: '@types/parse-json': 4.0.0 @@ -12507,17 +10537,17 @@ packages: path-type: 4.0.0 yaml: 1.10.2 - /cp-file@7.0.0: + /cp-file/7.0.0: resolution: {integrity: sha512-0Cbj7gyvFVApzpK/uhCtQ/9kE9UnYpxMzaq5nQQC/Dh4iaj5fxp7iEFIullrYwzj8nf0qnsI1Qsx34hAeAebvw==} engines: {node: '>=8'} dependencies: - graceful-fs: 4.2.10 + graceful-fs: 4.2.11 make-dir: 3.1.0 nested-error-stacks: 2.1.1 p-event: 4.2.0 dev: true - /cpy@8.1.2: + /cpy/8.1.2: resolution: {integrity: sha512-dmC4mUesv0OYH2kNFEidtf/skUwv4zePmGeepjyyJ0qTo5+8KhA1o99oIAwVVLzQMAeDJml74d6wPPKb6EZUTg==} engines: {node: '>=8'} dependencies: @@ -12534,28 +10564,28 @@ packages: - supports-color dev: true - /crc-32@1.2.2: + /crc-32/1.2.2: resolution: {integrity: sha512-ROmzCKrTnOwybPcJApAA6WBWij23HVfGVNKqqrZpuyZOHqK2CwHSvpGuyt/UNNvaIjEd8X5IFGp4Mh+Ie1IHJQ==} engines: {node: '>=0.8'} hasBin: true dev: true - /crc32-stream@4.0.2: + /crc32-stream/4.0.2: resolution: {integrity: sha512-DxFZ/Hk473b/muq1VJ///PMNLj0ZMnzye9thBpmjpJKCc5eMgB95aK8zCGrGfQ90cWo561Te6HK9D+j4KPdM6w==} engines: {node: '>= 10'} dependencies: crc-32: 1.2.2 - readable-stream: 3.6.0 + readable-stream: 3.6.2 dev: true - /create-ecdh@4.0.4: + /create-ecdh/4.0.4: resolution: {integrity: sha512-mf+TCx8wWc9VpuxfP2ht0iSISLZnt0JgWlrOKZiNqyUZWnjIaCIVNQArMHnCZKfEYRg6IM7A+NeJoN8gf/Ws0A==} dependencies: bn.js: 4.12.0 elliptic: 6.5.4 dev: true - /create-hash@1.2.0: + /create-hash/1.2.0: resolution: {integrity: sha512-z00bCGNHDG8mHAkP7CtT1qVu+bFQUPjYq/4Iv3C3kWjTFV10zIjfSoeqXo9Asws8gwSHDGj/hl2u4OGIjapeCg==} dependencies: cipher-base: 1.0.4 @@ -12565,7 +10595,7 @@ packages: sha.js: 2.4.11 dev: true - /create-hmac@1.1.7: + /create-hmac/1.1.7: resolution: {integrity: sha512-MJG9liiZ+ogc4TzUwuvbER1JRdgvUFSB5+VR/g5h82fGaIRWMWddtKBHi7/sVhfjQZ6SehlyhvQYrcYkaUIpLg==} dependencies: cipher-base: 1.0.4 @@ -12576,26 +10606,34 @@ packages: sha.js: 2.4.11 dev: true - /create-require@1.1.1: + /create-require/1.1.1: resolution: {integrity: sha512-dcKFX3jn0MpIaXjisoRvexIJVEKzaq7z2rZKxf+MSr9TkdmHmsU4m2lcLojrj/FHl8mk5VxMmYA+ftRkP/3oKQ==} dev: true - /cross-fetch@3.1.5: + /cross-fetch/3.1.5: resolution: {integrity: sha512-lvb1SBsI0Z7GDwmuid+mU3kWVBwTVUbe7S0H52yaaAdQOXq2YktTCZdlAcNKFzE6QtRz0snpw9bNiPeOIkkQvw==} dependencies: node-fetch: 2.6.7 transitivePeerDependencies: - encoding + dev: true - /cross-fetch@3.1.6: + /cross-fetch/3.1.6: resolution: {integrity: sha512-riRvo06crlE8HiqOwIpQhxwdOk4fOeR7FVM/wXoxchFEqMNUjvbs3bfo4OTgMEMHzppd4DxFBDbyySj8Cv781g==} dependencies: - node-fetch: 2.6.11 + node-fetch: 2.6.12 transitivePeerDependencies: - encoding dev: true - /cross-spawn@5.1.0: + /cross-fetch/3.1.8: + resolution: {integrity: sha512-cvA+JwZoU0Xq+h6WkMvAUqPEYy92Obet6UdKLfW60qn99ftItKjB5T+BkyWOFWe2pUyfQ+IJHmpOTznqk1M6Kg==} + dependencies: + node-fetch: 2.6.12 + transitivePeerDependencies: + - encoding + + /cross-spawn/5.1.0: resolution: {integrity: sha512-pTgQJ5KC0d2hcY8eyL1IzlBPYjTkyH72XRZPnLyKus2mBfNjQs3klqbJU2VILqZryAZUt9JOb3h/mWMy23/f5A==} dependencies: lru-cache: 4.1.5 @@ -12603,18 +10641,18 @@ packages: which: 1.3.1 dev: true - /cross-spawn@6.0.5: + /cross-spawn/6.0.5: resolution: {integrity: sha512-eTVLrBSt7fjbDygz805pMnstIs2VTBNkRm0qxZd+M7A5XDdxVRWO5MxGBXZhjY4cqLYLdtrGqRf8mBPmzwSpWQ==} engines: {node: '>=4.8'} dependencies: nice-try: 1.0.5 path-key: 2.0.1 - semver: 5.7.1 + semver: 5.7.2 shebang-command: 1.2.0 which: 1.3.1 dev: true - /cross-spawn@7.0.3: + /cross-spawn/7.0.3: resolution: {integrity: sha512-iRDPJKUPVEND7dHPO8rkbOnPpyDygcDFtWjpeWNCgy8WP2rXcxXL8TskReQl6OrB2G7+UJrags1q15Fudc7G6w==} engines: {node: '>= 8'} dependencies: @@ -12623,7 +10661,7 @@ packages: which: 2.0.2 dev: true - /crypto-browserify@3.12.0: + /crypto-browserify/3.12.0: resolution: {integrity: sha512-fz4spIh+znjO2VjL+IdhEpRJ3YN6sMzITSBijk6FK2UvTqruSQW+/cCZTSNsMiZNvUeq0CqurF+dAbyiGOY6Wg==} dependencies: browserify-cipher: 1.0.1 @@ -12639,12 +10677,12 @@ packages: randomfill: 1.0.4 dev: true - /crypto-random-string@2.0.0: + /crypto-random-string/2.0.0: resolution: {integrity: sha512-v1plID3y9r/lPhviJ1wrXpLeyUIGAZ2SHNYTEapm7/8A9nLPoyvVp3RK/EPFqn5kEznyWgYZNsRtYYIWbuG8KA==} engines: {node: '>=8'} dev: true - /css-loader@3.6.0(webpack@4.46.0): + /css-loader/3.6.0_webpack@4.46.0: resolution: {integrity: sha512-M5lSukoWi1If8dhQAUCvj4H8vUt3vOnwbQBH9DdTm/s4Ym2B/3dPMtYZeJmq7Q3S3Pa+I94DcZ7pc9bP14cWIQ==} engines: {node: '>= 8.9.0'} peerDependencies: @@ -12653,7 +10691,7 @@ packages: camelcase: 5.3.1 cssesc: 3.0.0 icss-utils: 4.1.1 - loader-utils: 1.4.0 + loader-utils: 1.4.2 normalize-path: 3.0.0 postcss: 7.0.39 postcss-modules-extract-imports: 2.0.0 @@ -12662,11 +10700,11 @@ packages: postcss-modules-values: 3.0.0 postcss-value-parser: 4.2.0 schema-utils: 2.7.1 - semver: 6.3.0 + semver: 6.3.1 webpack: 4.46.0 dev: true - /css-select@4.3.0: + /css-select/4.3.0: resolution: {integrity: sha512-wPpOYtnsVontu2mODhA19JrqWxNsfdatRKd64kmpRbQgh1KtItko5sTnEpPdpSaJszTOhEMlF/RPz28qj4HqhQ==} dependencies: boolbase: 1.0.0 @@ -12676,21 +10714,21 @@ packages: nth-check: 2.1.1 dev: true - /css-select@5.1.0: + /css-select/5.1.0: resolution: {integrity: sha512-nwoRF1rvRRnnCqqY7updORDsuqKzqYJ28+oSMaJMMgOauh3fvwHqMS7EZpIPqK8GL+g9mKxF1vP/ZjSeNjEVHg==} dependencies: boolbase: 1.0.0 css-what: 6.1.0 domhandler: 5.0.3 - domutils: 3.0.1 + domutils: 3.1.0 nth-check: 2.1.1 dev: true - /css-shorthand-properties@1.1.1: + /css-shorthand-properties/1.1.1: resolution: {integrity: sha512-Md+Juc7M3uOdbAFwOYlTrccIZ7oCFuzrhKYQjdeUEW/sE1hv17Jp/Bws+ReOPpGVBTYCBoYo+G17V5Qo8QQ75A==} dev: true - /css-tree@2.3.1: + /css-tree/2.3.1: resolution: {integrity: sha512-6Fv1DV/TYw//QF5IzQdqsNDjx/wc8TrMBZsqjL9eW01tWb7R7k/mq+/VXfJCl7SoD5emsJop9cOByJZfs8hYIw==} engines: {node: ^10 || ^12.20.0 || ^14.13.0 || >=15.0.0} dependencies: @@ -12698,64 +10736,54 @@ packages: source-map-js: 1.0.2 dev: true - /css-unit-converter@1.1.2: + /css-unit-converter/1.1.2: resolution: {integrity: sha512-IiJwMC8rdZE0+xiEZHeru6YoONC4rfPMqGm2W85jMIbkFvv5nFTwJVFHam2eFrN6txmoUYFAFXiv8ICVeTO0MA==} dev: false - /css-value@0.0.1: + /css-value/0.0.1: resolution: {integrity: sha512-FUV3xaJ63buRLgHrLQVlVgQnQdR4yqdLGaDu7g8CQcWjInDfM9plBTPI9FRfpahju1UBSaMckeb2/46ApS/V1Q==} dev: true - /css-what@6.1.0: + /css-what/6.1.0: resolution: {integrity: sha512-HTUrgRJ7r4dsZKU6GjmpfRK1O76h97Z8MfS1G0FozR+oF2kG6Vfe8JE6zwrkbxigziPHinCJ+gCPjA9EaBDtRw==} engines: {node: '>= 6'} - /css.escape@1.5.1: + /css.escape/1.5.1: resolution: {integrity: sha512-YUifsXXuknHlUsmlgyY0PKzgPOr7/FjCePfHNt0jxm83wHZi44VDMQ7/fGNkjY3/jV1MC+1CmZbaHzugyeRtpg==} dev: true - /cssesc@3.0.0: + /cssesc/3.0.0: resolution: {integrity: sha512-/Tb/JcjK111nNScGob5MNtsntNM1aCNUDipB/TkwZFhyDrrE47SOx/18wF2bbjgc3ZzCSKW1T5nt5EbFoAz/Vg==} engines: {node: '>=4'} hasBin: true dev: true - /cssom@0.3.8: + /cssom/0.3.8: resolution: {integrity: sha512-b0tGHbfegbhPJpxpiBPU2sCkigAqtM9O121le6bbOlgyV+NyGyCmVfJ6QW9eRjz8CpNfWEOYBIMIGRYkLwsIYg==} dev: true - /cssom@0.4.4: - resolution: {integrity: sha512-p3pvU7r1MyyqbTk+WbNJIgJjG2VmTIaB10rI93LzVPrmDJKkzKYMtxxyAvQXR/NS6otuzveI7+7BBq3SjBS2mw==} - dev: true - - /cssom@0.5.0: + /cssom/0.5.0: resolution: {integrity: sha512-iKuQcq+NdHqlAcwUY0o/HL69XQrUaQdMjmStJ8JFmUaiiQErlhrmuigkg/CU4E2J0IyUKUrMAgl36TvN67MqTw==} dev: true - /cssstyle@2.3.0: + /cssstyle/2.3.0: resolution: {integrity: sha512-AZL67abkUzIuvcHqk7c09cezpGNcxUxU4Ioi/05xHk4DQeTkWmGYftIE6ctU6AEt+Gn4n1lDStOtj7FKycP71A==} engines: {node: '>=8'} dependencies: cssom: 0.3.8 dev: true - /cssstyle@3.0.0: + /cssstyle/3.0.0: resolution: {integrity: sha512-N4u2ABATi3Qplzf0hWbVCdjenim8F3ojEXpBDF5hBpjzW182MjNGLqfmQ0SkSPeQ+V86ZXgeH8aXj6kayd4jgg==} engines: {node: '>=14'} dependencies: rrweb-cssom: 0.6.0 dev: true - /csstype@2.6.20: - resolution: {integrity: sha512-/WwNkdXfckNgw6S5R125rrW8ez139lBHWouiBvX8dfMFtcn6V81REDqnH7+CRpRipfYlyU1CmOnOxrmGcFOjeA==} - - /csstype@3.1.0: - resolution: {integrity: sha512-uX1KG+x9h5hIJsaKR9xHUeUraxf8IODOwq9JLNPq6BwB04a/xgpq3rcx47l5BZu5zBPlgD342tdke3Hom/nJRA==} - - /csstype@3.1.2: + /csstype/3.1.2: resolution: {integrity: sha512-I7K1Uu0MBPzaFKg4nI5Q7Vs2t+3gWWW648spaF+Rg7pI9ds18Ugn+lvg4SHczUdKlHI5LWBXyqfS8+DufyBsgQ==} - /currently-unhandled@0.4.1: + /currently-unhandled/0.4.1: resolution: {integrity: sha512-/fITjgjGU50vjQ4FH6eUoYu+iUoUKIXws2hL15JJpIR+BbTxaXQsMuuyjtNh2WqsSBS5nsaZHFsFecyw5CCAng==} engines: {node: '>=0.10.0'} dependencies: @@ -12763,19 +10791,19 @@ packages: dev: true optional: true - /cyclist@1.0.1: - resolution: {integrity: sha512-NJGVKPS81XejHcLhaLJS7plab0fK3slPh11mESeeDq2W4ZI5kUKK/LRRdVDvjJseojbPB7ZwjnyOybg3Igea/A==} + /cyclist/1.0.2: + resolution: {integrity: sha512-0sVXIohTfLqVIW3kb/0n6IiWF3Ifj5nm2XaSrLq2DI6fKIGa2fYAZdk917rUneaeLVpYfFcyXE2ft0fe3remsA==} dev: true - /cypress@12.16.0: - resolution: {integrity: sha512-mwv1YNe48hm0LVaPgofEhGCtLwNIQEjmj2dJXnAkY1b4n/NE9OtgPph4TyS+tOtYp5CKtRmDvBzWseUXQTjbTg==} + /cypress/12.17.1: + resolution: {integrity: sha512-eKfBgO6t8waEyhegL4gxD7tcI6uTCGttu+ZU7y9Hq8BlpMztd7iLeIF4AJFAnbZH1xjX+wwgg4cRKFNSvv3VWQ==} engines: {node: ^14.0.0 || ^16.0.0 || >=18.0.0} hasBin: true requiresBuild: true dependencies: - '@cypress/request': 2.88.10 - '@cypress/xvfb': 1.2.4(supports-color@8.1.1) - '@types/node': 14.18.26 + '@cypress/request': 2.88.11 + '@cypress/xvfb': 1.2.4_supports-color@8.1.1 + '@types/node': 14.18.53 '@types/sinonjs__fake-timers': 8.1.1 '@types/sizzle': 2.3.3 arch: 2.2.0 @@ -12786,23 +10814,23 @@ packages: chalk: 4.1.2 check-more-types: 2.24.0 cli-cursor: 3.1.0 - cli-table3: 0.6.2 + cli-table3: 0.6.3 commander: 6.2.1 common-tags: 1.8.2 - dayjs: 1.11.5 - debug: 4.3.4(supports-color@8.1.1) + dayjs: 1.11.9 + debug: 4.3.4_supports-color@8.1.1 enquirer: 2.3.6 eventemitter2: 6.4.7 execa: 4.1.0 executable: 4.1.1 - extract-zip: 2.0.1(supports-color@8.1.1) + extract-zip: 2.0.1_supports-color@8.1.1 figures: 3.2.0 fs-extra: 9.1.0 getos: 3.2.1 is-ci: 3.0.1 is-installed-globally: 0.4.0 lazy-ass: 1.6.0 - listr2: 3.14.0(enquirer@2.3.6) + listr2: 3.14.0_enquirer@2.3.6 lodash: 4.17.21 log-symbols: 4.1.0 minimist: 1.2.8 @@ -12810,30 +10838,30 @@ packages: pretty-bytes: 5.6.0 proxy-from-env: 1.0.0 request-progress: 3.0.0 - semver: 7.5.2 + semver: 7.5.4 supports-color: 8.1.1 tmp: 0.2.1 untildify: 4.0.0 yauzl: 2.10.0 dev: true - /d3-array@3.2.0: - resolution: {integrity: sha512-3yXFQo0oG3QCxbF06rMPFyGRMGJNS7NvsV1+2joOjbBE+9xvWQ8+GcMJAjRCzw06zQ3/arXeJgbPYcjUCuC+3g==} + /d3-array/3.2.4: + resolution: {integrity: sha512-tdQAmyA18i4J7wprpYq8ClcxZy3SC31QMeByyCFyRt7BVHdREQZ5lpzoe5mFEYZUWe+oq8HBvk9JjpibyEV4Jg==} engines: {node: '>=12'} dependencies: internmap: 2.0.3 dev: false - /d3-color@3.1.0: + /d3-color/3.1.0: resolution: {integrity: sha512-zg/chbXyeBtMQ1LbD/WSoW2DpC3I0mpmPdW+ynRTj/x2DAWYrIY7qeZIHidozwV24m4iavr15lNwIwLxRmOxhA==} engines: {node: '>=12'} - /d3-dispatch@3.0.1: + /d3-dispatch/3.0.1: resolution: {integrity: sha512-rzUyPU/S7rwUflMyLc1ETDeBj0NRuHKKAcvukozwhshr6g6c5d8zh4c2gQjY2bZ0dXeGLWc1PF174P2tVvKhfg==} engines: {node: '>=12'} dev: true - /d3-drag@3.0.0: + /d3-drag/3.0.0: resolution: {integrity: sha512-pWbUJLdETVA8lQNJecMxoXfH6x+mO2UQo8rSmZ+QqxcbyA3hfeprFgIT//HW2nlHChWeIIMwS2Fq+gEARkhTkg==} engines: {node: '>=12'} dependencies: @@ -12841,12 +10869,11 @@ packages: d3-selection: 3.0.0 dev: true - /d3-ease@3.0.1: + /d3-ease/3.0.1: resolution: {integrity: sha512-wR/XK3D3XcLIZwpbvQwQ5fK+8Ykds1ip7A2Txe0yxncXSdq1L9skcG7blcedkOX+ZcgxGAmLX1FrRGbADwzi0w==} engines: {node: '>=12'} - dev: true - /d3-force@3.0.0: + /d3-force/3.0.0: resolution: {integrity: sha512-zxV/SsA+U4yte8051P4ECydjD/S+qeYtnaIyAs9tgHCqfguma/aAQDjo85A9Z6EKhBirHRJHXIgJUlffT4wdLg==} engines: {node: '>=12'} dependencies: @@ -12855,12 +10882,12 @@ packages: d3-timer: 3.0.1 dev: true - /d3-format@3.1.0: + /d3-format/3.1.0: resolution: {integrity: sha512-YyUI6AEuY/Wpt8KWLgZHsIU86atmikuoOmCfommt0LYHiQSPjvX2AcFc38PX0CBpr2RCyZhjex+NS/LPOv6YqA==} engines: {node: '>=12'} dev: false - /d3-graph-controller@2.5.2: + /d3-graph-controller/2.5.2: resolution: {integrity: sha512-s8qJCEWuQKoE2uwkD1HpE3bpPHxG/30d7u1Dp5YT8modzc0Nbeh1iiqb0clxEHmNOAJd4vbDWkKtYhX58lycug==} dependencies: '@yeger/debounce': 1.0.66 @@ -12871,65 +10898,64 @@ packages: vecti: 2.1.40 dev: true - /d3-interpolate@3.0.1: + /d3-interpolate/3.0.1: resolution: {integrity: sha512-3bYs1rOD33uo8aqJfKP3JWPAibgw8Zm2+L9vBKEHJ2Rg+viTR7o5Mmv5mZcieN+FRYaAOWX5SJATX6k1PWz72g==} engines: {node: '>=12'} dependencies: d3-color: 3.1.0 - /d3-path@3.0.1: - resolution: {integrity: sha512-gq6gZom9AFZby0YLduxT1qmrp4xpBA1YZr19OI717WIdKE2OM5ETq5qrHLb301IgxhLwcuxvGZVLeeWc/k1I6w==} + /d3-path/3.1.0: + resolution: {integrity: sha512-p3KP5HCf/bvjBSSKuXid6Zqijx7wIfNW+J/maPs+iwR35at5JCbLUT0LzF1cnjbCHWhqzQTIN2Jpe8pRebIEFQ==} engines: {node: '>=12'} dev: false - /d3-quadtree@3.0.1: + /d3-quadtree/3.0.1: resolution: {integrity: sha512-04xDrxQTDTCFwP5H6hRhsRcb9xxv2RzkcsygFzmkSIOJy3PeRJP7sNk3VRIbKXcog561P9oU0/rVH6vDROAgUw==} engines: {node: '>=12'} dev: true - /d3-scale@4.0.2: + /d3-scale/4.0.2: resolution: {integrity: sha512-GZW464g1SH7ag3Y7hXjf8RoUuAFIqklOAq3MRl4OaWabTFJY9PN/E1YklhXLh+OQ3fM9yS2nOkCoS+WLZ6kvxQ==} engines: {node: '>=12'} dependencies: - d3-array: 3.2.0 + d3-array: 3.2.4 d3-format: 3.1.0 d3-interpolate: 3.0.1 - d3-time: 3.0.0 + d3-time: 3.1.0 d3-time-format: 4.1.0 dev: false - /d3-selection@3.0.0: + /d3-selection/3.0.0: resolution: {integrity: sha512-fmTRWbNMmsmWq6xJV8D19U/gw/bwrHfNXxrIN+HfZgnzqTHp9jOmKMhsTUjXOJnZOdZY9Q28y4yebKzqDKlxlQ==} engines: {node: '>=12'} dev: true - /d3-shape@3.1.0: - resolution: {integrity: sha512-tGDh1Muf8kWjEDT/LswZJ8WF85yDZLvVJpYU9Nq+8+yW1Z5enxrmXOhTArlkaElU+CTn0OTVNli+/i+HP45QEQ==} + /d3-shape/3.2.0: + resolution: {integrity: sha512-SaLBuwGm3MOViRq2ABk3eLoxwZELpH6zhl3FbAoJ7Vm1gofKx6El1Ib5z23NUEhF9AsGl7y+dzLe5Cw2AArGTA==} engines: {node: '>=12'} dependencies: - d3-path: 3.0.1 + d3-path: 3.1.0 dev: false - /d3-time-format@4.1.0: + /d3-time-format/4.1.0: resolution: {integrity: sha512-dJxPBlzC7NugB2PDLwo9Q8JiTR3M3e4/XANkreKSUxF8vvXKqm1Yfq4Q5dl8budlunRVlUUaDUgFt7eA8D6NLg==} engines: {node: '>=12'} dependencies: - d3-time: 3.0.0 + d3-time: 3.1.0 dev: false - /d3-time@3.0.0: - resolution: {integrity: sha512-zmV3lRnlaLI08y9IMRXSDshQb5Nj77smnfpnd2LrBa/2K281Jijactokeak14QacHs/kKq0AQ121nidNYlarbQ==} + /d3-time/3.1.0: + resolution: {integrity: sha512-VqKjzBLejbSMT4IgbmVgDjpkYrNWUYJnbCGo874u7MMKIWsILRX+OpX/gTk8MqjpT1A/c6HY2dCA77ZN0lkQ2Q==} engines: {node: '>=12'} dependencies: - d3-array: 3.2.0 + d3-array: 3.2.4 dev: false - /d3-timer@3.0.1: + /d3-timer/3.0.1: resolution: {integrity: sha512-ndfJ/JxxMd3nw31uyKoY2naivF+r29V+Lc0svZxe1JvvIRmi8hUsrMvdOwgS1o6uBHmiz91geQ0ylPP0aj1VUA==} engines: {node: '>=12'} - dev: true - /d3-transition@3.0.1(d3-selection@3.0.0): + /d3-transition/3.0.1_d3-selection@3.0.0: resolution: {integrity: sha512-ApKvfjsSR6tg06xrL434C0WydLr7JewBB3V+/39RMHsaXTOG0zmt/OAXeng5M5LBm0ojmxJrpomQVZ1aPvBL4w==} engines: {node: '>=12'} peerDependencies: @@ -12943,7 +10969,7 @@ packages: d3-timer: 3.0.1 dev: true - /d3-zoom@3.0.0: + /d3-zoom/3.0.0: resolution: {integrity: sha512-b8AmV3kfQaqWAuacbPuNbL6vahnOJflOhexLzMMNLga62+/nh0JzvJ0aO/5a5MVgUFGS7Hu1P9P03o3fJkDCyw==} engines: {node: '>=12'} dependencies: @@ -12951,26 +10977,17 @@ packages: d3-drag: 3.0.0 d3-interpolate: 3.0.1 d3-selection: 3.0.0 - d3-transition: 3.0.1(d3-selection@3.0.0) + d3-transition: 3.0.1_d3-selection@3.0.0 dev: true - /dashdash@1.14.1: + /dashdash/1.14.1: resolution: {integrity: sha512-jRFi8UDGo6j+odZiEpjazZaWqEal3w/basFjQHQEwVtZJGDpxbH1MeYluwCS8Xq5wmLJooDlMgvVarmWfGM44g==} engines: {node: '>=0.10'} dependencies: assert-plus: 1.0.0 dev: true - /data-urls@2.0.0: - resolution: {integrity: sha512-X5eWTSXO/BJmpdIKCRuKUgSCgAN0OwliVK3yPKbwIWU1Tdw5BRajxlzMidvh+gwko9AfQ9zIj52pzF91Q3YAvQ==} - engines: {node: '>=10'} - dependencies: - abab: 2.0.6 - whatwg-mimetype: 2.3.0 - whatwg-url: 8.7.0 - dev: true - - /data-urls@3.0.2: + /data-urls/3.0.2: resolution: {integrity: sha512-Jy/tj3ldjZJo63sVAvg6LHt2mHvl4V6AgRAmNDtLdm7faqtsx+aJG42rsyCo9JCoRVKwPFzKlIPx3DIibwSIaQ==} engines: {node: '>=12'} dependencies: @@ -12979,7 +10996,7 @@ packages: whatwg-url: 11.0.0 dev: true - /data-urls@4.0.0: + /data-urls/4.0.0: resolution: {integrity: sha512-/mMTei/JXPqvFqQtfyTowxmJVwr2PVAeCcDxyFf6LhoOu/09TX2OX3kb2wzi4DMXcfj4OItwDOnhl5oziPnT6g==} engines: {node: '>=14'} dependencies: @@ -12988,19 +11005,21 @@ packages: whatwg-url: 12.0.1 dev: true - /date-fns@2.29.2: - resolution: {integrity: sha512-0VNbwmWJDS/G3ySwFSJA3ayhbURMTJLtwM2DTxf9CWondCnh6DTNlO9JgRSq6ibf4eD0lfMJNBxUdEAHHix+bA==} + /date-fns/2.30.0: + resolution: {integrity: sha512-fnULvOpxnC5/Vg3NCiWelDsLiUc9bRwAPs/+LfTLNvetFCtCTN+yQz15C/fs4AwX1R9K5GLtLfn8QW+dWisaAw==} engines: {node: '>=0.11'} + dependencies: + '@babel/runtime': 7.22.6 - /dayjs@1.11.5: - resolution: {integrity: sha512-CAdX5Q3YW3Gclyo5Vpqkgpj8fSdLQcRuzfX6mC6Phy0nfJ0eGYOeS7m4mt2plDWLAtA4TqTakvbboHvUxfe4iA==} + /dayjs/1.11.9: + resolution: {integrity: sha512-QvzAURSbQ0pKdIye2txOzNaHmxtUBXerpY0FJsFXUMKbIZeFm5ht1LS/jFsrncjnmtv8HsG0W2g6c0zUjZWmpA==} dev: true - /de-indent@1.0.2: + /de-indent/1.0.2: resolution: {integrity: sha512-e/1zu3xH5MQryN2zdVaF0OrdNLUbvWxzMbi+iNA6Bky7l1RoP8a2fIbRocyHclXt/arDrrR6lL3TqFD9pMQTsg==} dev: true - /debug@2.6.9: + /debug/2.6.9: resolution: {integrity: sha512-bC7ElrdJaJnPbAP+1EotYvqZsb3ecl5wi6Bfi6BJTUcNowp6cvspg0jXznRTKDjm/E7AdgFBVeAPVMNcKGsHMA==} peerDependencies: supports-color: '*' @@ -13011,7 +11030,18 @@ packages: ms: 2.0.0 dev: true - /debug@3.2.7(supports-color@8.1.1): + /debug/3.2.7: + resolution: {integrity: sha512-CFjzYYAi4ThfiQvizrFQevTTXHtnCqWfe7x1AhgEscTz6ZbLbfoLRLPugTQyBth6f8ZERVUSyWHFD/7Wu4t1XQ==} + peerDependencies: + supports-color: '*' + peerDependenciesMeta: + supports-color: + optional: true + dependencies: + ms: 2.1.3 + dev: true + + /debug/3.2.7_supports-color@8.1.1: resolution: {integrity: sha512-CFjzYYAi4ThfiQvizrFQevTTXHtnCqWfe7x1AhgEscTz6ZbLbfoLRLPugTQyBth6f8ZERVUSyWHFD/7Wu4t1XQ==} peerDependencies: supports-color: '*' @@ -13023,7 +11053,18 @@ packages: supports-color: 8.1.1 dev: true - /debug@4.3.4(supports-color@8.1.1): + /debug/4.3.4: + resolution: {integrity: sha512-PRWFHuSU3eDtQJPvnNY7Jcket1j0t5OuOsFzPPzsekD52Zl8qUfFIPEiswXqIvHWGVHOgX+7G/vCNNhehwxfkQ==} + engines: {node: '>=6.0'} + peerDependencies: + supports-color: '*' + peerDependenciesMeta: + supports-color: + optional: true + dependencies: + ms: 2.1.2 + + /debug/4.3.4_supports-color@8.1.1: resolution: {integrity: sha512-PRWFHuSU3eDtQJPvnNY7Jcket1j0t5OuOsFzPPzsekD52Zl8qUfFIPEiswXqIvHWGVHOgX+7G/vCNNhehwxfkQ==} engines: {node: '>=6.0'} peerDependencies: @@ -13034,35 +11075,28 @@ packages: dependencies: ms: 2.1.2 supports-color: 8.1.1 + dev: true - /decamelize@1.2.0: + /decamelize/1.2.0: resolution: {integrity: sha512-z2S+W9X73hAUUki+N+9Za2lBlun89zigOyGrsax+KUQ6wKW4ZoWpEYBkGhQjwAjjDCkWxhY0VKEhk8wzY7F5cA==} engines: {node: '>=0.10.0'} dev: true optional: true - /decamelize@6.0.0: + /decamelize/6.0.0: resolution: {integrity: sha512-Fv96DCsdOgB6mdGl67MT5JaTNKRzrzill5OH5s8bjYJXVlcXyPYGyPsUkWyGV5p1TXI5esYIYMMeDJL0hEIwaA==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dev: true - /decimal.js-light@2.5.1: + /decimal.js-light/2.5.1: resolution: {integrity: sha512-qIMFpTMZmny+MMIitAB6D7iVPEorVw6YQRWkvarTkT4tBeSLLiHzcwj6q0MmYSFCiVpiqPJTJEYIrpcPzVEIvg==} dev: false - /decimal.js@10.4.0: - resolution: {integrity: sha512-Nv6ENEzyPQ6AItkGwLE2PGKinZZ9g59vSh2BeH6NqPu0OTKZ5ruJsVqh/orbAnqXc9pBbgXAIrc2EyaCj8NpGg==} - dev: true - - /decimal.js@10.4.2: - resolution: {integrity: sha512-ic1yEvwT6GuvaYwBLLY6/aFFgjZdySKTE8en/fkU3QICTmRtgtSlFn0u0BXN06InZwtfCelR7j8LRiDI/02iGA==} - dev: true - - /decimal.js@10.4.3: + /decimal.js/10.4.3: resolution: {integrity: sha512-VBBaLc1MgL5XpzgIP7ny5Z6Nx3UrRkIViUkPUdtl9aya5amy3De1gsUUSB1g3+3sExYNjCAsAznmukyxCb1GRA==} dev: true - /decode-bmp@0.2.1: + /decode-bmp/0.2.1: resolution: {integrity: sha512-NiOaGe+GN0KJqi2STf24hfMkFitDUaIoUU3eKvP/wAbLe8o6FuW5n/x7MHPR0HKvBokp6MQY/j7w8lewEeVCIA==} engines: {node: '>=8.6.0'} dependencies: @@ -13070,7 +11104,7 @@ packages: to-data-view: 1.1.0 dev: true - /decode-ico@0.4.1: + /decode-ico/0.4.1: resolution: {integrity: sha512-69NZfbKIzux1vBOd31al3XnMnH+2mqDhEgLdpygErm4d60N+UwA5Sq5WFjmEDQzumgB9fElojGwWG0vybVfFmA==} engines: {node: '>=8.6'} dependencies: @@ -13079,36 +11113,36 @@ packages: to-data-view: 1.1.0 dev: true - /decode-uri-component@0.2.0: - resolution: {integrity: sha512-hjf+xovcEn31w/EUYdTXQh/8smFL/dzYjohQGEIgjyNavaJfBY2p5F527Bo1VPATxv0VYTUC2bOcXvqFwk78Og==} + /decode-uri-component/0.2.2: + resolution: {integrity: sha512-FqUYQ+8o158GyGTrMFJms9qh3CqTKvAqgqsTnkLI8sKu0028orqBhxNMFkFen0zGyg6epACD32pjVk58ngIErQ==} engines: {node: '>=0.10'} dev: true - /decompress-response@6.0.0: + /decompress-response/6.0.0: resolution: {integrity: sha512-aW35yZM6Bb/4oJlZncMH2LCoZtJXTRxES17vE3hoRiowU2kWHaJKFkSBDnDR+cm9J+9QhXmREyIfv0pji9ejCQ==} engines: {node: '>=10'} dependencies: mimic-response: 3.1.0 dev: true - /dedent@0.7.0: + /dedent/0.7.0: resolution: {integrity: sha512-Q6fKUPqnAHAyhiUgFU7BUzLiv0kd8saH9al7tnu5Q/okj6dnupxyTgFIBjVzJATdfIAm9NAsvXNzjaKa+bxVyA==} dev: true - /deep-eql@4.1.3: + /deep-eql/4.1.3: resolution: {integrity: sha512-WaEtAOpRA1MQ0eohqZjpGD8zdI0Ovsm8mmFhaDN8dvDZzyoUMcYDnf5Y6iu7HTXxf8JDS23qWa4a+hKCDyOPzw==} engines: {node: '>=6'} dependencies: type-detect: 4.0.8 dev: false - /deep-equal@2.2.1: - resolution: {integrity: sha512-lKdkdV6EOGoVn65XaOsPdH4rMxTZOnmFyuIkMjM1i5HHCbfjC97dawgTAy0deYNfuqUqW+Q5VrVaQYtUpSd6yQ==} + /deep-equal/2.2.2: + resolution: {integrity: sha512-xjVyBf0w5vH0I42jdAZzOKVldmPgSulmiyPRywoyq7HXC9qdgo17kxJE+rdnif5Tz6+pIrpJI8dCpMNLIGkUiA==} dependencies: array-buffer-byte-length: 1.0.0 call-bind: 1.0.2 es-get-iterator: 1.1.3 - get-intrinsic: 1.2.0 + get-intrinsic: 1.2.1 is-arguments: 1.1.1 is-array-buffer: 3.0.2 is-date-object: 1.0.5 @@ -13122,29 +11156,29 @@ packages: side-channel: 1.0.4 which-boxed-primitive: 1.0.2 which-collection: 1.0.1 - which-typed-array: 1.1.9 + which-typed-array: 1.1.10 dev: true - /deep-extend@0.6.0: + /deep-extend/0.6.0: resolution: {integrity: sha512-LOHxIOaPYdHlJRtCQfDIVZtfw/ufM8+rVj649RIHzcm/vGwQRXFt6OPqIFWsm2XEMrNIEtWR64sY1LEKD2vAOA==} engines: {node: '>=4.0.0'} dev: true - /deep-is@0.1.4: + /deep-is/0.1.4: resolution: {integrity: sha512-oIPzksmTg4/MriiaYGO+okXDT7ztn/w3Eptv/+gSIdMdKsJo0u4CfYNFJPy+4SKMuCqGw2wxnA+URMg3t8a/bQ==} dev: true - /deepmerge-ts@5.0.0: - resolution: {integrity: sha512-esq9xUO8+CQCG63IlpkoOBNlpm1m4WBm0NRLFrGL/dcgzqWi1tmTLfG7QTvffqYt6T+dS+xaxrHxdexqGWkV1g==} + /deepmerge-ts/5.1.0: + resolution: {integrity: sha512-eS8dRJOckyo9maw9Tu5O5RUi/4inFLrnoLkBe3cPfDMx3WZioXtmOew4TXQaxq7Rhl4xjDtR7c6x8nNTxOvbFw==} engines: {node: '>=16.0.0'} dev: true - /deepmerge@4.3.1: + /deepmerge/4.3.1: resolution: {integrity: sha512-3sUqbMEc77XqpdNO7FRyRog+eW3ph+GYCbj+rK+uYyRMuwsVy0rMiVtPn+QJlKFvWP/1PYpapqYn0Me2knFn+A==} engines: {node: '>=0.10.0'} dev: true - /default-browser-id@1.0.4: + /default-browser-id/1.0.4: resolution: {integrity: sha512-qPy925qewwul9Hifs+3sx1ZYn14obHxpkX+mPD369w4Rzg+YkJBgi3SOvwUq81nWSjqGUegIgEPwD8u+HUnxlw==} engines: {node: '>=0.10.0'} hasBin: true @@ -13156,23 +11190,23 @@ packages: dev: true optional: true - /defaults@1.0.3: - resolution: {integrity: sha512-s82itHOnYrN0Ib8r+z7laQz3sdE+4FP3d9Q7VLO7U+KRT+CR0GsWuyHxzdAY82I7cXv0G/twrqomTJLOssO5HA==} + /defaults/1.0.4: + resolution: {integrity: sha512-eFuaLoy/Rxalv2kr+lqMlUnrDWV+3j4pljOIJgLIhI058IQfWJ7vXhyEIHu+HtC738klGALYxOKDO0bQP3tg8A==} dependencies: clone: 1.0.4 dev: true - /defer-to-connect@2.0.1: + /defer-to-connect/2.0.1: resolution: {integrity: sha512-4tvttepXG1VaYGrRibk5EwJd1t4udunSOVMdLSAL6mId1ix438oPwPZMALY41FCijukO1L0twNcGsdzS7dHgDg==} engines: {node: '>=10'} dev: true - /define-lazy-prop@2.0.0: + /define-lazy-prop/2.0.0: resolution: {integrity: sha512-Ds09qNh8yw3khSjiJjiUInaGX9xlqZDY7JVryGxdxV7NPeuqQfplOpQ66yJFZut3jLa5zOwkXw1g9EI2uKh4Og==} engines: {node: '>=8'} dev: true - /define-properties@1.2.0: + /define-properties/1.2.0: resolution: {integrity: sha512-xvqAVKGfT1+UAvPwKTVw/njhdQ8ZhXK4lI0bCIuCMrp2up9nPnaDftrLtmpTazqd1o+UY4zgzU+avtMbDP+ldA==} engines: {node: '>= 0.4'} dependencies: @@ -13180,21 +11214,21 @@ packages: object-keys: 1.1.1 dev: true - /define-property@0.2.5: + /define-property/0.2.5: resolution: {integrity: sha512-Rr7ADjQZenceVOAKop6ALkkRAmH1A4Gx9hV/7ZujPUN2rkATqFO0JZLZInbAjpZYoJ1gUx8MRMQVkYemcbMSTA==} engines: {node: '>=0.10.0'} dependencies: is-descriptor: 0.1.6 dev: true - /define-property@1.0.0: + /define-property/1.0.0: resolution: {integrity: sha512-cZTYKFWspt9jZsMscWo8sc/5lbPC9Q0N5nBLgb+Yd915iL3udB1uFgS3B8YCx66UVHq018DAVFoee7x+gxggeA==} engines: {node: '>=0.10.0'} dependencies: is-descriptor: 1.0.2 dev: true - /define-property@2.0.2: + /define-property/2.0.2: resolution: {integrity: sha512-jwK2UV4cnPpbcG7+VRARKTZPUWowwXA8bzH5NP6ud0oeAxyYPuGZUAC7hMugpCdz4BeSZl2Dl9k66CHJ/46ZYQ==} engines: {node: '>=0.10.0'} dependencies: @@ -13202,112 +11236,102 @@ packages: isobject: 3.0.1 dev: true - /defu@6.1.2: + /defu/6.1.2: resolution: {integrity: sha512-+uO4+qr7msjNNWKYPHqN/3+Dx3NFkmIzayk2L1MyZQlvgZb/J1A0fo410dpKrN2SnqFjt8n4JL8fDJE0wIgjFQ==} dev: true - /delayed-stream@1.0.0: + /delayed-stream/1.0.0: resolution: {integrity: sha512-ZySD7Nf91aLB0RxL4KGrKHBXl7Eds1DAmEdcoVawXnLD7SDhpNgtuII2aAkg7a7QS41jxPSZ17p4VdGnMHk3MQ==} engines: {node: '>=0.4.0'} dev: true - /delegates@1.0.0: + /delegates/1.0.0: resolution: {integrity: sha512-bd2L678uiWATM6m5Z1VzNCErI3jiGzt6HGY8OVICs40JQq/HALfbyNJmp0UDakEY4pMMaN0Ly5om/B1VI/+xfQ==} dev: true - /depd@2.0.0: + /depd/2.0.0: resolution: {integrity: sha512-g7nH6P6dyDioJogAAGprGpCtVImJhpPk/roCzdb3fIh61/s/nPsfR6onyMwkCAR/OlC3yBC0lESvUoQEAssIrw==} engines: {node: '>= 0.8'} dev: true - /dequal@2.0.3: + /dequal/2.0.3: resolution: {integrity: sha512-0je+qPKHEMohvfRTCEo3CrPG6cAzAYgmzKyxRiYSSDkS6eGJdyVJm7WaYA5ECaAD9wLB2T4EEeymA5aFVcYXCA==} engines: {node: '>=6'} dev: true - /des.js@1.0.1: - resolution: {integrity: sha512-Q0I4pfFrv2VPd34/vfLrFOoRmlYj3OV50i7fskps1jZWK1kApMWWT9G6RRUeYedLcBDIhnSDaUvJMb3AhUlaEA==} + /des.js/1.1.0: + resolution: {integrity: sha512-r17GxjhUCjSRy8aiJpr8/UadFIzMzJGexI3Nmz4ADi9LYSFx4gTBp80+NaX/YsXWWLhpZ7v/v/ubEc/bCNfKwg==} dependencies: inherits: 2.0.4 minimalistic-assert: 1.0.1 dev: true - /destr@1.2.0: - resolution: {integrity: sha512-JG+cG4ZPB1L27sl2C2URg8MIOmIUtTbE5wEx02BpmrTCqg/hXxFKXsYsnODl5PdpqNRaS1KQGUQ56V8jk8XpYQ==} - dev: true - - /destr@1.2.2: + /destr/1.2.2: resolution: {integrity: sha512-lrbCJwD9saUQrqUfXvl6qoM+QN3W7tLV5pAOs+OqOmopCCz/JkE05MHedJR1xfk4IAnZuJXPVuN5+7jNA2ZCiA==} dev: true - /destr@2.0.0: + /destr/2.0.0: resolution: {integrity: sha512-FJ9RDpf3GicEBvzI3jxc2XhHzbqD8p4ANw/1kPsFBfTvP1b7Gn/Lg1vO7R9J4IVgoMbyUmFrFGZafJ1hPZpvlg==} dev: true - /destroy@1.2.0: + /destroy/1.2.0: resolution: {integrity: sha512-2sJGJTaXIIaR1w4iJSNoN0hnMY7Gpc/n8D4qSCJw8QqFWXf7cuAgnEHxBpweaVcPevC2l3KpjYCx3NypQQgaJg==} engines: {node: '>= 0.8', npm: 1.2.8000 || >= 1.4.16} dev: true - /detab@2.0.4: + /detab/2.0.4: resolution: {integrity: sha512-8zdsQA5bIkoRECvCrNKPla84lyoR7DSAyf7p0YgXzBO9PDJx8KntPUay7NS6yp+KdxdVtiE5SpHKtbp2ZQyA9g==} dependencies: repeat-string: 1.6.1 dev: true - /detect-indent@6.1.0: + /detect-indent/6.1.0: resolution: {integrity: sha512-reYkTUJAZb9gUuZ2RvVCNhVHdg62RHnJ7WJl8ftMi4diZ6NWlciOzQN88pUhSELEwflJht4oQDv0F0BMlwaYtA==} engines: {node: '>=8'} dev: true - /detect-libc@2.0.1: + /detect-libc/2.0.1: resolution: {integrity: sha512-463v3ZeIrcWtdgIg6vI6XUncguvr2TnGl4SzDXinkt9mSLpBJKXT3mW6xT3VQdDN11+WVs29pgvivTc4Lp8v+w==} engines: {node: '>=8'} dev: true - /detect-newline@3.1.0: - resolution: {integrity: sha512-TLz+x/vEXm/Y7P7wn1EJFNLxYpUD4TgMosxY6fAVJUnJMbupHBOncxyWUG9OpTaH9EBD7uFI5LfEgmMOc54DsA==} - engines: {node: '>=8'} - dev: true - - /detect-node@2.1.0: + /detect-node/2.1.0: resolution: {integrity: sha512-T0NIuQpnTvFDATNuHN5roPwSBG83rFsuO+MXXH9/3N1eFbn4wcPjttvjMLEPWJ0RGUYgQE7cGgS3tNxbqCGM7g==} - /detect-package-manager@2.0.1: + /detect-package-manager/2.0.1: resolution: {integrity: sha512-j/lJHyoLlWi6G1LDdLgvUtz60Zo5GEj+sVYtTVXnYLDPuzgC3llMxonXym9zIwhhUII8vjdw0LXxavpLqTbl1A==} engines: {node: '>=12'} dependencies: execa: 5.1.1 dev: true - /detect-port@1.3.0: - resolution: {integrity: sha512-E+B1gzkl2gqxt1IhUzwjrxBKRqx1UzC3WLONHinn8S3T6lwV/agVCyitiFOsGJ/eYuEUBvD71MZHy3Pv1G9doQ==} - engines: {node: '>= 4.2.1'} + /detect-port/1.5.1: + resolution: {integrity: sha512-aBzdj76lueB6uUst5iAs7+0H/oOjqI5D16XUWxlWMIMROhcM0rfsNVk93zTngq1dDNpoXRr++Sus7ETAExppAQ==} hasBin: true dependencies: - address: 1.2.0 - debug: 2.6.9 + address: 1.2.2 + debug: 4.3.4 transitivePeerDependencies: - supports-color dev: true - /devalue@4.3.2: + /devalue/4.3.2: resolution: {integrity: sha512-KqFl6pOgOW+Y6wJgu80rHpo2/3H07vr8ntR9rkkFIRETewbf5GaYYcakYfiKz89K+sLsuPkQIZaXDMjUObZwWg==} dev: true - /devtools-protocol@0.0.1120988: + /devtools-protocol/0.0.1120988: resolution: {integrity: sha512-39fCpE3Z78IaIPChJsP6Lhmkbf4dWXOmzLk/KFTdRkNk/0JymRIfUynDVRndV9HoDz8PyalK1UH21ST/ivwW5Q==} dev: true - /devtools-protocol@0.0.1161598: + /devtools-protocol/0.0.1161598: resolution: {integrity: sha512-MQNeVRDiJ9yAfHUlumx7OCweu15GgMIqEIvz/DTZwpZKjT7oGo9FcwUqS7PyH0mDJsWnuJIn41BZ4SPoQbZfew==} dev: true - /devtools-protocol@0.0.981744: + /devtools-protocol/0.0.981744: resolution: {integrity: sha512-0cuGS8+jhR67Fy7qG3i3Pc7Aw494sb9yG9QgpG97SFVWwolgYjlhJg7n+UaHxOQT30d1TYu/EYe9k01ivLErIg==} dev: true - /devtools@8.12.1(typescript@5.1.6): + /devtools/8.12.1: resolution: {integrity: sha512-R72raQLN1lDSqbr2DVj9SRh07JRyojzmrcLa33VBa2nw3cf5ZyHOHe0DgxlJ/5c2Dfs1+wGNJy16gWKGBq+xgg==} engines: {node: ^16.13 || >=18} dependencies: @@ -13317,14 +11341,14 @@ packages: '@wdio/protocols': 8.11.0 '@wdio/types': 8.10.4 '@wdio/utils': 8.12.1 - chrome-launcher: 0.15.1 + chrome-launcher: 0.15.2 edge-paths: 3.0.5 import-meta-resolve: 3.0.0 - puppeteer-core: 20.3.0(typescript@5.1.6) + puppeteer-core: 20.3.0 query-selector-shadow-dom: 1.0.1 - ua-parser-js: 1.0.34 + ua-parser-js: 1.0.35 uuid: 9.0.0 - which: 3.0.0 + which: 3.0.1 transitivePeerDependencies: - bufferutil - encoding @@ -13333,28 +11357,23 @@ packages: - utf-8-validate dev: true - /dezalgo@1.0.3: - resolution: {integrity: sha512-K7i4zNfT2kgQz3GylDw40ot9GAE47sFZ9EXHFSPP6zONLgH6kWXE0KWJchkbQJLBkRazq4APwZ4OwiFFlT95OQ==} + /dezalgo/1.0.4: + resolution: {integrity: sha512-rXSP0bf+5n0Qonsb+SVVfNfIsimO4HEtmnIpPHY8Q1UCzKlQrDMfdobr8nJOOsRgWCyMRqeSBQzmWUMq7zvVig==} dependencies: asap: 2.0.6 wrappy: 1.0.2 dev: true - /diff-sequences@27.5.1: - resolution: {integrity: sha512-k1gCAXAsNgLwEL+Y8Wvl+M6oEFj5bgazfZULpS5CneoPPXRaCCW7dm+q21Ky2VEE5X+VeRDBVg1Pcvvsr4TtNQ==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dev: true - - /diff-sequences@29.4.3: + /diff-sequences/29.4.3: resolution: {integrity: sha512-ofrBgwpPhCD85kMKtE9RYFFq6OC1A89oW2vvgWZNCwxrUpRUILopY7lsYyMDSjc8g6U6aiO0Qubg6r4Wgt5ZnA==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} - /diff@4.0.2: + /diff/4.0.2: resolution: {integrity: sha512-58lmxKSA4BNyLz+HHMUzlOEpg09FV+ev6ZMe3vJihgdxzgcwZ8VoEEPmALCZG9LmqfVoNMMKpttIYTVG6uDY7A==} engines: {node: '>=0.3.1'} dev: true - /diffie-hellman@5.0.3: + /diffie-hellman/5.0.3: resolution: {integrity: sha512-kqag/Nl+f3GwyK25fhUMYj81BUOrZ9IuJsjIcDE5icNM9FJHAVm3VcUDxdLPoQtTuUylWm6ZIknYJwwaPxsUzg==} dependencies: bn.js: 4.12.0 @@ -13362,66 +11381,66 @@ packages: randombytes: 2.1.0 dev: true - /dir-glob@2.2.2: + /dir-glob/2.2.2: resolution: {integrity: sha512-f9LBi5QWzIW3I6e//uxZoLBlUt9kcp66qo0sSCxL6YZKc75R1c4MFCoe/LaZiBGmgujvQdxc5Bn3QhfyvK5Hsw==} engines: {node: '>=4'} dependencies: path-type: 3.0.0 dev: true - /dir-glob@3.0.1: + /dir-glob/3.0.1: resolution: {integrity: sha512-WkrWp9GR4KXfKGYzOLmTuGVi1UWFfws377n9cc55/tb6DuqyF6pcQ5AbiHEshaDpY9v6oaSr2XCDidGmMwdzIA==} engines: {node: '>=8'} dependencies: path-type: 4.0.0 dev: true - /discontinuous-range@1.0.0: - resolution: {integrity: sha1-44Mx8IRLukm5qctxx3FYWqsbxlo=} + /discontinuous-range/1.0.0: + resolution: {integrity: sha512-c68LpLbO+7kP/b1Hr1qs8/BJ09F5khZGTxqxZuhzxpmwJKOgRFHJWIb9/KmqnqHhLdO55aOxFH/EGBvUQbL/RQ==} dev: true - /doctrine@2.1.0: + /doctrine/2.1.0: resolution: {integrity: sha512-35mSku4ZXK0vfCuHEDAwt55dg2jNajHZ1odvF+8SSr82EsZY4QmXfuWso8oEd8zRhVObSN18aM0CjSdoBX7zIw==} engines: {node: '>=0.10.0'} dependencies: esutils: 2.0.3 dev: true - /doctrine@3.0.0: + /doctrine/3.0.0: resolution: {integrity: sha512-yS+Q5i3hBf7GBkd4KG8a7eBNNWNGLTaEwwYWUijIYM7zrlYDM0BFXHjjPWlWZ1Rg7UaddZeIDmi9jF3HmqiQ2w==} engines: {node: '>=6.0.0'} dependencies: esutils: 2.0.3 dev: true - /dom-accessibility-api@0.5.14: - resolution: {integrity: sha512-NMt+m9zFMPZe0JcY9gN224Qvk6qLIdqex29clBvc/y75ZBX9YA9wNK3frsYvu2DI1xcCIwxwnX+TlsJ2DSOADg==} + /dom-accessibility-api/0.5.16: + resolution: {integrity: sha512-X7BJ2yElsnOJ30pZF4uIIDfBEVgF4XEBxL9Bxhy6dnrm5hkzqmsWHGTiHqRiITNhMyFLyAiWndIJP7Z1NTteDg==} dev: true - /dom-converter@0.2.0: + /dom-converter/0.2.0: resolution: {integrity: sha512-gd3ypIPfOMr9h5jIKq8E3sHOTCjeirnl0WK5ZdS1AW0Odt0b1PaWaHdJ4Qk4klv+YB9aJBS7mESXjFoDQPu6DA==} dependencies: utila: 0.4.0 dev: true - /dom-event-types@1.1.0: + /dom-event-types/1.1.0: resolution: {integrity: sha512-jNCX+uNJ3v38BKvPbpki6j5ItVlnSqVV6vDWGS6rExzCMjsc39frLjm1n91o6YaKK6AZl0wLloItW6C6mr61BQ==} dev: true - /dom-helpers@3.4.0: + /dom-helpers/3.4.0: resolution: {integrity: sha512-LnuPJ+dwqKDIyotW1VzmOZ5TONUN7CwkCR5hrgawTUbkBGYdeoNLZo6nNfGkCrjtE1nXXaj7iMMpDa8/d9WoIA==} dependencies: - '@babel/runtime': 7.18.9 + '@babel/runtime': 7.22.6 dev: false - /dom-helpers@5.2.1: + /dom-helpers/5.2.1: resolution: {integrity: sha512-nRCa7CK3VTrM2NmGkIy4cbK7IZlgBE/PYMn55rrXefr5xXDP0LdtfPnblFDoVdcAfslJ7or6iqAUnx0CCGIWQA==} dependencies: - '@babel/runtime': 7.18.9 + '@babel/runtime': 7.22.6 csstype: 3.1.2 dev: false - /dom-serializer@1.4.1: + /dom-serializer/1.4.1: resolution: {integrity: sha512-VHwB3KfrcOOkelEG2ZOfxqLZdfkil8PtJi4P8N2MMXucZq2yLp75ClViUlOVwyoHEDjYU433Aq+5zWP61+RGag==} dependencies: domelementtype: 2.3.0 @@ -13429,7 +11448,7 @@ packages: entities: 2.2.0 dev: true - /dom-serializer@2.0.0: + /dom-serializer/2.0.0: resolution: {integrity: sha512-wIkAryiqt/nV5EQKqQpo3SToSOV9J0DnbJqwK7Wv/Trc92zIAYZ4FlMu+JPFW1DfGFt81ZTCGgDEabffXeLyJg==} dependencies: domelementtype: 2.3.0 @@ -13437,55 +11456,48 @@ packages: entities: 4.5.0 dev: true - /dom-walk@0.1.2: + /dom-walk/0.1.2: resolution: {integrity: sha512-6QvTW9mrGeIegrFXdtQi9pk7O/nSK6lSdXW2eqUspN5LWD7UTji2Fqw5V2YLjBpHEoU9Xl/eUWNpDeZvoyOv2w==} dev: true - /domain-browser@1.2.0: + /domain-browser/1.2.0: resolution: {integrity: sha512-jnjyiM6eRyZl2H+W8Q/zLMA481hzi0eszAaBUzIVnmYVDBbnLxVNnfu1HgEBvCbL+71FrxMl3E6lpKH7Ge3OXA==} engines: {node: '>=0.4', npm: '>=1.2'} dev: true - /domelementtype@2.3.0: + /domelementtype/2.3.0: resolution: {integrity: sha512-OLETBj6w0OsagBwdXnPdN0cnMfF9opN69co+7ZrbfPGrdpPVNBUj02spi6B1N7wChLQiPn4CSH/zJvXw56gmHw==} dev: true - /domexception@2.0.1: - resolution: {integrity: sha512-yxJ2mFy/sibVQlu5qHjOkf9J3K6zgmCxgJ94u2EdvDOV09H+32LtRswEcUsmUWN72pVLOEnTSRaIVVzVQgS0dg==} - engines: {node: '>=8'} - dependencies: - webidl-conversions: 5.0.0 - dev: true - - /domexception@4.0.0: + /domexception/4.0.0: resolution: {integrity: sha512-A2is4PLG+eeSfoTMA95/s4pvAoSo2mKtiM5jlHkAVewmiO8ISFTFKZjH7UAM1Atli/OT/7JHOrJRJiMKUZKYBw==} engines: {node: '>=12'} dependencies: webidl-conversions: 7.0.0 dev: true - /domhandler@3.3.0: + /domhandler/3.3.0: resolution: {integrity: sha512-J1C5rIANUbuYK+FuFL98650rihynUOEzRLxW+90bKZRWB6A1X1Tf82GxR1qAWLyfNPRvjqfip3Q5tdYlmAa9lA==} engines: {node: '>= 4'} dependencies: domelementtype: 2.3.0 dev: true - /domhandler@4.3.1: + /domhandler/4.3.1: resolution: {integrity: sha512-GrwoxYN+uWlzO8uhUXRl0P+kHE4GtVPfYzVLcUxPL7KNdHKj66vvlhiweIHqYYXWlw+T8iLMp42Lm67ghw4WMQ==} engines: {node: '>= 4'} dependencies: domelementtype: 2.3.0 dev: true - /domhandler@5.0.3: + /domhandler/5.0.3: resolution: {integrity: sha512-cgwlv/1iFQiFnU96XXgROh8xTeetsnJiDsTc7TYCLFd9+/WNkIqPTxiM/8pSd8VIrhXGTf1Ny1q1hquVqDJB5w==} engines: {node: '>= 4'} dependencies: domelementtype: 2.3.0 dev: true - /domutils@2.8.0: + /domutils/2.8.0: resolution: {integrity: sha512-w96Cjofp72M5IIhpjgobBimYEfoPjx1Vx0BSX9P30WBdZW2WIKU0T1Bd0kz2eNZ9ikjKgHbEyKx8BB6H1L3h3A==} dependencies: dom-serializer: 1.4.1 @@ -13493,60 +11505,60 @@ packages: domhandler: 4.3.1 dev: true - /domutils@3.0.1: - resolution: {integrity: sha512-z08c1l761iKhDFtfXO04C7kTdPBLi41zwOZl00WS8b5eiaebNpY00HKbztwBq+e3vyqWNwWF3mP9YLUeqIrF+Q==} + /domutils/3.1.0: + resolution: {integrity: sha512-H78uMmQtI2AhgDJjWeQmHwJJ2bLPD3GMmO7Zja/ZZh84wkm+4ut+IUnUdRa8uCGX88DiVx1j6FRe1XfxEgjEZA==} dependencies: dom-serializer: 2.0.0 domelementtype: 2.3.0 domhandler: 5.0.3 dev: true - /dot-case@3.0.4: + /dot-case/3.0.4: resolution: {integrity: sha512-Kv5nKlh6yRrdrGvxeJ2e5y2eRUpkUosIW4A2AS38zwSz27zu7ufDwQPi5Jhs3XAlGNetl3bmnGhQsMtkKJnj3w==} dependencies: no-case: 3.0.4 - tslib: 2.5.3 + tslib: 2.6.0 dev: true - /dotenv-expand@5.1.0: + /dotenv-expand/5.1.0: resolution: {integrity: sha512-YXQl1DSa4/PQyRfgrv6aoNjhasp/p4qs9FjJ4q4cQk+8m4r6k4ZSiEyytKG8f8W9gi8WsQtIObNmKd+tMzNTmA==} dev: true - /dotenv@16.0.3: - resolution: {integrity: sha512-7GO6HghkA5fYG9TYnNxi14/7K9f5occMlp3zXAuSxn7CKCxt9xbNWG7yF8hTCSUchlfWSe3uLmlPfigevRItzQ==} + /dotenv/16.3.1: + resolution: {integrity: sha512-IPzF4w4/Rd94bA9imS68tZBaYyBWSCE47V1RGuMrB94iyTOIEwRmVL2x/4An+6mETpLrKJ5hQkB8W4kFAadeIQ==} engines: {node: '>=12'} dev: true - /dotenv@8.6.0: + /dotenv/8.6.0: resolution: {integrity: sha512-IrPdXQsk2BbzvCBGBOTmmSH5SodmqZNt4ERAZDmW4CT+tL8VtvinqywuANaFu4bOMWki16nqf0e4oC0QIaDr/g==} engines: {node: '>=10'} dev: true - /duplexer@0.1.2: + /duplexer/0.1.2: resolution: {integrity: sha512-jtD6YG370ZCIi/9GTaJKQxWTZD045+4R4hTk/x1UyoqadyJ9x9CgSi1RlVDQF8U2sxLLSnFkCaMihqljHIWgMg==} dev: true - /duplexify@3.7.1: + /duplexify/3.7.1: resolution: {integrity: sha512-07z8uv2wMyS51kKhD1KsdXJg5WQ6t93RneqRxUHnskXVtlYYkLqM0gqStQZ3pj073g687jPCHrqNfCzawLYh5g==} dependencies: end-of-stream: 1.4.4 inherits: 2.0.4 - readable-stream: 2.3.7 + readable-stream: 2.3.8 stream-shift: 1.0.1 dev: true - /eastasianwidth@0.2.0: + /eastasianwidth/0.2.0: resolution: {integrity: sha512-I88TYZWc9XiYHRQ4/3c5rjjfgkjhLyW2luGIheGERbNQ6OY7yTybanSpDXZa8y7VUP9YmDcYa+eyq4ca7iLqWA==} dev: true - /ecc-jsbn@0.1.2: + /ecc-jsbn/0.1.2: resolution: {integrity: sha512-eh9O+hwRHNbG4BLTjEl3nw044CkGm5X6LoaCf7LPp7UU8Qrt47JYNi6nPX8xjW97TKGKm1ouctg0QSpZe9qrnw==} dependencies: jsbn: 0.1.1 safer-buffer: 2.1.2 dev: true - /edge-paths@3.0.5: + /edge-paths/3.0.5: resolution: {integrity: sha512-sB7vSrDnFa4ezWQk9nZ/n0FdpdUuC6R1EOrlU3DL+bovcNFK28rqu2emmAUjujYEJTWIgQGqgVVWUZXMnc8iWg==} engines: {node: '>=14.0.0'} dependencies: @@ -13554,32 +11566,32 @@ packages: which: 2.0.2 dev: true - /editorconfig@0.15.3: + /editorconfig/0.15.3: resolution: {integrity: sha512-M9wIMFx96vq0R4F+gRpY3o2exzb8hEj/n9S8unZtHSvYjibBp/iMufSzvmOcV/laG0ZtuTVGtiJggPOSW2r93g==} hasBin: true dependencies: commander: 2.20.3 lru-cache: 4.1.5 - semver: 5.7.1 + semver: 5.7.2 sigmund: 1.0.1 dev: true - /ee-first@1.1.1: - resolution: {integrity: sha1-WQxhFWsK4vTwJVcyoViyZrxWsh0=} + /ee-first/1.1.1: + resolution: {integrity: sha512-WMwm9LhRUo+WUaRN+vRuETqG89IgZphVSNkdFgeb6sS/E4OrDIN7t48CAewSHXc6C8lefD8KKfr5vY61brQlow==} dev: true - /ejs@3.1.8: - resolution: {integrity: sha512-/sXZeMlhS0ArkfX2Aw780gJzXSMPnKjtspYZv+f3NiKLlubezAHDU5+9xz6gd3/NhG3txQCo6xlglmTS+oTGEQ==} + /ejs/3.1.9: + resolution: {integrity: sha512-rC+QVNMJWv+MtPgkt0y+0rVEIdbtxVADApW9JXrUVlzHetgcyczP/E7DJmWJ4fJCZF2cPcBk0laWO9ZHMG3DmQ==} engines: {node: '>=0.10.0'} hasBin: true dependencies: - jake: 10.8.5 + jake: 10.8.7 dev: true - /electron-to-chromium@1.4.237: - resolution: {integrity: sha512-vxVyGJcsgArNOVUJcXm+7iY3PJAfmSapEszQD1HbyPLl0qoCmNQ1o/EX3RI7Et5/88In9oLxX3SGF8J3orkUgA==} + /electron-to-chromium/1.4.457: + resolution: {integrity: sha512-/g3UyNDmDd6ebeWapmAoiyy+Sy2HyJ+/X8KyvNeHfKRFfHaA2W8oF5fxD5F3tjBDcjpwo0iek6YNgxNXDBoEtA==} - /elliptic@6.5.4: + /elliptic/6.5.4: resolution: {integrity: sha512-iLhC6ULemrljPZb+QutR5TQGB+pdW6KGD5RSegS+8sorOZT+rdQFbsQFJgvN3eRqNALqJer4oQ16YvJHlU8hzQ==} dependencies: bn.js: 4.12.0 @@ -13591,36 +11603,31 @@ packages: minimalistic-crypto-utils: 1.0.1 dev: true - /emittery@0.8.1: - resolution: {integrity: sha512-uDfvUjVrfGJJhymx/kz6prltenw1u7WrCg1oa94zYY8xxVpLLUu045LAT0dhDZdXG58/EpPL/5kA180fQ/qudg==} - engines: {node: '>=10'} - dev: true - - /emoji-regex@8.0.0: + /emoji-regex/8.0.0: resolution: {integrity: sha512-MSjYzcWNOA0ewAHpz0MxpYFvwg6yjy1NG3xteoqz644VCo/RPgnr1/GGt+ic3iJTzQ8Eu3TdM14SawnVUmGE6A==} dev: true - /emoji-regex@9.2.2: + /emoji-regex/9.2.2: resolution: {integrity: sha512-L18DaJsXSUk2+42pv8mLs5jJT2hqFkFE4j21wOmgbUqsZ2hL72NsUU785g9RXgo3s0ZNgVl42TiHp3ZtOv/Vyg==} dev: true - /emojis-list@3.0.0: + /emojis-list/3.0.0: resolution: {integrity: sha512-/kyM18EfinwXZbno9FyUGeFh87KC8HRQBQGildHZbEuRyWFOmv1U10o9BBp8XVZDVNNuQKyIGIu5ZYAAXJ0V2Q==} engines: {node: '>= 4'} dev: true - /encodeurl@1.0.2: + /encodeurl/1.0.2: resolution: {integrity: sha512-TPJXq8JqFaVYm2CWmPvnP2Iyo4ZSM7/QKcSmuMLDObfpH5fi7RUGmd/rTDf+rut/saiDiQEeVTNgAmJEdAOx0w==} engines: {node: '>= 0.8'} dev: true - /end-of-stream@1.4.4: + /end-of-stream/1.4.4: resolution: {integrity: sha512-+uw1inIHVPQoaVuHzRyXd21icM+cnt4CzD5rW+NC1wjOUSTOs+Te7FOv7AhN7vS9x/oIyhLP5PR1H+phQAHu5Q==} dependencies: once: 1.4.0 dev: true - /endent@2.1.0: + /endent/2.1.0: resolution: {integrity: sha512-r8VyPX7XL8U01Xgnb1CjZ3XV+z90cXIJ9JPE/R9SEC9vpw2P6CfsRPJmp20DppC5N7ZAMCmjYkJIa744Iyg96w==} dependencies: dedent: 0.7.0 @@ -13628,130 +11635,140 @@ packages: objectorarray: 1.0.5 dev: true - /enhanced-resolve@4.5.0: + /enhanced-resolve/4.5.0: resolution: {integrity: sha512-Nv9m36S/vxpsI+Hc4/ZGRs0n9mXqSWGGq49zxb/cJfPAQMbUtttJAlNPS4AQzaBdw/pKskw5bMbekT/Y7W/Wlg==} engines: {node: '>=6.9.0'} dependencies: - graceful-fs: 4.2.10 + graceful-fs: 4.2.11 memory-fs: 0.5.0 tapable: 1.1.3 dev: true - /enhanced-resolve@5.10.0: - resolution: {integrity: sha512-T0yTFjdpldGY8PmuXXR0PyQ1ufZpEGiHVrp7zHKB7jdR4qlmZHhONVM5AQOAWXuF/w3dnHbEQVrNptJgt7F+cQ==} + /enhanced-resolve/5.15.0: + resolution: {integrity: sha512-LXYT42KJ7lpIKECr2mAXIaMldcNCh/7E0KBKOu4KSfkHmP+mZmSs+8V5gBAqisWBy0OO4W5Oyys0GO1Y8KtdKg==} engines: {node: '>=10.13.0'} dependencies: - graceful-fs: 4.2.10 + graceful-fs: 4.2.11 tapable: 2.2.1 dev: true - /enquirer@2.3.6: + /enquirer/2.3.6: resolution: {integrity: sha512-yjNnPr315/FjS4zIsUxYguYUPP2e1NK4d7E7ZOLiyYCcbFBiTMyID+2wvm2w6+pZ/odMA7cRkjhsPbltwBOrLg==} engines: {node: '>=8.6'} dependencies: ansi-colors: 4.1.3 dev: true - /entities@2.2.0: + /entities/2.2.0: resolution: {integrity: sha512-p92if5Nz619I0w+akJrLZH0MX0Pb5DX39XOwQTtXSdQQOaYH03S1uIQp4mhOZtAXrxq4ViO67YTiLBo2638o9A==} dev: true - /entities@4.5.0: + /entities/4.5.0: resolution: {integrity: sha512-V0hjH4dGPh9Ao5p0MoRY6BVqtwCjhz6vI5LT8AJ55H+4g9/4vbHx1I54fS0XuclLhDHArPQCiMjDxjaL8fPxhw==} engines: {node: '>=0.12'} dev: true - /enzyme-shallow-equal@1.0.4: - resolution: {integrity: sha512-MttIwB8kKxypwHvRynuC3ahyNc+cFbR8mjVIltnmzQ0uKGqmsfO4bfBuLxb0beLNPhjblUEYvEbsg+VSygvF1Q==} + /enzyme-shallow-equal/1.0.5: + resolution: {integrity: sha512-i6cwm7hN630JXenxxJFBKzgLC3hMTafFQXflvzHgPmDhOBhxUWDe8AeRv1qp2/uWJ2Y8z5yLWMzmAfkTOiOCZg==} dependencies: has: 1.0.3 object-is: 1.1.5 dev: true - /enzyme@3.11.0: + /enzyme/3.11.0: resolution: {integrity: sha512-Dw8/Gs4vRjxY6/6i9wU0V+utmQO9kvh9XLnz3LIudviOnVYDEe2ec+0k+NQoMamn1VrjKgCUOWj5jG/5M5M0Qw==} dependencies: - array.prototype.flat: 1.3.0 + array.prototype.flat: 1.3.1 cheerio: 1.0.0-rc.12 - enzyme-shallow-equal: 1.0.4 + enzyme-shallow-equal: 1.0.5 function.prototype.name: 1.1.5 has: 1.0.3 html-element-map: 1.3.1 is-boolean-object: 1.1.2 - is-callable: 1.2.4 + is-callable: 1.2.7 is-number-object: 1.0.7 is-regex: 1.1.4 is-string: 1.0.7 is-subset: 0.1.1 lodash.escape: 4.0.1 lodash.isequal: 4.5.0 - object-inspect: 1.12.2 + object-inspect: 1.12.3 object-is: 1.1.5 object.assign: 4.1.4 - object.entries: 1.1.5 - object.values: 1.1.5 + object.entries: 1.1.6 + object.values: 1.1.6 raf: 3.4.1 rst-selector-parser: 2.2.3 - string.prototype.trim: 1.2.6 + string.prototype.trim: 1.2.7 dev: true - /errno@0.1.8: + /errno/0.1.8: resolution: {integrity: sha512-dJ6oBr5SQ1VSd9qkk7ByRgb/1SH4JZjCHSW/mr63/QcXO9zLVxvJ6Oy13nio03rxpSnVDDjFor75SjVeZWPW/A==} hasBin: true dependencies: prr: 1.0.1 dev: true - /error-ex@1.3.2: + /error-ex/1.3.2: resolution: {integrity: sha512-7dFHNmqeFSEt2ZBsCriorKnn3Z2pj+fd9kmI6QoWw4//DL+icEBfc0U7qJCisqrTsKTjw4fNFy2pW9OqStD84g==} dependencies: is-arrayish: 0.2.1 - /error-stack-parser@2.1.4: + /error-stack-parser/2.1.4: resolution: {integrity: sha512-Sk5V6wVazPhq5MhpO+AUxJn5x7XSXGl1R93Vn7i+zS15KDVxQijejNCrz8340/2bgLBjR9GtEG8ZVKONDjcqGQ==} dependencies: stackframe: 1.3.4 dev: true - /es-abstract@1.20.4: - resolution: {integrity: sha512-0UtvRN79eMe2L+UNEF1BwRe364sj/DXhQ/k5FmivgoSdpM90b8Jc0mDzKMGo7QS0BVbOP/bTwBKNnDc9rNzaPA==} + /es-abstract/1.21.2: + resolution: {integrity: sha512-y/B5POM2iBnIxCiernH1G7rC9qQoM77lLIMQLuob0zhp8C56Po81+2Nj0WFKnd0pNReDTnkYryc+zhOzpEIROg==} engines: {node: '>= 0.4'} dependencies: + array-buffer-byte-length: 1.0.0 + available-typed-arrays: 1.0.5 call-bind: 1.0.2 + es-set-tostringtag: 2.0.1 es-to-primitive: 1.2.1 - function-bind: 1.1.1 function.prototype.name: 1.1.5 - get-intrinsic: 1.2.0 + get-intrinsic: 1.2.1 get-symbol-description: 1.0.0 + globalthis: 1.0.3 + gopd: 1.0.1 has: 1.0.3 has-property-descriptors: 1.0.0 + has-proto: 1.0.1 has-symbols: 1.0.3 internal-slot: 1.0.5 + is-array-buffer: 3.0.2 is-callable: 1.2.7 is-negative-zero: 2.0.2 is-regex: 1.1.4 is-shared-array-buffer: 1.0.2 is-string: 1.0.7 + is-typed-array: 1.1.10 is-weakref: 1.0.2 object-inspect: 1.12.3 object-keys: 1.1.1 object.assign: 4.1.4 regexp.prototype.flags: 1.5.0 safe-regex-test: 1.0.0 - string.prototype.trimend: 1.0.5 - string.prototype.trimstart: 1.0.5 + string.prototype.trim: 1.2.7 + string.prototype.trimend: 1.0.6 + string.prototype.trimstart: 1.0.6 + typed-array-length: 1.0.4 unbox-primitive: 1.0.2 + which-typed-array: 1.1.10 dev: true - /es-array-method-boxes-properly@1.0.0: + /es-array-method-boxes-properly/1.0.0: resolution: {integrity: sha512-wd6JXUmyHmt8T5a2xreUwKcGPq6f1f+WwIJkijUqiGcJz1qqnZgP6XIK+QyIWU5lT7imeNxUll48bziG+TSYcA==} dev: true - /es-get-iterator@1.1.3: + /es-get-iterator/1.1.3: resolution: {integrity: sha512-sPZmqHBe6JIiTfN5q2pEi//TwxmAFHwj/XEuYjTuse78i8KxaqMTTzxPoFKuzRpDpTJ+0NAbpfenkmH2rePtuw==} dependencies: call-bind: 1.0.2 - get-intrinsic: 1.2.0 + get-intrinsic: 1.2.1 has-symbols: 1.0.3 is-arguments: 1.1.1 is-map: 2.0.2 @@ -13761,21 +11778,30 @@ packages: stop-iteration-iterator: 1.0.0 dev: true - /es-module-lexer@0.9.3: + /es-module-lexer/0.9.3: resolution: {integrity: sha512-1HQ2M2sPtxwnvOvT1ZClHyQDiggdNjURWpY2we6aMKCQiUVxTmVs2UYPLIrD84sS+kMdUwfBSylbJPwNnBrnHQ==} dev: true - /es-module-lexer@1.1.0: - resolution: {integrity: sha512-fJg+1tiyEeS8figV+fPcPpm8WqJEflG3yPU0NOm5xMvrNkuiy7HzX/Ljng4Y0hAoiw4/3hQTCFYw+ub8+a2pRA==} + /es-module-lexer/1.3.0: + resolution: {integrity: sha512-vZK7T0N2CBmBOixhmjdqx2gWVbFZ4DXZ/NyRMZVlJXPa7CyFS+/a4QQsDGDQy9ZfEzxFuNEsMLeQJnKP2p5/JA==} + dev: true + + /es-set-tostringtag/2.0.1: + resolution: {integrity: sha512-g3OMbtlwY3QewlqAiMLI47KywjWZoEytKr8pf6iTC8uJq5bIAH52Z9pnQ8pVL6whrCto53JZDuUIsifGeLorTg==} + engines: {node: '>= 0.4'} + dependencies: + get-intrinsic: 1.2.1 + has: 1.0.3 + has-tostringtag: 1.0.0 dev: true - /es-shim-unscopables@1.0.0: + /es-shim-unscopables/1.0.0: resolution: {integrity: sha512-Jm6GPcCdC30eMLbZ2x8z2WuRwAws3zTBBKuusffYVUrNj/GVSUAZ+xKMaUpfNDR5IbyNA5LJbaecoUVbmUcB1w==} dependencies: has: 1.0.3 dev: true - /es-to-primitive@1.2.1: + /es-to-primitive/1.2.1: resolution: {integrity: sha512-QCOllgZJtaUo9miYBcLChTUaHNjJF3PYs1VidD7AwiEj1kYxKeQTctLAezAOH5ZKRH0g2IgPn6KwB4IT8iRpvA==} engines: {node: '>= 0.4'} dependencies: @@ -13784,20 +11810,20 @@ packages: is-symbol: 1.0.4 dev: true - /es5-shim@4.6.7: + /es5-shim/4.6.7: resolution: {integrity: sha512-jg21/dmlrNQI7JyyA2w7n+yifSxBng0ZralnSfVZjoCawgNTCnS+yBCyVM9DL5itm7SUnDGgv7hcq2XCZX4iRQ==} engines: {node: '>=0.4.0'} dev: true - /es6-promise@3.3.1: + /es6-promise/3.3.1: resolution: {integrity: sha512-SOp9Phqvqn7jtEUxPWdWfWoLmyt2VaJ6MpvP9Comy1MceMXqE6bxvaTu4iaxpYYPzhny28Lc+M87/c2cPK6lDg==} dev: true - /es6-shim@0.35.6: - resolution: {integrity: sha512-EmTr31wppcaIAgblChZiuN/l9Y7DPyw8Xtbg7fIVngn6zMW+IEBJDJngeKC3x6wr0V/vcA2wqeFnaw1bFJbDdA==} + /es6-shim/0.35.8: + resolution: {integrity: sha512-Twf7I2v4/1tLoIXMT8HlqaBSS5H2wQTs2wx3MNYCI8K1R1/clXyCazrcVCPm/FuO9cyV8+leEaZOWD5C253NDg==} dev: true - /esbuild-android-64@0.14.54: + /esbuild-android-64/0.14.54: resolution: {integrity: sha512-Tz2++Aqqz0rJ7kYBfz+iqyE3QMycD4vk7LBRyWaAVFgFtQ/O8EJOnVmTOiDWYZ/uYzB4kvP+bqejYdVKzE5lAQ==} engines: {node: '>=12'} cpu: [x64] @@ -13806,16 +11832,7 @@ packages: dev: false optional: true - /esbuild-android-64@0.15.18: - resolution: {integrity: sha512-wnpt3OXRhcjfIDSZu9bnzT4/TNTDsOUvip0foZOUBG7QbSt//w3QV4FInVJxNhKc/ErhUxc5z4QjHtMi7/TbgA==} - engines: {node: '>=12'} - cpu: [x64] - os: [android] - requiresBuild: true - dev: true - optional: true - - /esbuild-android-arm64@0.14.54: + /esbuild-android-arm64/0.14.54: resolution: {integrity: sha512-F9E+/QDi9sSkLaClO8SOV6etqPd+5DgJje1F9lOWoNncDdOBL2YF59IhsWATSt0TLZbYCf3pNlTHvVV5VfHdvg==} engines: {node: '>=12'} cpu: [arm64] @@ -13824,16 +11841,7 @@ packages: dev: false optional: true - /esbuild-android-arm64@0.15.18: - resolution: {integrity: sha512-G4xu89B8FCzav9XU8EjsXacCKSG2FT7wW9J6hOc18soEHJdtWu03L3TQDGf0geNxfLTtxENKBzMSq9LlbjS8OQ==} - engines: {node: '>=12'} - cpu: [arm64] - os: [android] - requiresBuild: true - dev: true - optional: true - - /esbuild-darwin-64@0.14.54: + /esbuild-darwin-64/0.14.54: resolution: {integrity: sha512-jtdKWV3nBviOd5v4hOpkVmpxsBy90CGzebpbO9beiqUYVMBtSc0AL9zGftFuBon7PNDcdvNCEuQqw2x0wP9yug==} engines: {node: '>=12'} cpu: [x64] @@ -13842,16 +11850,7 @@ packages: dev: false optional: true - /esbuild-darwin-64@0.15.18: - resolution: {integrity: sha512-2WAvs95uPnVJPuYKP0Eqx+Dl/jaYseZEUUT1sjg97TJa4oBtbAKnPnl3b5M9l51/nbx7+QAEtuummJZW0sBEmg==} - engines: {node: '>=12'} - cpu: [x64] - os: [darwin] - requiresBuild: true - dev: true - optional: true - - /esbuild-darwin-arm64@0.14.54: + /esbuild-darwin-arm64/0.14.54: resolution: {integrity: sha512-OPafJHD2oUPyvJMrsCvDGkRrVCar5aVyHfWGQzY1dWnzErjrDuSETxwA2HSsyg2jORLY8yBfzc1MIpUkXlctmw==} engines: {node: '>=12'} cpu: [arm64] @@ -13860,16 +11859,7 @@ packages: dev: false optional: true - /esbuild-darwin-arm64@0.15.18: - resolution: {integrity: sha512-tKPSxcTJ5OmNb1btVikATJ8NftlyNlc8BVNtyT/UAr62JFOhwHlnoPrhYWz09akBLHI9nElFVfWSTSRsrZiDUA==} - engines: {node: '>=12'} - cpu: [arm64] - os: [darwin] - requiresBuild: true - dev: true - optional: true - - /esbuild-freebsd-64@0.14.54: + /esbuild-freebsd-64/0.14.54: resolution: {integrity: sha512-OKwd4gmwHqOTp4mOGZKe/XUlbDJ4Q9TjX0hMPIDBUWWu/kwhBAudJdBoxnjNf9ocIB6GN6CPowYpR/hRCbSYAg==} engines: {node: '>=12'} cpu: [x64] @@ -13878,16 +11868,7 @@ packages: dev: false optional: true - /esbuild-freebsd-64@0.15.18: - resolution: {integrity: sha512-TT3uBUxkteAjR1QbsmvSsjpKjOX6UkCstr8nMr+q7zi3NuZ1oIpa8U41Y8I8dJH2fJgdC3Dj3CXO5biLQpfdZA==} - engines: {node: '>=12'} - cpu: [x64] - os: [freebsd] - requiresBuild: true - dev: true - optional: true - - /esbuild-freebsd-arm64@0.14.54: + /esbuild-freebsd-arm64/0.14.54: resolution: {integrity: sha512-sFwueGr7OvIFiQT6WeG0jRLjkjdqWWSrfbVwZp8iMP+8UHEHRBvlaxL6IuKNDwAozNUmbb8nIMXa7oAOARGs1Q==} engines: {node: '>=12'} cpu: [arm64] @@ -13896,16 +11877,7 @@ packages: dev: false optional: true - /esbuild-freebsd-arm64@0.15.18: - resolution: {integrity: sha512-R/oVr+X3Tkh+S0+tL41wRMbdWtpWB8hEAMsOXDumSSa6qJR89U0S/PpLXrGF7Wk/JykfpWNokERUpCeHDl47wA==} - engines: {node: '>=12'} - cpu: [arm64] - os: [freebsd] - requiresBuild: true - dev: true - optional: true - - /esbuild-linux-32@0.14.54: + /esbuild-linux-32/0.14.54: resolution: {integrity: sha512-1ZuY+JDI//WmklKlBgJnglpUL1owm2OX+8E1syCD6UAxcMM/XoWd76OHSjl/0MR0LisSAXDqgjT3uJqT67O3qw==} engines: {node: '>=12'} cpu: [ia32] @@ -13914,16 +11886,7 @@ packages: dev: false optional: true - /esbuild-linux-32@0.15.18: - resolution: {integrity: sha512-lphF3HiCSYtaa9p1DtXndiQEeQDKPl9eN/XNoBf2amEghugNuqXNZA/ZovthNE2aa4EN43WroO0B85xVSjYkbg==} - engines: {node: '>=12'} - cpu: [ia32] - os: [linux] - requiresBuild: true - dev: true - optional: true - - /esbuild-linux-64@0.14.54: + /esbuild-linux-64/0.14.54: resolution: {integrity: sha512-EgjAgH5HwTbtNsTqQOXWApBaPVdDn7XcK+/PtJwZLT1UmpLoznPd8c5CxqsH2dQK3j05YsB3L17T8vE7cp4cCg==} engines: {node: '>=12'} cpu: [x64] @@ -13932,34 +11895,7 @@ packages: dev: false optional: true - /esbuild-linux-64@0.15.18: - resolution: {integrity: sha512-hNSeP97IviD7oxLKFuii5sDPJ+QHeiFTFLoLm7NZQligur8poNOWGIgpQ7Qf8Balb69hptMZzyOBIPtY09GZYw==} - engines: {node: '>=12'} - cpu: [x64] - os: [linux] - requiresBuild: true - dev: true - optional: true - - /esbuild-linux-arm64@0.14.54: - resolution: {integrity: sha512-WL71L+0Rwv+Gv/HTmxTEmpv0UgmxYa5ftZILVi2QmZBgX3q7+tDeOQNqGtdXSdsL8TQi1vIaVFHUPDe0O0kdig==} - engines: {node: '>=12'} - cpu: [arm64] - os: [linux] - requiresBuild: true - dev: false - optional: true - - /esbuild-linux-arm64@0.15.18: - resolution: {integrity: sha512-54qr8kg/6ilcxd+0V3h9rjT4qmjc0CccMVWrjOEM/pEcUzt8X62HfBSeZfT2ECpM7104mk4yfQXkosY8Quptug==} - engines: {node: '>=12'} - cpu: [arm64] - os: [linux] - requiresBuild: true - dev: true - optional: true - - /esbuild-linux-arm@0.14.54: + /esbuild-linux-arm/0.14.54: resolution: {integrity: sha512-qqz/SjemQhVMTnvcLGoLOdFpCYbz4v4fUo+TfsWG+1aOu70/80RV6bgNpR2JCrppV2moUQkww+6bWxXRL9YMGw==} engines: {node: '>=12'} cpu: [arm] @@ -13968,16 +11904,16 @@ packages: dev: false optional: true - /esbuild-linux-arm@0.15.18: - resolution: {integrity: sha512-UH779gstRblS4aoS2qpMl3wjg7U0j+ygu3GjIeTonCcN79ZvpPee12Qun3vcdxX+37O5LFxz39XeW2I9bybMVA==} + /esbuild-linux-arm64/0.14.54: + resolution: {integrity: sha512-WL71L+0Rwv+Gv/HTmxTEmpv0UgmxYa5ftZILVi2QmZBgX3q7+tDeOQNqGtdXSdsL8TQi1vIaVFHUPDe0O0kdig==} engines: {node: '>=12'} - cpu: [arm] + cpu: [arm64] os: [linux] requiresBuild: true - dev: true + dev: false optional: true - /esbuild-linux-mips64le@0.14.54: + /esbuild-linux-mips64le/0.14.54: resolution: {integrity: sha512-qTHGQB8D1etd0u1+sB6p0ikLKRVuCWhYQhAHRPkO+OF3I/iSlTKNNS0Lh2Oc0g0UFGguaFZZiPJdJey3AGpAlw==} engines: {node: '>=12'} cpu: [mips64el] @@ -13986,70 +11922,34 @@ packages: dev: false optional: true - /esbuild-linux-mips64le@0.15.18: - resolution: {integrity: sha512-Mk6Ppwzzz3YbMl/ZZL2P0q1tnYqh/trYZ1VfNP47C31yT0K8t9s7Z077QrDA/guU60tGNp2GOwCQnp+DYv7bxQ==} - engines: {node: '>=12'} - cpu: [mips64el] - os: [linux] - requiresBuild: true - dev: true - optional: true - - /esbuild-linux-ppc64le@0.14.54: + /esbuild-linux-ppc64le/0.14.54: resolution: {integrity: sha512-j3OMlzHiqwZBDPRCDFKcx595XVfOfOnv68Ax3U4UKZ3MTYQB5Yz3X1mn5GnodEVYzhtZgxEBidLWeIs8FDSfrQ==} engines: {node: '>=12'} cpu: [ppc64] os: [linux] requiresBuild: true - dev: false - optional: true - - /esbuild-linux-ppc64le@0.15.18: - resolution: {integrity: sha512-b0XkN4pL9WUulPTa/VKHx2wLCgvIAbgwABGnKMY19WhKZPT+8BxhZdqz6EgkqCLld7X5qiCY2F/bfpUUlnFZ9w==} - engines: {node: '>=12'} - cpu: [ppc64] - os: [linux] - requiresBuild: true - dev: true - optional: true - - /esbuild-linux-riscv64@0.14.54: - resolution: {integrity: sha512-y7Vt7Wl9dkOGZjxQZnDAqqn+XOqFD7IMWiewY5SPlNlzMX39ocPQlOaoxvT4FllA5viyV26/QzHtvTjVNOxHZg==} - engines: {node: '>=12'} - cpu: [riscv64] - os: [linux] - requiresBuild: true - dev: false - optional: true - - /esbuild-linux-riscv64@0.15.18: - resolution: {integrity: sha512-ba2COaoF5wL6VLZWn04k+ACZjZ6NYniMSQStodFKH/Pu6RxzQqzsmjR1t9QC89VYJxBeyVPTaHuBMCejl3O/xg==} - engines: {node: '>=12'} - cpu: [riscv64] - os: [linux] - requiresBuild: true - dev: true + dev: false optional: true - /esbuild-linux-s390x@0.14.54: - resolution: {integrity: sha512-zaHpW9dziAsi7lRcyV4r8dhfG1qBidQWUXweUjnw+lliChJqQr+6XD71K41oEIC3Mx1KStovEmlzm+MkGZHnHA==} + /esbuild-linux-riscv64/0.14.54: + resolution: {integrity: sha512-y7Vt7Wl9dkOGZjxQZnDAqqn+XOqFD7IMWiewY5SPlNlzMX39ocPQlOaoxvT4FllA5viyV26/QzHtvTjVNOxHZg==} engines: {node: '>=12'} - cpu: [s390x] + cpu: [riscv64] os: [linux] requiresBuild: true dev: false optional: true - /esbuild-linux-s390x@0.15.18: - resolution: {integrity: sha512-VbpGuXEl5FCs1wDVp93O8UIzl3ZrglgnSQ+Hu79g7hZu6te6/YHgVJxCM2SqfIila0J3k0csfnf8VD2W7u2kzQ==} + /esbuild-linux-s390x/0.14.54: + resolution: {integrity: sha512-zaHpW9dziAsi7lRcyV4r8dhfG1qBidQWUXweUjnw+lliChJqQr+6XD71K41oEIC3Mx1KStovEmlzm+MkGZHnHA==} engines: {node: '>=12'} cpu: [s390x] os: [linux] requiresBuild: true - dev: true + dev: false optional: true - /esbuild-netbsd-64@0.14.54: + /esbuild-netbsd-64/0.14.54: resolution: {integrity: sha512-PR01lmIMnfJTgeU9VJTDY9ZerDWVFIUzAtJuDHwwceppW7cQWjBBqP48NdeRtoP04/AtO9a7w3viI+PIDr6d+w==} engines: {node: '>=12'} cpu: [x64] @@ -14058,16 +11958,7 @@ packages: dev: false optional: true - /esbuild-netbsd-64@0.15.18: - resolution: {integrity: sha512-98ukeCdvdX7wr1vUYQzKo4kQ0N2p27H7I11maINv73fVEXt2kyh4K4m9f35U1K43Xc2QGXlzAw0K9yoU7JUjOg==} - engines: {node: '>=12'} - cpu: [x64] - os: [netbsd] - requiresBuild: true - dev: true - optional: true - - /esbuild-openbsd-64@0.14.54: + /esbuild-openbsd-64/0.14.54: resolution: {integrity: sha512-Qyk7ikT2o7Wu76UsvvDS5q0amJvmRzDyVlL0qf5VLsLchjCa1+IAvd8kTBgUxD7VBUUVgItLkk609ZHUc1oCaw==} engines: {node: '>=12'} cpu: [x64] @@ -14076,16 +11967,7 @@ packages: dev: false optional: true - /esbuild-openbsd-64@0.15.18: - resolution: {integrity: sha512-yK5NCcH31Uae076AyQAXeJzt/vxIo9+omZRKj1pauhk3ITuADzuOx5N2fdHrAKPxN+zH3w96uFKlY7yIn490xQ==} - engines: {node: '>=12'} - cpu: [x64] - os: [openbsd] - requiresBuild: true - dev: true - optional: true - - /esbuild-sunos-64@0.14.54: + /esbuild-sunos-64/0.14.54: resolution: {integrity: sha512-28GZ24KmMSeKi5ueWzMcco6EBHStL3B6ubM7M51RmPwXQGLe0teBGJocmWhgwccA1GeFXqxzILIxXpHbl9Q/Kw==} engines: {node: '>=12'} cpu: [x64] @@ -14094,16 +11976,7 @@ packages: dev: false optional: true - /esbuild-sunos-64@0.15.18: - resolution: {integrity: sha512-On22LLFlBeLNj/YF3FT+cXcyKPEI263nflYlAhz5crxtp3yRG1Ugfr7ITyxmCmjm4vbN/dGrb/B7w7U8yJR9yw==} - engines: {node: '>=12'} - cpu: [x64] - os: [sunos] - requiresBuild: true - dev: true - optional: true - - /esbuild-windows-32@0.14.54: + /esbuild-windows-32/0.14.54: resolution: {integrity: sha512-T+rdZW19ql9MjS7pixmZYVObd9G7kcaZo+sETqNH4RCkuuYSuv9AGHUVnPoP9hhuE1WM1ZimHz1CIBHBboLU7w==} engines: {node: '>=12'} cpu: [ia32] @@ -14112,16 +11985,7 @@ packages: dev: false optional: true - /esbuild-windows-32@0.15.18: - resolution: {integrity: sha512-o+eyLu2MjVny/nt+E0uPnBxYuJHBvho8vWsC2lV61A7wwTWC3jkN2w36jtA+yv1UgYkHRihPuQsL23hsCYGcOQ==} - engines: {node: '>=12'} - cpu: [ia32] - os: [win32] - requiresBuild: true - dev: true - optional: true - - /esbuild-windows-64@0.14.54: + /esbuild-windows-64/0.14.54: resolution: {integrity: sha512-AoHTRBUuYwXtZhjXZbA1pGfTo8cJo3vZIcWGLiUcTNgHpJJMC1rVA44ZereBHMJtotyN71S8Qw0npiCIkW96cQ==} engines: {node: '>=12'} cpu: [x64] @@ -14130,16 +11994,7 @@ packages: dev: false optional: true - /esbuild-windows-64@0.15.18: - resolution: {integrity: sha512-qinug1iTTaIIrCorAUjR0fcBk24fjzEedFYhhispP8Oc7SFvs+XeW3YpAKiKp8dRpizl4YYAhxMjlftAMJiaUw==} - engines: {node: '>=12'} - cpu: [x64] - os: [win32] - requiresBuild: true - dev: true - optional: true - - /esbuild-windows-arm64@0.14.54: + /esbuild-windows-arm64/0.14.54: resolution: {integrity: sha512-M0kuUvXhot1zOISQGXwWn6YtS+Y/1RT9WrVIOywZnJHo3jCDyewAc79aKNQWFCQm+xNHVTq9h8dZKvygoXQQRg==} engines: {node: '>=12'} cpu: [arm64] @@ -14148,16 +12003,7 @@ packages: dev: false optional: true - /esbuild-windows-arm64@0.15.18: - resolution: {integrity: sha512-q9bsYzegpZcLziq0zgUi5KqGVtfhjxGbnksaBFYmWLxeV/S1fK4OLdq2DFYnXcLMjlZw2L0jLsk1eGoB522WXQ==} - engines: {node: '>=12'} - cpu: [arm64] - os: [win32] - requiresBuild: true - dev: true - optional: true - - /esbuild@0.14.54: + /esbuild/0.14.54: resolution: {integrity: sha512-Cy9llcy8DvET5uznocPyqL3BFRrFXSVqbgpMJ9Wz8oVjZlh/zUSNbPRbov0VX7VxN2JH1Oa0uNxZ7eLRb62pJA==} engines: {node: '>=12'} hasBin: true @@ -14186,66 +12032,37 @@ packages: esbuild-windows-arm64: 0.14.54 dev: false - /esbuild@0.15.18: - resolution: {integrity: sha512-x/R72SmW3sSFRm5zrrIjAhCeQSAWoni3CmHEqfQrZIQTM3lVCdehdwuIqaOtfC2slvpdlLa62GYoN8SxT23m6Q==} - engines: {node: '>=12'} - hasBin: true - requiresBuild: true - optionalDependencies: - '@esbuild/android-arm': 0.15.18 - '@esbuild/linux-loong64': 0.15.18 - esbuild-android-64: 0.15.18 - esbuild-android-arm64: 0.15.18 - esbuild-darwin-64: 0.15.18 - esbuild-darwin-arm64: 0.15.18 - esbuild-freebsd-64: 0.15.18 - esbuild-freebsd-arm64: 0.15.18 - esbuild-linux-32: 0.15.18 - esbuild-linux-64: 0.15.18 - esbuild-linux-arm: 0.15.18 - esbuild-linux-arm64: 0.15.18 - esbuild-linux-mips64le: 0.15.18 - esbuild-linux-ppc64le: 0.15.18 - esbuild-linux-riscv64: 0.15.18 - esbuild-linux-s390x: 0.15.18 - esbuild-netbsd-64: 0.15.18 - esbuild-openbsd-64: 0.15.18 - esbuild-sunos-64: 0.15.18 - esbuild-windows-32: 0.15.18 - esbuild-windows-64: 0.15.18 - esbuild-windows-arm64: 0.15.18 - dev: true - - /esbuild@0.17.18: - resolution: {integrity: sha512-z1lix43jBs6UKjcZVKOw2xx69ffE2aG0PygLL5qJ9OS/gy0Ewd1gW/PUQIOIQGXBHWNywSc0floSKoMFF8aK2w==} + /esbuild/0.17.19: + resolution: {integrity: sha512-XQ0jAPFkK/u3LcVRcvVHQcTIqD6E2H1fvZMA5dQPSOWb3suUbWbfbRf94pjc0bNzRYLfIrDRQXr7X+LHIm5oHw==} engines: {node: '>=12'} hasBin: true requiresBuild: true optionalDependencies: - '@esbuild/android-arm': 0.17.18 - '@esbuild/android-arm64': 0.17.18 - '@esbuild/android-x64': 0.17.18 - '@esbuild/darwin-arm64': 0.17.18 - '@esbuild/darwin-x64': 0.17.18 - '@esbuild/freebsd-arm64': 0.17.18 - '@esbuild/freebsd-x64': 0.17.18 - '@esbuild/linux-arm': 0.17.18 - '@esbuild/linux-arm64': 0.17.18 - '@esbuild/linux-ia32': 0.17.18 - '@esbuild/linux-loong64': 0.17.18 - '@esbuild/linux-mips64el': 0.17.18 - '@esbuild/linux-ppc64': 0.17.18 - '@esbuild/linux-riscv64': 0.17.18 - '@esbuild/linux-s390x': 0.17.18 - '@esbuild/linux-x64': 0.17.18 - '@esbuild/netbsd-x64': 0.17.18 - '@esbuild/openbsd-x64': 0.17.18 - '@esbuild/sunos-x64': 0.17.18 - '@esbuild/win32-arm64': 0.17.18 - '@esbuild/win32-ia32': 0.17.18 - '@esbuild/win32-x64': 0.17.18 - - /esbuild@0.18.11: + '@esbuild/android-arm': 0.17.19 + '@esbuild/android-arm64': 0.17.19 + '@esbuild/android-x64': 0.17.19 + '@esbuild/darwin-arm64': 0.17.19 + '@esbuild/darwin-x64': 0.17.19 + '@esbuild/freebsd-arm64': 0.17.19 + '@esbuild/freebsd-x64': 0.17.19 + '@esbuild/linux-arm': 0.17.19 + '@esbuild/linux-arm64': 0.17.19 + '@esbuild/linux-ia32': 0.17.19 + '@esbuild/linux-loong64': 0.17.19 + '@esbuild/linux-mips64el': 0.17.19 + '@esbuild/linux-ppc64': 0.17.19 + '@esbuild/linux-riscv64': 0.17.19 + '@esbuild/linux-s390x': 0.17.19 + '@esbuild/linux-x64': 0.17.19 + '@esbuild/netbsd-x64': 0.17.19 + '@esbuild/openbsd-x64': 0.17.19 + '@esbuild/sunos-x64': 0.17.19 + '@esbuild/win32-arm64': 0.17.19 + '@esbuild/win32-ia32': 0.17.19 + '@esbuild/win32-x64': 0.17.19 + dev: true + + /esbuild/0.18.11: resolution: {integrity: sha512-i8u6mQF0JKJUlGR3OdFLKldJQMMs8OqM9Cc3UCi9XXziJ9WERM5bfkHaEAy0YAvPRMgqSW55W7xYn84XtEFTtA==} engines: {node: '>=12'} hasBin: true @@ -14273,58 +12090,56 @@ packages: '@esbuild/win32-arm64': 0.18.11 '@esbuild/win32-ia32': 0.18.11 '@esbuild/win32-x64': 0.18.11 - dev: true - /escalade@3.1.1: + /escalade/3.1.1: resolution: {integrity: sha512-k0er2gUkLf8O0zKJiAhmkTnJlTvINGv7ygDNPbeIsX/TJjGJZHuh9B2UxbsaEkmlEo9MfhrSzmhIlhRlI2GXnw==} engines: {node: '>=6'} - /escape-html@1.0.3: + /escape-html/1.0.3: resolution: {integrity: sha512-NiSupZ4OeuGwr68lGIeym/ksIZMJodUGOSCZ/FSnTxcrekbvqrgdUxlJOMpijaKZVjAJrWrGs/6Jy8OMuyj9ow==} dev: true - /escape-string-regexp@1.0.5: + /escape-string-regexp/1.0.5: resolution: {integrity: sha512-vbRorB5FUQWvla16U8R/qgaFIya2qGzwDrNmCZuYKrbdSUMG6I1ZCGQRefkRVhuOkIGVne7BQ35DSfo1qvJqFg==} engines: {node: '>=0.8.0'} - /escape-string-regexp@2.0.0: + /escape-string-regexp/2.0.0: resolution: {integrity: sha512-UpzcLCXolUWcNu5HtVMHYdXJjArjsF9C0aNnquZYY4uW/Vu0miy5YoWvbV345HauVvcAUnpRuhMMcqTcGOY2+w==} engines: {node: '>=8'} dev: true - /escape-string-regexp@4.0.0: + /escape-string-regexp/4.0.0: resolution: {integrity: sha512-TtpcNJ3XAzx3Gq8sWRzJaVajRs0uVxA2YAkdb1jm2YkPz4G6egUFAyA3n5vtEIZefPk5Wa4UXbKuS5fKkJWdgA==} engines: {node: '>=10'} - /escape-string-regexp@5.0.0: + /escape-string-regexp/5.0.0: resolution: {integrity: sha512-/veY75JbMK4j1yjvuUxuVsiS/hr/4iHs9FTT6cgTexxdE0Ly/glccBAkloH/DofkjRbZU3bnoj38mOmhkZ0lHw==} engines: {node: '>=12'} dev: true - /escodegen@2.0.0: - resolution: {integrity: sha512-mmHKys/C8BFUGI+MAWNcSYoORYLMdPzjrknd2Vc+bUsjN5bXcr8EhrNB+UTqfL1y3I9c4fw2ihgtMPQLBRiQxw==} + /escodegen/2.1.0: + resolution: {integrity: sha512-2NlIDTwUWJN0mRPQOdtQBzbUHvdGY2P1VXSyU83Q3xKxM7WHX2Ql8dKq782Q9TgQUNOLEzEYu9bzLNj1q88I5w==} engines: {node: '>=6.0'} hasBin: true dependencies: esprima: 4.0.1 estraverse: 5.3.0 esutils: 2.0.3 - optionator: 0.8.3 optionalDependencies: source-map: 0.6.1 dev: true - /eslint-import-resolver-node@0.3.7: + /eslint-import-resolver-node/0.3.7: resolution: {integrity: sha512-gozW2blMLJCeFpBwugLTGyvVjNoeo1knonXAcatC6bjPBZitotxdWf7Gimr25N4c0AAOo4eOUfaG82IJPDpqCA==} dependencies: - debug: 3.2.7(supports-color@8.1.1) + debug: 3.2.7 is-core-module: 2.12.1 - resolve: 1.22.2 + resolve: 1.22.3 transitivePeerDependencies: - supports-color dev: true - /eslint-module-utils@2.8.0(@typescript-eslint/parser@5.60.0)(eslint-import-resolver-node@0.3.7)(eslint@8.44.0): + /eslint-module-utils/2.8.0_obwxlbvpmtyn54zwezzu2ooh6u: resolution: {integrity: sha512-aWajIYfsqCKRDgUfjEXNN/JlrzauMuSEy5sbd7WXbtW3EH6A6MpwEh42c7qD+MqQo9QMJ6fWLAeIJynx0g6OAw==} engines: {node: '>=4'} peerDependencies: @@ -14345,36 +12160,36 @@ packages: eslint-import-resolver-webpack: optional: true dependencies: - '@typescript-eslint/parser': 5.60.0(eslint@8.44.0)(typescript@5.1.6) - debug: 3.2.7(supports-color@8.1.1) + '@typescript-eslint/parser': 5.62.0_iqf7tbmerllfqanu4l3d6aqdn4 + debug: 3.2.7 eslint: 8.44.0 eslint-import-resolver-node: 0.3.7 transitivePeerDependencies: - supports-color dev: true - /eslint-plugin-antfu@0.39.6(eslint@8.44.0)(typescript@5.1.6): - resolution: {integrity: sha512-ecZ+tfk4OrkrHVfJT+li89ZRsxaAWRcFwB9SqqN+NBMaZxP4+pjtRIngcX8dto+BF/L/o50oGePoK6kapxt6aw==} + /eslint-plugin-antfu/0.39.7_iqf7tbmerllfqanu4l3d6aqdn4: + resolution: {integrity: sha512-z+xqVTnneKogHuJLTSmIbFb8Ll0TVGeghufz56hAVa6JCKOsVpvqOkVjJDZ+R/JGnzqvA+GTBh1fugxlspq3Rw==} dependencies: - '@typescript-eslint/utils': 5.60.0(eslint@8.44.0)(typescript@5.1.6) + '@typescript-eslint/utils': 5.62.0_iqf7tbmerllfqanu4l3d6aqdn4 transitivePeerDependencies: - eslint - supports-color - typescript dev: true - /eslint-plugin-es-x@6.2.1(eslint@8.44.0): - resolution: {integrity: sha512-uR34zUhZ9EBoiSD2DdV5kHLpydVEvwWqjteUr9sXRgJknwbKZJZhdJ7uFnaTtd+Nr/2G3ceJHnHXrFhJ67n3Tw==} + /eslint-plugin-es-x/7.1.0_eslint@8.44.0: + resolution: {integrity: sha512-AhiaF31syh4CCQ+C5ccJA0VG6+kJK8+5mXKKE7Qs1xcPRg02CDPOj3mWlQxuWS/AYtg7kxrDNgW9YW3vc0Q+Mw==} engines: {node: ^14.18.0 || >=16.0.0} peerDependencies: eslint: '>=8' dependencies: - '@eslint-community/eslint-utils': 4.4.0(eslint@8.44.0) - '@eslint-community/regexpp': 4.5.0 + '@eslint-community/eslint-utils': 4.4.0_eslint@8.44.0 + '@eslint-community/regexpp': 4.5.1 eslint: 8.44.0 dev: true - /eslint-plugin-eslint-comments@3.2.0(eslint@8.44.0): + /eslint-plugin-eslint-comments/3.2.0_eslint@8.44.0: resolution: {integrity: sha512-0jkOl0hfojIHHmEHgmNdqv4fmh7300NdpA9FFpF7zaoLvB/QeXOGNLIo86oAveJFrfB1p05kC8hpEMHM8DwWVQ==} engines: {node: '>=6.5.0'} peerDependencies: @@ -14382,16 +12197,16 @@ packages: dependencies: escape-string-regexp: 1.0.5 eslint: 8.44.0 - ignore: 5.2.0 + ignore: 5.2.4 dev: true - /eslint-plugin-html@7.1.0: + /eslint-plugin-html/7.1.0: resolution: {integrity: sha512-fNLRraV/e6j8e3XYOC9xgND4j+U7b1Rq+OygMlLcMg+wI/IpVbF+ubQa3R78EjKB9njT6TQOlcK5rFKBVVtdfg==} dependencies: - htmlparser2: 8.0.1 + htmlparser2: 8.0.2 dev: true - /eslint-plugin-i@2.27.5-3(@typescript-eslint/parser@5.60.0)(eslint@8.44.0): + /eslint-plugin-i/2.27.5-3_owyyv4y74swggqrdagvp7hd7n4: resolution: {integrity: sha512-fxJkCgJmJ1j/4fQwoonVtXT9nwF/MZ5GTUm9bzFvJQIauJgkkaPblqiMox+2pFjXN+2F7xUeq+UzCDJGBJ+vOA==} engines: {node: '>=4'} peerDependencies: @@ -14400,11 +12215,11 @@ packages: array-includes: 3.1.6 array.prototype.flat: 1.3.1 array.prototype.flatmap: 1.3.1 - debug: 3.2.7(supports-color@8.1.1) + debug: 3.2.7 doctrine: 2.1.0 eslint: 8.44.0 eslint-import-resolver-node: 0.3.7 - eslint-module-utils: 2.8.0(@typescript-eslint/parser@5.60.0)(eslint-import-resolver-node@0.3.7)(eslint@8.44.0) + eslint-module-utils: 2.8.0_obwxlbvpmtyn54zwezzu2ooh6u get-tsconfig: 4.6.2 has: 1.0.3 is-core-module: 2.12.1 @@ -14412,7 +12227,7 @@ packages: minimatch: 3.1.2 object.values: 1.1.6 resolve: 1.22.3 - semver: 6.3.0 + semver: 6.3.1 transitivePeerDependencies: - '@typescript-eslint/parser' - eslint-import-resolver-typescript @@ -14420,8 +12235,8 @@ packages: - supports-color dev: true - /eslint-plugin-jest@27.2.1(@typescript-eslint/eslint-plugin@5.60.0)(eslint@8.44.0)(typescript@5.1.6): - resolution: {integrity: sha512-l067Uxx7ZT8cO9NJuf+eJHvt6bqJyz2Z29wykyEdz/OtmcELQl2MQGQLX8J94O1cSJWAwUSEvCjwjA7KEK3Hmg==} + /eslint-plugin-jest/27.2.2_qtrczavcy63fstz24hwardykcu: + resolution: {integrity: sha512-euzbp06F934Z7UDl5ZUaRPLAc9MKjh0rMPERrHT7UhlCEwgb25kBj37TvMgWeHZVkR5I9CayswrpoaqZU1RImw==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} peerDependencies: '@typescript-eslint/eslint-plugin': ^5.0.0 @@ -14433,27 +12248,27 @@ packages: jest: optional: true dependencies: - '@typescript-eslint/eslint-plugin': 5.60.0(@typescript-eslint/parser@5.60.0)(eslint@8.44.0)(typescript@5.1.6) - '@typescript-eslint/utils': 5.60.0(eslint@8.44.0)(typescript@5.1.6) + '@typescript-eslint/eslint-plugin': 5.62.0_l3h7p4bxv72z3fumgmc6kvfciu + '@typescript-eslint/utils': 5.62.0_iqf7tbmerllfqanu4l3d6aqdn4 eslint: 8.44.0 transitivePeerDependencies: - supports-color - typescript dev: true - /eslint-plugin-jsonc@2.9.0(eslint@8.44.0): + /eslint-plugin-jsonc/2.9.0_eslint@8.44.0: resolution: {integrity: sha512-RK+LeONVukbLwT2+t7/OY54NJRccTXh/QbnXzPuTLpFMVZhPuq1C9E07+qWenGx7rrQl0kAalAWl7EmB+RjpGA==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: eslint: '>=6.0.0' dependencies: - '@eslint-community/eslint-utils': 4.4.0(eslint@8.44.0) + '@eslint-community/eslint-utils': 4.4.0_eslint@8.44.0 eslint: 8.44.0 jsonc-eslint-parser: 2.3.0 natural-compare: 1.4.0 dev: true - /eslint-plugin-markdown@3.0.0(eslint@8.44.0): + /eslint-plugin-markdown/3.0.0_eslint@8.44.0: resolution: {integrity: sha512-hRs5RUJGbeHDLfS7ELanT0e29Ocyssf/7kBM+p7KluY5AwngGkDf8Oyu4658/NZSGTTq05FZeWbkxXtbVyHPwg==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: @@ -14465,29 +12280,29 @@ packages: - supports-color dev: true - /eslint-plugin-n@16.0.0(eslint@8.44.0): - resolution: {integrity: sha512-akkZTE3hsHBrq6CwmGuYCzQREbVUrA855kzcHqe6i0FLBkeY7Y/6tThCVkjUnjhvRBAlc+8lILcSe5QvvDpeZQ==} + /eslint-plugin-n/16.0.1_eslint@8.44.0: + resolution: {integrity: sha512-CDmHegJN0OF3L5cz5tATH84RPQm9kG+Yx39wIqIwPR2C0uhBGMWfbbOtetR83PQjjidA5aXMu+LEFw1jaSwvTA==} engines: {node: '>=16.0.0'} peerDependencies: eslint: '>=7.0.0' dependencies: - '@eslint-community/eslint-utils': 4.4.0(eslint@8.44.0) + '@eslint-community/eslint-utils': 4.4.0_eslint@8.44.0 builtins: 5.0.1 eslint: 8.44.0 - eslint-plugin-es-x: 6.2.1(eslint@8.44.0) - ignore: 5.2.0 + eslint-plugin-es-x: 7.1.0_eslint@8.44.0 + ignore: 5.2.4 is-core-module: 2.12.1 minimatch: 3.1.2 resolve: 1.22.2 - semver: 7.5.2 + semver: 7.5.4 dev: true - /eslint-plugin-no-only-tests@3.1.0: + /eslint-plugin-no-only-tests/3.1.0: resolution: {integrity: sha512-Lf4YW/bL6Un1R6A76pRZyE1dl1vr31G/ev8UzIc/geCgFWyrKil8hVjYqWVKGB/UIGmb6Slzs9T0wNezdSVegw==} engines: {node: '>=5.0.0'} dev: true - /eslint-plugin-promise@6.1.1(eslint@8.44.0): + /eslint-plugin-promise/6.1.1_eslint@8.44.0: resolution: {integrity: sha512-tjqWDwVZQo7UIPMeDReOpUgHCmCiH+ePnVT+5zVapL0uuHnegBUs2smM13CzOs2Xb5+MHMRFTs9v24yjba4Oig==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: @@ -14496,14 +12311,14 @@ packages: eslint: 8.44.0 dev: true - /eslint-plugin-unicorn@47.0.0(eslint@8.44.0): + /eslint-plugin-unicorn/47.0.0_eslint@8.44.0: resolution: {integrity: sha512-ivB3bKk7fDIeWOUmmMm9o3Ax9zbMz1Bsza/R2qm46ufw4T6VBFBaJIR1uN3pCKSmSXm8/9Nri8V+iUut1NhQGA==} engines: {node: '>=16'} peerDependencies: eslint: '>=8.38.0' dependencies: '@babel/helper-validator-identifier': 7.22.5 - '@eslint-community/eslint-utils': 4.4.0(eslint@8.44.0) + '@eslint-community/eslint-utils': 4.4.0_eslint@8.44.0 ci-info: 3.8.0 clean-regexp: 1.0.0 eslint: 8.44.0 @@ -14514,14 +12329,14 @@ packages: lodash: 4.17.21 pluralize: 8.0.0 read-pkg-up: 7.0.1 - regexp-tree: 0.1.24 + regexp-tree: 0.1.27 regjsparser: 0.10.0 safe-regex: 2.1.1 - semver: 7.5.2 + semver: 7.5.4 strip-indent: 3.0.0 dev: true - /eslint-plugin-unused-imports@2.0.0(@typescript-eslint/eslint-plugin@5.60.0)(eslint@8.44.0): + /eslint-plugin-unused-imports/2.0.0_fjgzgq23hjlrbj45h2rdrfisla: resolution: {integrity: sha512-3APeS/tQlTrFa167ThtP0Zm0vctjr4M44HMpeg1P4bK6wItarumq0Ma82xorMKdFsWpphQBlRPzw/pxiVELX1A==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: @@ -14531,36 +12346,36 @@ packages: '@typescript-eslint/eslint-plugin': optional: true dependencies: - '@typescript-eslint/eslint-plugin': 5.60.0(@typescript-eslint/parser@5.60.0)(eslint@8.44.0)(typescript@5.1.6) + '@typescript-eslint/eslint-plugin': 5.62.0_l3h7p4bxv72z3fumgmc6kvfciu eslint: 8.44.0 eslint-rule-composer: 0.3.0 dev: true - /eslint-plugin-vue@9.15.0(eslint@8.44.0): - resolution: {integrity: sha512-XYzpK6e2REli100+6iCeBA69v6Sm0D/yK2FZP+fCeNt0yH/m82qZQq+ztseyV0JsKdhFysuSEzeE1yCmSC92BA==} + /eslint-plugin-vue/9.15.1_eslint@8.44.0: + resolution: {integrity: sha512-CJE/oZOslvmAR9hf8SClTdQ9JLweghT6JCBQNrT2Iel1uVw0W0OLJxzvPd6CxmABKCvLrtyDnqGV37O7KQv6+A==} engines: {node: ^14.17.0 || >=16.0.0} peerDependencies: eslint: ^6.2.0 || ^7.0.0 || ^8.0.0 dependencies: - '@eslint-community/eslint-utils': 4.4.0(eslint@8.44.0) + '@eslint-community/eslint-utils': 4.4.0_eslint@8.44.0 eslint: 8.44.0 natural-compare: 1.4.0 nth-check: 2.1.1 - postcss-selector-parser: 6.0.10 - semver: 7.5.2 - vue-eslint-parser: 9.3.1(eslint@8.44.0) + postcss-selector-parser: 6.0.13 + semver: 7.5.4 + vue-eslint-parser: 9.3.1_eslint@8.44.0 xml-name-validator: 4.0.0 transitivePeerDependencies: - supports-color dev: true - /eslint-plugin-yml@1.8.0(eslint@8.44.0): + /eslint-plugin-yml/1.8.0_eslint@8.44.0: resolution: {integrity: sha512-fgBiJvXD0P2IN7SARDJ2J7mx8t0bLdG6Zcig4ufOqW5hOvSiFxeUyc2g5I1uIm8AExbo26NNYCcTGZT0MXTsyg==} engines: {node: ^14.17.0 || >=16.0.0} peerDependencies: eslint: '>=6.0.0' dependencies: - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 eslint: 8.44.0 lodash: 4.17.21 natural-compare: 1.4.0 @@ -14569,12 +12384,12 @@ packages: - supports-color dev: true - /eslint-rule-composer@0.3.0: + /eslint-rule-composer/0.3.0: resolution: {integrity: sha512-bt+Sh8CtDmn2OajxvNO+BX7Wn4CIWMpTRm3MaiKPCQcnnlm0CS2mhui6QaoeQugs+3Kj2ESKEEGJUdVafwhiCg==} engines: {node: '>=4.0.0'} dev: true - /eslint-scope@4.0.3: + /eslint-scope/4.0.3: resolution: {integrity: sha512-p7VutNr1O/QrxysMo3E45FjYDTeXBy0iTltPFNSqKAIfjDSXC+4dj+qfyuD8bfAXrW/y6lW3O76VaYNPKfpKrg==} engines: {node: '>=4.0.0'} dependencies: @@ -14582,7 +12397,7 @@ packages: estraverse: 4.3.0 dev: true - /eslint-scope@5.1.1: + /eslint-scope/5.1.1: resolution: {integrity: sha512-2NxwbF/hZ0KpepYN0cNbo+FN6XoK7GaHlQhgx/hIZl6Va0bF45RQOOwhLIy8lQDbuCiadSLCBnH2CFYquit5bw==} engines: {node: '>=8.0.0'} dependencies: @@ -14590,7 +12405,7 @@ packages: estraverse: 4.3.0 dev: true - /eslint-scope@7.2.0: + /eslint-scope/7.2.0: resolution: {integrity: sha512-DYj5deGlHBfMt15J7rdtyKNq/Nqlv5KfU4iodrQ019XESsRnwXH9KAE0y3cwtUHDo2ob7CypAnCqefh6vioWRw==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dependencies: @@ -14598,7 +12413,7 @@ packages: estraverse: 5.3.0 dev: true - /eslint-utils@3.0.0(eslint@8.4.1): + /eslint-utils/3.0.0_eslint@8.4.1: resolution: {integrity: sha512-uuQC43IGctw68pJA1RgbQS8/NP7rch6Cwd4j3ZBtgo4/8Flj4eGE7ZYSZRN3iq5pVUv6GPdW5Z1RFleo84uLDA==} engines: {node: ^10.0.0 || ^12.0.0 || >= 14.0.0} peerDependencies: @@ -14608,17 +12423,17 @@ packages: eslint-visitor-keys: 2.1.0 dev: true - /eslint-visitor-keys@2.1.0: + /eslint-visitor-keys/2.1.0: resolution: {integrity: sha512-0rSmRBzXgDzIsD6mGdJgevzgezI534Cer5L/vyMX0kHzT/jiB43jRhd9YUlMGYLQy2zprNmoT8qasCGtY+QaKw==} engines: {node: '>=10'} dev: true - /eslint-visitor-keys@3.4.1: + /eslint-visitor-keys/3.4.1: resolution: {integrity: sha512-pZnmmLwYzf+kWaM/Qgrvpen51upAktaaiI01nsJD/Yr3lMOdNtq0cxkrrg16w64VtisN6okbs7Q8AfGqj4c9fA==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dev: true - /eslint@8.4.1: + /eslint/8.4.1: resolution: {integrity: sha512-TxU/p7LB1KxQ6+7aztTnO7K0i+h0tDi81YRY9VzB6Id71kNz+fFYnf5HD5UOQmxkzcoa0TlVZf9dpMtUv0GpWg==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} hasBin: true @@ -14628,21 +12443,21 @@ packages: ajv: 6.12.6 chalk: 4.1.2 cross-spawn: 7.0.3 - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 doctrine: 3.0.0 enquirer: 2.3.6 escape-string-regexp: 4.0.0 eslint-scope: 7.2.0 - eslint-utils: 3.0.0(eslint@8.4.1) + eslint-utils: 3.0.0_eslint@8.4.1 eslint-visitor-keys: 3.4.1 - espree: 9.5.2 + espree: 9.2.0 esquery: 1.5.0 esutils: 2.0.3 fast-deep-equal: 3.1.3 file-entry-cache: 6.0.1 functional-red-black-tree: 1.0.1 glob-parent: 6.0.2 - globals: 13.19.0 + globals: 13.20.0 ignore: 4.0.6 import-fresh: 3.3.0 imurmurhash: 0.1.4 @@ -14653,7 +12468,7 @@ packages: lodash.merge: 4.6.2 minimatch: 3.1.2 natural-compare: 1.4.0 - optionator: 0.9.1 + optionator: 0.9.3 progress: 2.0.3 regexpp: 3.2.0 semver: 7.5.4 @@ -14665,13 +12480,13 @@ packages: - supports-color dev: true - /eslint@8.44.0: + /eslint/8.44.0: resolution: {integrity: sha512-0wpHoUbDUHgNCyvFB5aXLiQVfK9B0at6gUvzy83k4kAsQ/u769TQDX6iKC+aO4upIHO9WSaA3QoXYQDHbNwf1A==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} hasBin: true dependencies: - '@eslint-community/eslint-utils': 4.4.0(eslint@8.44.0) - '@eslint-community/regexpp': 4.5.0 + '@eslint-community/eslint-utils': 4.4.0_eslint@8.44.0 + '@eslint-community/regexpp': 4.5.1 '@eslint/eslintrc': 2.1.0 '@eslint/js': 8.44.0 '@humanwhocodes/config-array': 0.11.10 @@ -14680,7 +12495,7 @@ packages: ajv: 6.12.6 chalk: 4.1.2 cross-spawn: 7.0.3 - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 doctrine: 3.0.0 escape-string-regexp: 4.0.0 eslint-scope: 7.2.0 @@ -14692,9 +12507,9 @@ packages: file-entry-cache: 6.0.1 find-up: 5.0.0 glob-parent: 6.0.2 - globals: 13.19.0 + globals: 13.20.0 graphemer: 1.4.0 - ignore: 5.2.0 + ignore: 5.2.4 import-fresh: 3.3.0 imurmurhash: 0.1.4 is-glob: 4.0.3 @@ -14713,147 +12528,138 @@ packages: - supports-color dev: true - /esm-env@1.0.0: + /esm-env/1.0.0: resolution: {integrity: sha512-Cf6VksWPsTuW01vU9Mk/3vRue91Zevka5SjyNf3nEpokFRuqt/KjUQoGAwq9qMmhpLTHmXzSIrFRw8zxWzmFBA==} dev: true - /esno@0.16.3: + /esno/0.16.3: resolution: {integrity: sha512-6slSBEV1lMKcX13DBifvnDFpNno5WXhw4j/ff7RI0y51BZiDqEe5dNhhjhIQ3iCOQuzsm2MbVzmwqbN78BBhPg==} hasBin: true dependencies: - tsx: 3.11.0 + tsx: 3.12.7 dev: true - /espree@9.2.0: + /espree/9.2.0: resolution: {integrity: sha512-oP3utRkynpZWF/F2x/HZJ+AGtnIclaR7z1pYPxy7NYM2fSO6LgK/Rkny8anRSPK/VwEA1eqm2squui0T7ZMOBg==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dependencies: - acorn: 8.9.0 - acorn-jsx: 5.3.2(acorn@8.9.0) - eslint-visitor-keys: 3.4.1 - dev: true - - /espree@9.5.2: - resolution: {integrity: sha512-7OASN1Wma5fum5SrNhFMAMJxOUAbhyfQ8dQ//PJaJbNw0URTPWqIghHWt1MmAANKhHZIYOHruW4Kw4ruUWOdGw==} - engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} - dependencies: - acorn: 8.9.0 - acorn-jsx: 5.3.2(acorn@8.9.0) + acorn: 8.10.0 + acorn-jsx: 5.3.2_acorn@8.10.0 eslint-visitor-keys: 3.4.1 dev: true - /espree@9.6.0: + /espree/9.6.0: resolution: {integrity: sha512-1FH/IiruXZ84tpUlm0aCUEwMl2Ho5ilqVh0VvQXw+byAz/4SAciyHLlfmL5WYqsvD38oymdUwBss0LtK8m4s/A==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dependencies: - acorn: 8.9.0 - acorn-jsx: 5.3.2(acorn@8.9.0) + acorn: 8.10.0 + acorn-jsx: 5.3.2_acorn@8.10.0 eslint-visitor-keys: 3.4.1 dev: true - /esprima-extract-comments@1.1.0: + /esprima-extract-comments/1.1.0: resolution: {integrity: sha512-sBQUnvJwpeE9QnPrxh7dpI/dp67erYG4WXEAreAMoelPRpMR7NWb4YtwRPn9b+H1uLQKl/qS8WYmyaljTpjIsw==} engines: {node: '>=4'} dependencies: esprima: 4.0.1 dev: true - /esprima@4.0.1: + /esprima/4.0.1: resolution: {integrity: sha512-eGuFFw7Upda+g4p+QHvnW0RyTX/SVeJBDM/gCtMARO0cLuT2HcEKnTPvhjV6aGeqrCB/sbNop0Kszm0jsaWU4A==} engines: {node: '>=4'} hasBin: true dev: true - /esquery@1.5.0: + /esquery/1.5.0: resolution: {integrity: sha512-YQLXUplAwJgCydQ78IMJywZCceoqk1oH01OERdSAJc/7U2AylwjhSCLDEtqwg811idIS/9fIU5GjG73IgjKMVg==} engines: {node: '>=0.10'} dependencies: estraverse: 5.3.0 dev: true - /esrecurse@4.3.0: + /esrecurse/4.3.0: resolution: {integrity: sha512-KmfKL3b6G+RXvP8N1vr3Tq1kL/oCFgn2NYXEtqP8/L3pKapUA4G8cFVaoF3SU323CD4XypR/ffioHmkti6/Tag==} engines: {node: '>=4.0'} dependencies: estraverse: 5.3.0 dev: true - /estraverse@4.3.0: + /estraverse/4.3.0: resolution: {integrity: sha512-39nnKffWz8xN1BU/2c79n9nB9HDzo0niYUqx6xyqUnyoAnQyyWpOTdZEeiCch8BBu515t4wp9ZmgVfVhn9EBpw==} engines: {node: '>=4.0'} dev: true - /estraverse@5.3.0: + /estraverse/5.3.0: resolution: {integrity: sha512-MMdARuVEQziNTeJD8DgMqmhwR11BRQ/cBP+pLtYdSTnf3MIO8fFeiINEbX36ZdNlfU/7A9f3gUw49B3oQsvwBA==} engines: {node: '>=4.0'} dev: true - /estree-to-babel@3.2.1: + /estree-to-babel/3.2.1: resolution: {integrity: sha512-YNF+mZ/Wu2FU/gvmzuWtYc8rloubL7wfXCTgouFrnjGVXPA/EeYYA7pupXWrb3Iv1cTBeSSxxJIbK23l4MRNqg==} engines: {node: '>=8.3.0'} dependencies: - '@babel/traverse': 7.22.5 + '@babel/traverse': 7.22.8 '@babel/types': 7.22.5 c8: 7.14.0 transitivePeerDependencies: - supports-color dev: true - /estree-walker@1.0.1: + /estree-walker/1.0.1: resolution: {integrity: sha512-1fMXF3YP4pZZVozF8j/ZLfvnR8NSIljt56UhbZ5PeeDmmGHpgpdwQt7ITlGvYaQukCvuBRMLEiKiYC+oeIg4cg==} - /estree-walker@2.0.2: + /estree-walker/2.0.2: resolution: {integrity: sha512-Rfkk/Mp/DL7JVje3u18FxFujQlTNR2q6QfMSMB7AvCBx91NGj/ba3kCfza0f6dVDbw7YlRf/nDrn7pQrCCyQ/w==} - /estree-walker@3.0.3: + /estree-walker/3.0.3: resolution: {integrity: sha512-7RUKfXgSMMkzt6ZuXmqapOurLGPPfgj6l9uRZ7lRGolvk0y2yocc35LdcxKC5PQZdn2DMqioAQ2NoWcrTKmm6g==} dependencies: '@types/estree': 1.0.1 - /esutils@2.0.3: + /esutils/2.0.3: resolution: {integrity: sha512-kVscqXk4OCp68SZ0dkgEKVi6/8ij300KBWTJq32P/dYeWTSwK41WyTxalN1eRmA5Z9UU/LX9D7FWSmV9SAYx6g==} engines: {node: '>=0.10.0'} dev: true - /etag@1.8.1: + /etag/1.8.1: resolution: {integrity: sha512-aIL5Fx7mawVa300al2BnEE4iNvo1qETxLrPI/o05L7z6go7fCw1J6EQmbK4FmJ2AS7kgVF/KEZWufBfdClMcPg==} engines: {node: '>= 0.6'} dev: true - /event-target-polyfill@0.0.3: + /event-target-polyfill/0.0.3: resolution: {integrity: sha512-ZMc6UuvmbinrCk4RzGyVmRyIsAyxMRlp4CqSrcQRO8Dy0A9ldbiRy5kdtBj4OtP7EClGdqGfIqo9JmOClMsGLQ==} dev: true - /event-target-shim@5.0.1: + /event-target-shim/5.0.1: resolution: {integrity: sha512-i/2XbnSz/uxRCU6+NdVJgKWDTM427+MqYbkQzD321DuCQJUqOuJKIA0IM2+W2xtYHdKOmZ4dR6fExsd4SXL+WQ==} engines: {node: '>=6'} dev: true - /eventemitter2@6.4.7: + /eventemitter2/6.4.7: resolution: {integrity: sha512-tYUSVOGeQPKt/eC1ABfhHy5Xd96N3oIijJvN3O9+TsC28T5V9yX9oEfEK5faP0EFSNVOG97qtAS68GBrQB2hDg==} dev: true - /eventemitter3@4.0.7: + /eventemitter3/4.0.7: resolution: {integrity: sha512-8guHBZCwKnFhYdHr2ysuRWErTwhoN2X8XELRlrRwpmfeY2jjuUN4taQMsULKUVo1K4DvZl+0pgfyoysHxvmvEw==} dev: false - /events@3.3.0: + /events/3.3.0: resolution: {integrity: sha512-mQw+2fkQbALzQ7V0MY0IqdnXNOeTtP4r0lN9z7AAawCXgqea7bDii20AYrIBrFd/Hx0M2Ocz6S111CaFkUcb0Q==} engines: {node: '>=0.8.x'} dev: true - /evp_bytestokey@1.0.3: + /evp_bytestokey/1.0.3: resolution: {integrity: sha512-/f2Go4TognH/KvCISP7OUsHn85hT9nUkxxA9BEWxFn+Oj9o8ZNLm/40hdlgSLyuOimsrTKLUMEorQexp/aPQeA==} dependencies: md5.js: 1.3.5 safe-buffer: 5.2.1 dev: true - /exec-sh@0.3.6: + /exec-sh/0.3.6: resolution: {integrity: sha512-nQn+hI3yp+oD0huYhKwvYI32+JFeq+XkNcD1GAo3Y/MjxsfVGmrrzrnzjWiNY6f+pUCP440fThsFh5gZrRAU/w==} dev: true - /execa@1.0.0: + /execa/1.0.0: resolution: {integrity: sha512-adbxcyWV46qiHyvSp50TKt05tB4tK3HcmF7/nxfAdhnox83seTDbwnaqKO4sXRy7roHAIFqJP/Rw/AuEbX61LA==} engines: {node: '>=6'} dependencies: @@ -14866,7 +12672,7 @@ packages: strip-eof: 1.0.0 dev: true - /execa@4.1.0: + /execa/4.1.0: resolution: {integrity: sha512-j5W0//W7f8UxAn8hXVnwG8tLwdiUy4FJLcSupCg6maBYZDpyBvTApK7KyuI4bKj8KOh1r2YH+6ucuYtJv1bTZA==} engines: {node: '>=10'} dependencies: @@ -14881,7 +12687,7 @@ packages: strip-final-newline: 2.0.0 dev: true - /execa@5.1.1: + /execa/5.1.1: resolution: {integrity: sha512-8uSpZZocAZRBAPIEINJj3Lo9HyGitllczc27Eh5YYojjMFMn8yHMDMaUHE2Jqfq05D/wucwI4JGURyXt1vchyg==} engines: {node: '>=10'} dependencies: @@ -14896,7 +12702,7 @@ packages: strip-final-newline: 2.0.0 dev: true - /execa@6.1.0: + /execa/6.1.0: resolution: {integrity: sha512-QVWlX2e50heYJcCPG0iWtf8r0xjEYfz/OYLGDYH+IyjWezzPNxz63qNFOu0l4YftGWuizFVZHHs8PrLU5p2IDA==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dependencies: @@ -14911,13 +12717,13 @@ packages: strip-final-newline: 3.0.0 dev: true - /execa@7.1.1: + /execa/7.1.1: resolution: {integrity: sha512-wH0eMf/UXckdUYnO21+HDztteVv05rq2GXksxT4fCGeHkBhw1DROXh40wcjMcRqDOWE7iPJ4n3M7e2+YFP+76Q==} engines: {node: ^14.18.0 || ^16.14.0 || >=18.0.0} dependencies: cross-spawn: 7.0.3 get-stream: 6.0.1 - human-signals: 4.3.0 + human-signals: 4.3.1 is-stream: 3.0.0 merge-stream: 2.0.0 npm-run-path: 5.1.0 @@ -14926,19 +12732,14 @@ packages: strip-final-newline: 3.0.0 dev: true - /executable@4.1.1: + /executable/4.1.1: resolution: {integrity: sha512-8iA79xD3uAch729dUG8xaaBBFGaEa0wdD2VkYLFHwlqosEj/jT66AzcreRDSgV7ehnNLBW2WR5jIXwGKjVdTLg==} engines: {node: '>=4'} dependencies: pify: 2.3.0 dev: true - /exit@0.1.2: - resolution: {integrity: sha512-Zk/eNKV2zbjpKzrsQ+n1G6poVbErQxJ0LBOJXaKZ1EViLzH+hrLu9cdXI4zw9dBQJslwBEpbQ2P1oS7nDxs6jQ==} - engines: {node: '>= 0.8.0'} - dev: true - - /expand-brackets@2.1.4: + /expand-brackets/2.1.4: resolution: {integrity: sha512-w/ozOKR9Obk3qoWeY/WDi6MFta9AoMR+zud60mdnbniMcBxRuFJyDt2LdX/14A1UABeqk+Uk+LDfUpvoGKppZA==} engines: {node: '>=0.10.0'} dependencies: @@ -14953,46 +12754,37 @@ packages: - supports-color dev: true - /expand-template@2.0.3: + /expand-template/2.0.3: resolution: {integrity: sha512-XYfuKMvj4O35f/pOXLObndIRvyQ+/+6AhODh+OKWj9S9498pHHn/IMszH+gt0fBCRWMNfk1ZSp5x3AifmnI2vg==} engines: {node: '>=6'} dev: true - /expect-type@0.16.0: + /expect-type/0.16.0: resolution: {integrity: sha512-wCpFeVBiAPGiYkQZzaqvGuuBnNCHbtnowMOBpBGY8a27XbG8VAit3lklWph1r8VmgsH61mOZqI3NuGm8bZnUlw==} engines: {node: '>=12.0.0'} dev: true - /expect@27.5.1: - resolution: {integrity: sha512-E1q5hSUG2AmYQwQJ041nvgpkODHQvB+RKlB4IYdru6uJsyFTRyZAP463M+1lINorwbqAmUggi6+WwkD8lCS/Dw==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - '@jest/types': 27.5.1 - jest-get-type: 27.5.1 - jest-matcher-utils: 27.5.1 - jest-message-util: 27.5.1 - dev: true - - /expect@29.0.1: - resolution: {integrity: sha512-yQgemsjLU+1S8t2A7pXT3Sn/v5/37LY8J+tocWtKEA0iEYYc6gfKbbJJX2fxHZmd7K9WpdbQqXUpmYkq1aewYg==} + /expect/29.6.1: + resolution: {integrity: sha512-XEdDLonERCU1n9uR56/Stx9OqojaLAQtZf9PrCHH9Hl8YXiEIka3H4NXJ3NOIBmQJTg7+j7buh34PMHfJujc8g==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: - '@jest/expect-utils': 29.0.1 - jest-get-type: 29.0.0 - jest-matcher-utils: 29.0.1 - jest-message-util: 29.0.1 - jest-util: 29.0.1 + '@jest/expect-utils': 29.6.1 + '@types/node': 20.4.1 + jest-get-type: 29.4.3 + jest-matcher-utils: 29.6.1 + jest-message-util: 29.6.1 + jest-util: 29.6.1 dev: true - /express@4.18.1: - resolution: {integrity: sha512-zZBcOX9TfehHQhtupq57OF8lFZ3UZi08Y97dwFCkD8p9d/d2Y3M+ykKcwaMDEL+4qyUolgBDX6AblpR3fL212Q==} + /express/4.18.2: + resolution: {integrity: sha512-5/PsL6iGPdfQ/lKM1UuielYgv3BUoJfz1aUwU9vHZ+J7gyvwdQXFEBIEIaxeGf0GIcreATNyBExtalisDbuMqQ==} engines: {node: '>= 0.10.0'} dependencies: accepts: 1.3.8 array-flatten: 1.1.1 - body-parser: 1.20.0 + body-parser: 1.20.1 content-disposition: 0.5.4 - content-type: 1.0.4 + content-type: 1.0.5 cookie: 0.5.0 cookie-signature: 1.0.6 debug: 2.6.9 @@ -15009,7 +12801,7 @@ packages: parseurl: 1.3.3 path-to-regexp: 0.1.7 proxy-addr: 2.0.7 - qs: 6.10.3 + qs: 6.11.0 range-parser: 1.2.1 safe-buffer: 5.2.1 send: 0.18.0 @@ -15023,14 +12815,14 @@ packages: - supports-color dev: true - /extend-shallow@2.0.1: + /extend-shallow/2.0.1: resolution: {integrity: sha512-zCnTtlxNoAiDc3gqY2aYAWFx7XWWiasuF2K8Me5WbN8otHKTUKBwjPtNpRs/rbUZm7KxWAaNj7P1a/p52GbVug==} engines: {node: '>=0.10.0'} dependencies: is-extendable: 0.1.1 dev: true - /extend-shallow@3.0.2: + /extend-shallow/3.0.2: resolution: {integrity: sha512-BwY5b5Ql4+qZoefgMj2NUmx+tehVTH/Kf4k1ZEtOHNFcm2wSxMRo992l6X3TIgni2eZVTZ85xMOjF31fwZAj6Q==} engines: {node: '>=0.10.0'} dependencies: @@ -15038,11 +12830,11 @@ packages: is-extendable: 1.0.1 dev: true - /extend@3.0.2: + /extend/3.0.2: resolution: {integrity: sha512-fjquC59cD7CyW6urNXK0FBufkZcoiGG80wTuPujX590cB5Ttln20E2UB4S/WARVqhXffZl2LNgS+gQdPIIim/g==} dev: true - /external-editor@3.1.0: + /external-editor/3.1.0: resolution: {integrity: sha512-hMQ4CX1p1izmuLYyZqLMO/qGNw10wSv9QDCPfzXfyFrOaCSSoRfqE1Kf1s5an66J5JZC62NewG+mK49jOCtQew==} engines: {node: '>=4'} dependencies: @@ -15051,7 +12843,7 @@ packages: tmp: 0.0.33 dev: true - /extglob@2.0.4: + /extglob/2.0.4: resolution: {integrity: sha512-Nmb6QXkELsuBr24CJSkilo6UHHgbekK5UiZgfE6UHD3Eb27YC6oD+bhcT+tJ6cl8dmsgdQxnWlcry8ksBIBLpw==} engines: {node: '>=0.10.0'} dependencies: @@ -15067,7 +12859,7 @@ packages: - supports-color dev: true - /extract-comments@1.1.0: + /extract-comments/1.1.0: resolution: {integrity: sha512-dzbZV2AdSSVW/4E7Ti5hZdHWbA+Z80RJsJhr5uiL10oyjl/gy7/o+HI1HwK4/WSZhlq4SNKU3oUzXlM13Qx02Q==} engines: {node: '>=6'} dependencies: @@ -15075,12 +12867,26 @@ packages: parse-code-context: 1.0.0 dev: true - /extract-zip@2.0.1(supports-color@8.1.1): + /extract-zip/2.0.1: + resolution: {integrity: sha512-GDhU9ntwuKyGXdZBUgTIe+vXnWj0fppUEtMDL0+idd5Sta8TGpHssn/eusA9mrPr9qNDym6SxAYZjNvCn/9RBg==} + engines: {node: '>= 10.17.0'} + hasBin: true + dependencies: + debug: 4.3.4 + get-stream: 5.2.0 + yauzl: 2.10.0 + optionalDependencies: + '@types/yauzl': 2.10.0 + transitivePeerDependencies: + - supports-color + dev: true + + /extract-zip/2.0.1_supports-color@8.1.1: resolution: {integrity: sha512-GDhU9ntwuKyGXdZBUgTIe+vXnWj0fppUEtMDL0+idd5Sta8TGpHssn/eusA9mrPr9qNDym6SxAYZjNvCn/9RBg==} engines: {node: '>= 10.17.0'} hasBin: true dependencies: - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4_supports-color@8.1.1 get-stream: 5.2.0 yauzl: 2.10.0 optionalDependencies: @@ -15089,24 +12895,33 @@ packages: - supports-color dev: true - /extsprintf@1.3.0: + /extsprintf/1.3.0: resolution: {integrity: sha512-11Ndz7Nv+mvAC1j0ktTa7fAb0vLyGGX+rMHNBYQviQDGU0Hw7lhctJANqbPhu9nV9/izT/IntTgZ7Im/9LJs9g==} engines: {'0': node >=0.6.0} dev: true - /fast-deep-equal@2.0.1: + /fast-decode-uri-component/1.0.1: + resolution: {integrity: sha512-WKgKWg5eUxvRZGwW8FvfbaH7AXSh2cL+3j5fMGzUMCxWBJ3dV3a7Wz8y2f/uQ0e3B6WmodD3oS54jTQ9HVTIIg==} + dev: true + + /fast-deep-equal/2.0.1: resolution: {integrity: sha512-bCK/2Z4zLidyB4ReuIsvALH6w31YfAQDmXMqMx6FyfHqvBxtjC0eRumeSu4Bs3XtXwpyIywtSTrVT99BxY1f9w==} dev: true - /fast-deep-equal@3.1.3: + /fast-deep-equal/3.1.3: resolution: {integrity: sha512-f3qQ9oQy9j2AhBe/H9VC91wLmKBCCU/gDOnKNAYG5hswO7BLKj09Hc5HYNz9cGI++xlpDCIgDaitVs03ATR84Q==} dev: true - /fast-equals@2.0.4: - resolution: {integrity: sha512-caj/ZmjHljPrZtbzJ3kfH5ia/k4mTJe/qSiXAGzxZWRZgsgDV0cvNaQULqUX8t0/JVlzzEdYOwCN5DmzTxoD4w==} + /fast-equals/5.0.1: + resolution: {integrity: sha512-WF1Wi8PwwSY7/6Kx0vKXtw8RwuSGoM1bvDaJbu7MxDlR1vovZjIAKrnzyrThgAjm6JDTu0fVgWXDlMGspodfoQ==} + engines: {node: '>=6.0.0'} dev: false - /fast-glob@2.2.7: + /fast-fifo/1.3.0: + resolution: {integrity: sha512-IgfweLvEpwyA4WgiQe9Nx6VV2QkML2NkvZnk1oKnIzXgXdWxuhF7zw4DvLTPZJn6PIUneiAXPF24QmoEqHTjyw==} + dev: true + + /fast-glob/2.2.7: resolution: {integrity: sha512-g1KuQwHOZAmOZMuBtHdxDtju+T2RT8jgCC9aANsbpdiDDTSnjgfuVsIBNKbUeJI3oKMRExcfNDtJl4OhbffMsw==} engines: {node: '>=4.0.0'} dependencies: @@ -15120,7 +12935,7 @@ packages: - supports-color dev: true - /fast-glob@3.3.0: + /fast-glob/3.3.0: resolution: {integrity: sha512-ChDuvbOypPuNjO8yIDf36x7BlZX1smcUMTTcyoIjycexOxd6DFsKsg21qVBzEmr3G7fUKIRy2/psii+CIUt7FA==} engines: {node: '>=8.6.0'} dependencies: @@ -15130,100 +12945,106 @@ packages: merge2: 1.4.1 micromatch: 4.0.5 - /fast-json-parse@1.0.3: + /fast-json-parse/1.0.3: resolution: {integrity: sha512-FRWsaZRWEJ1ESVNbDWmsAlqDk96gPQezzLghafp5J4GUKjbCz3OkAHuZs5TuPEtkbVQERysLp9xv6c24fBm8Aw==} dev: true - /fast-json-stable-stringify@2.1.0: + /fast-json-stable-stringify/2.1.0: resolution: {integrity: sha512-lhd/wF+Lk98HZoTCtlVraHtfh5XYijIjalXck7saUtuanSDyLMxnHhSXEDJqHxD7msR8D0uCmqlkwjCV8xvwHw==} dev: true - /fast-json-stringify@5.2.0: - resolution: {integrity: sha512-u5jtrcAK9RINW15iuDKnsuuhqmqre4AmDMp3crRTjUMdAuHMpQUt3IfoMm5wlJm59b74PcajqOl3SjgnC5FPmw==} + /fast-json-stringify/5.7.0: + resolution: {integrity: sha512-sBVPTgnAZseLu1Qgj6lUbQ0HfjFhZWXAmpZ5AaSGkyLh5gAXBga/uPJjQPHpDFjC9adWIpdOcCLSDTgrZ7snoQ==} dependencies: - '@fastify/deepmerge': 1.1.0 - ajv: 8.11.0 - ajv-formats: 2.1.1(ajv@8.11.0) + '@fastify/deepmerge': 1.3.0 + ajv: 8.12.0 + ajv-formats: 2.1.1 fast-deep-equal: 3.1.3 - fast-uri: 2.1.0 + fast-uri: 2.2.0 rfdc: 1.3.0 dev: true - /fast-levenshtein@2.0.6: + /fast-levenshtein/2.0.6: resolution: {integrity: sha512-DCXu6Ifhqcks7TZKY3Hxp3y6qphY5SJZmrWMDrKcERSOXWQdMhU9Ig/PYrzyw/ul9jOIyh0N4M0tbC5hodg8dw==} dev: true - /fast-redact@3.1.2: - resolution: {integrity: sha512-+0em+Iya9fKGfEQGcd62Yv6onjBmmhV1uh86XVfOU8VwAe6kaFdQCWI9s0/Nnugx5Vd9tdbZ7e6gE2tR9dzXdw==} + /fast-querystring/1.1.2: + resolution: {integrity: sha512-g6KuKWmFXc0fID8WWH0jit4g0AGBoJhCkJMb1RmbsSEUNvQ+ZC8D6CUZ+GtF8nMzSPXnhiePyyqqipzNNEnHjg==} + dependencies: + fast-decode-uri-component: 1.0.1 + dev: true + + /fast-redact/3.2.0: + resolution: {integrity: sha512-zaTadChr+NekyzallAMXATXLOR8MNx3zqpZ0MUF2aGf4EathnG0f32VLODNlY8IuGY3HoRO2L6/6fSzNsLaHIw==} engines: {node: '>=6'} dev: true - /fast-safe-stringify@2.1.1: + /fast-safe-stringify/2.1.1: resolution: {integrity: sha512-W+KJc2dmILlPplD/H4K9l9LcAHAfPtP6BY84uVLXQ6Evcz9Lcg33Y2z1IVblT6xdY54PXYVHEv+0Wpq8Io6zkA==} dev: true - /fast-uri@2.1.0: - resolution: {integrity: sha512-qKRta6N7BWEFVlyonVY/V+BMLgFqktCUV0QjT259ekAIlbVrMaFnFLxJ4s/JPl4tou56S1BzPufI60bLe29fHA==} + /fast-uri/2.2.0: + resolution: {integrity: sha512-cIusKBIt/R/oI6z/1nyfe2FvGKVTohVRfvkOhvx0nCEW+xf5NoCXjAHcWp93uOUBchzYcsvPlrapAdX1uW+YGg==} dev: true - /fastify@4.5.3: + /fastify/4.5.3: resolution: {integrity: sha512-Q8Zvkmg7GnioMCDX1jT2Q7iRqjywlnDZ1735D2Ipf7ashCM/3/bqPKv2Jo1ZF2iDExct2eP1C/tdhcj0GG/OuQ==} dependencies: - '@fastify/ajv-compiler': 3.2.0 - '@fastify/error': 3.0.0 - '@fastify/fast-json-stringify-compiler': 4.1.0 + '@fastify/ajv-compiler': 3.5.0 + '@fastify/error': 3.3.0 + '@fastify/fast-json-stringify-compiler': 4.3.0 abstract-logging: 2.0.1 - avvio: 8.2.0 - find-my-way: 7.0.1 - light-my-request: 5.5.1 - pino: 8.5.0 - process-warning: 2.0.0 + avvio: 8.2.1 + find-my-way: 7.6.2 + light-my-request: 5.10.0 + pino: 8.14.1 + process-warning: 2.2.0 proxy-addr: 2.0.7 rfdc: 1.3.0 - secure-json-parse: 2.5.0 - semver: 7.3.7 + secure-json-parse: 2.7.0 + semver: 7.5.4 tiny-lru: 8.0.2 transitivePeerDependencies: - supports-color dev: true - /fastq@1.13.0: - resolution: {integrity: sha512-YpkpUnK8od0o1hmeSc7UUs/eB/vIPWJYjKck2QKIzAf71Vm1AAQ3EbuZB3g2JIy+pg+ERD0vqI79KyZiB2e2Nw==} + /fastq/1.15.0: + resolution: {integrity: sha512-wBrocU2LCXXa+lWBt8RoIRD89Fi8OdABODa/kEnyeyjS5aZO5/GNvI5sEINADqP/h8M29UHTHUb53sUu5Ihqdw==} dependencies: reusify: 1.0.4 - /fb-watchman@2.0.1: - resolution: {integrity: sha512-DkPJKQeY6kKwmuMretBhr7G6Vodr7bFwDYTXIkfG1gjvNpaxBTQV3PbXg6bR1c1UP4jPOX0jHUbbHANL9vRjVg==} + /fb-watchman/2.0.2: + resolution: {integrity: sha512-p5161BqbuCaSnB8jIbzQHOlpgsPmK5rJVDfDKO91Axs5NC1uu3HRQm6wt9cd9/+GtQQIO53JdGXXoyDpTAsgYA==} dependencies: bser: 2.1.1 dev: true - /fd-slicer@1.1.0: + /fd-slicer/1.1.0: resolution: {integrity: sha512-cE1qsB/VwyQozZ+q1dGxR8LBYNZeofhEdUNGSMbQD3Gw2lAzX9Zb3uIU6Ebc/Fmyjo9AWWfnn0AUCHqtevs/8g==} dependencies: pend: 1.2.0 dev: true - /fetch-retry@5.0.3: - resolution: {integrity: sha512-uJQyMrX5IJZkhoEUBQ3EjxkeiZkppBd5jS/fMTJmfZxLSiaQjv2zD0kTvuvkSH89uFvgSlB6ueGpjD3HWN7Bxw==} + /fetch-retry/5.0.6: + resolution: {integrity: sha512-3yurQZ2hD9VISAhJJP9bpYFNQrHHBXE2JxxjY5aLEcDi46RmAzJE2OC9FAde0yis5ElW0jTTzs0zfg/Cca4XqQ==} dev: true - /fflate@0.8.0: + /fflate/0.8.0: resolution: {integrity: sha512-FAdS4qMuFjsJj6XHbBaZeXOgaypXp8iw/Tpyuq/w3XA41jjLHT8NPA+n7czH/DDhdncq0nAyDZmPeWXh2qmdIg==} dev: false - /figgy-pudding@3.5.2: + /figgy-pudding/3.5.2: resolution: {integrity: sha512-0btnI/H8f2pavGMN8w40mlSKOfTK2SVJmBfBeVIj3kNw0swwgzyRq0d5TJVOwodFmtvpPeWPN/MCcfuWF0Ezbw==} dev: true - /figures@3.2.0: + /figures/3.2.0: resolution: {integrity: sha512-yaduQFRKLXYOGgEn6AZau90j3ggSOyiqXU0F9JZfeXYhNa+Jk4X+s45A2zg5jns87GAFa34BBm2kXw4XpNcbdg==} engines: {node: '>=8'} dependencies: escape-string-regexp: 1.0.5 dev: true - /figures@5.0.0: + /figures/5.0.0: resolution: {integrity: sha512-ej8ksPF4x6e5wvK9yevct0UCXh8TTFlWGVLlgjZuoBH1HwjIfKE/IdL5mq89sFA7zELi1VhKpmtDnrs7zWyeyg==} engines: {node: '>=14'} dependencies: @@ -15231,44 +13052,50 @@ packages: is-unicode-supported: 1.3.0 dev: true - /file-entry-cache@6.0.1: + /file-entry-cache/6.0.1: resolution: {integrity: sha512-7Gps/XWymbLk2QLYK4NzpMOrYjMhdIxXuIvy2QBsLE6ljuodKvdkWs/cpyJJ3CVIVpH0Oi1Hvg1ovbMzLdFBBg==} engines: {node: ^10.12.0 || >=12.0.0} dependencies: flat-cache: 3.0.4 dev: true - /file-loader@6.2.0(webpack@4.46.0): + /file-loader/6.2.0_webpack@4.46.0: resolution: {integrity: sha512-qo3glqyTa61Ytg4u73GultjHGjdRyig3tG6lPtyX/jOEJvHif9uB0/OCI2Kif6ctF3caQTW2G5gym21oAsI4pw==} engines: {node: '>= 10.13.0'} peerDependencies: webpack: ^4.0.0 || ^5.0.0 dependencies: - loader-utils: 2.0.2 - schema-utils: 3.1.1 + loader-utils: 2.0.4 + schema-utils: 3.3.0 webpack: 4.46.0 dev: true - /file-system-cache@1.1.0: + /file-system-cache/1.1.0: resolution: {integrity: sha512-IzF5MBq+5CR0jXx5RxPe4BICl/oEhBSXKaL9fLhAXrIfIUS77Hr4vzrYyqYMHN6uTt+BOqi3fDCTjjEBCjERKw==} dependencies: fs-extra: 10.1.0 ramda: 0.28.0 dev: true - /file-uri-to-path@1.0.0: + /file-system-cache/2.3.0: + resolution: {integrity: sha512-l4DMNdsIPsVnKrgEXbJwDJsA5mB8rGwHYERMgqQx/xAUtChPJMre1bXBzDEqqVbWv9AIbFezXMxeEkZDSrXUOQ==} + dependencies: + fs-extra: 11.1.1 + ramda: 0.29.0 + dev: true + + /file-uri-to-path/1.0.0: resolution: {integrity: sha512-0Zt+s3L7Vf1biwWZ29aARiVYLx7iMGnEUl9x33fbB/j3jR81u/O2LbqK+Bm1CDSNDKVtJ/YjwY7TUd5SkeLQLw==} - requiresBuild: true dev: true optional: true - /filelist@1.0.4: + /filelist/1.0.4: resolution: {integrity: sha512-w1cEuf3S+DrLCQL7ET6kz+gmlJdbq9J7yXCSjK/OZCPA+qEN1WyF4ZAf0YYJa4/shHJra2t/d/r8SV4Ji+x+8Q==} dependencies: - minimatch: 5.1.1 + minimatch: 5.1.6 dev: true - /fill-range@4.0.0: + /fill-range/4.0.0: resolution: {integrity: sha512-VcpLTWqWDiTerugjj8e3+esbg+skS3M9e54UuR3iCeIDMXCLTsAH8hTSzDQU/X6/6t3eYkOKoZSef2PlU6U1XQ==} engines: {node: '>=0.10.0'} dependencies: @@ -15278,13 +13105,13 @@ packages: to-regex-range: 2.1.1 dev: true - /fill-range@7.0.1: + /fill-range/7.0.1: resolution: {integrity: sha512-qOo9F+dMUmC2Lcb4BbVvnKJxTPjCm+RRpe4gDuGrzkL7mEVl/djYSu2OdQ2Pa302N4oqkSg9ir6jaLWJ2USVpQ==} engines: {node: '>=8'} dependencies: to-regex-range: 5.0.1 - /finalhandler@1.2.0: + /finalhandler/1.2.0: resolution: {integrity: sha512-5uXcUVftlQMFnWC9qu/svkWv3GTd2PfUhK/3PLkYNAe7FbqJMt3515HaxE6eRL74GdsriiwujiawdaB1BpEISg==} engines: {node: '>= 0.8'} dependencies: @@ -15299,7 +13126,7 @@ packages: - supports-color dev: true - /find-cache-dir@2.1.0: + /find-cache-dir/2.1.0: resolution: {integrity: sha512-Tq6PixE0w/VMFfCgbONnkiQIVol/JJL7nRMi20fqzA4NRs9AfeqMGeRdPi3wIhYkxjeBaWh2rxwapn5Tu3IqOQ==} engines: {node: '>=6'} dependencies: @@ -15308,7 +13135,7 @@ packages: pkg-dir: 3.0.0 dev: true - /find-cache-dir@3.3.2: + /find-cache-dir/3.3.2: resolution: {integrity: sha512-wXZV5emFEjrridIgED11OoUKLxiYjAcqot/NJdAkOhlJ+vGzwhOAfcG5OX1jP+S0PcjEn8bdMJv+g2jwQ3Onig==} engines: {node: '>=8'} dependencies: @@ -15317,19 +13144,20 @@ packages: pkg-dir: 4.2.0 dev: true - /find-my-way@7.0.1: - resolution: {integrity: sha512-w05SaOPg54KqBof/RDA+75n1R48V7ZZNPL3nR17jJJs5dgZpR3ivfrMWOyx7BVFQgCLhYRG05hfgFCohYvSUXA==} + /find-my-way/7.6.2: + resolution: {integrity: sha512-0OjHn1b1nCX3eVbm9ByeEHiscPYiHLfhei1wOUU9qffQkk98wE0Lo8VrVYfSGMgnSnDh86DxedduAnBf4nwUEw==} engines: {node: '>=14'} dependencies: fast-deep-equal: 3.1.3 + fast-querystring: 1.1.2 safe-regex2: 2.0.0 dev: true - /find-root@1.1.0: + /find-root/1.1.0: resolution: {integrity: sha512-NKfW6bec6GfKc0SGx1e07QZY9PE99u0Bft/0rzSD5k3sO/vwkVUpDUKVm5Gpp5Ue3YfShPFTX2070tDs5kB9Ng==} dev: false - /find-up@1.1.2: + /find-up/1.1.2: resolution: {integrity: sha512-jvElSjyuo4EMQGoTwo1uJU5pQMwTW5lS1x05zzfJuTIyLR3zwO27LYrxNg+dlvKpGOuGy/MzBdXh80g0ve5+HA==} engines: {node: '>=0.10.0'} dependencies: @@ -15338,14 +13166,14 @@ packages: dev: true optional: true - /find-up@3.0.0: + /find-up/3.0.0: resolution: {integrity: sha512-1yD6RmLI1XBfxugvORwlck6f75tYL+iR0jqwsOrOxMZyGYqUuDhJ0l4AXdO1iX/FTs9cBAMEk1gWSEx1kSbylg==} engines: {node: '>=6'} dependencies: locate-path: 3.0.0 dev: true - /find-up@4.1.0: + /find-up/4.1.0: resolution: {integrity: sha512-PpOwAdQ/YlXQ2vj8a3h8IipDuYRi3wceVQQGYWxNINccq40Anw7BlsEXCMbt1Zt+OLA6Fq9suIpIWD0OsnISlw==} engines: {node: '>=8'} dependencies: @@ -15353,7 +13181,7 @@ packages: path-exists: 4.0.0 dev: true - /find-up@5.0.0: + /find-up/5.0.0: resolution: {integrity: sha512-78/PXT1wlLLDgTzDs7sjq9hzz0vXD+zn+7wypEe4fXQxCmdmqfGsEPQxmiCSQI3ajFV91bVSsvNtrJRiW6nGng==} engines: {node: '>=10'} dependencies: @@ -15361,15 +13189,15 @@ packages: path-exists: 4.0.0 dev: true - /find-up@6.3.0: + /find-up/6.3.0: resolution: {integrity: sha512-v2ZsoEuVHYy8ZIlYqwPe/39Cy+cFDzp4dXPaxNvkEuouymu+2Jbz0PxpKarJHYJTmv2HWT3O382qY8l4jMWthw==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dependencies: - locate-path: 7.1.1 + locate-path: 7.2.0 path-exists: 5.0.0 dev: true - /flat-cache@3.0.4: + /flat-cache/3.0.4: resolution: {integrity: sha512-dm9s5Pw7Jc0GvMYbshN6zchCA9RgQlzzEZX3vylR9IqFfS8XciblUXOKfW6SiuJ0e13eDYZoZV5wdrev7P3Nwg==} engines: {node: ^10.12.0 || >=12.0.0} dependencies: @@ -15377,39 +13205,39 @@ packages: rimraf: 3.0.2 dev: true - /flat@5.0.2: + /flat/5.0.2: resolution: {integrity: sha512-b6suED+5/3rTpUBdG1gupIl8MPFCAMA0QXwmljLhvCUKcUvdE4gWky9zpuGCcXHOsz4J9wPGNWq6OKpmIzz3hQ==} hasBin: true dev: true - /flatted@3.2.7: + /flatted/3.2.7: resolution: {integrity: sha512-5nqDSxl8nn5BSNxyR3n4I6eDmbolI6WT+QqR547RwxQapgjQBmtktdP+HTBb/a/zLsbzERTONyUB5pefh5TtjQ==} - /floating-vue@2.0.0-y.0(vue@3.3.4): + /floating-vue/2.0.0-y.0_vue@3.3.4: resolution: {integrity: sha512-UpJquQIlP0Z5978RYwGN3qsE6jhxxCt7ltzE1mV2m9GwsZ6y7IaIOAszWqALC+OqWhdPad/0GYxoQYGLC0y+Ow==} peerDependencies: vue: ^3.2.0 dependencies: '@floating-ui/dom': 0.1.10 vue: 3.3.4 - vue-resize: 2.0.0-alpha.1(vue@3.3.4) + vue-resize: 2.0.0-alpha.1_vue@3.3.4 dev: true - /flush-write-stream@1.1.1: + /flush-write-stream/1.1.1: resolution: {integrity: sha512-3Z4XhFZ3992uIq0XOqb9AreonueSYphE6oYbpt5+3u06JWklbsPkNv3ZKkP9Bz/r+1MWCaMoSQ28P85+1Yc77w==} dependencies: inherits: 2.0.4 - readable-stream: 2.3.7 + readable-stream: 2.3.8 dev: true - /focus-trap@7.4.3: - resolution: {integrity: sha512-BgSSbK4GPnS2VbtZ50VtOv1Sti6DIkj3+LkVjiWMNjLeAp1SH1UlLx3ULu/DCu4vq5R4/uvTm+zrvsMsuYmGLg==} + /focus-trap/7.5.2: + resolution: {integrity: sha512-p6vGNNWLDGwJCiEjkSK6oERj/hEyI9ITsSwIUICBoKLlWiTWXJRfQibCwcoi50rTZdbi87qDtUlMCmQwsGSgPw==} dependencies: - tabbable: 6.1.2 + tabbable: 6.2.0 dev: true - /follow-redirects@1.15.1: - resolution: {integrity: sha512-yLAMQs+k0b2m7cVxpS1VKJVvoz7SS9Td1zss3XRwXj+ZDH00RJgnuLx7E44wx02kQLrdM3aOOy+FpzS7+8OizA==} + /follow-redirects/1.15.2: + resolution: {integrity: sha512-VQLG33o04KaQ8uYi2tVNbdrWp1QWxNNea+nmIB4EVM28v0hmP17z7aG1+wAkNzVq4KeXTq3221ye5qTJP91JwA==} engines: {node: '>=4.0'} peerDependencies: debug: '*' @@ -15417,18 +13245,18 @@ packages: debug: optional: true - /for-each@0.3.3: + /for-each/0.3.3: resolution: {integrity: sha512-jqYfLp7mo9vIyQf8ykW2v7A+2N4QjeCeI5+Dz9XraiO1ign81wjiH7Fb9vSOWvQfNtmSa4H2RoQTrrXivdUZmw==} dependencies: is-callable: 1.2.7 dev: true - /for-in@1.0.2: + /for-in/1.0.2: resolution: {integrity: sha512-7EwmXrOjyL+ChxMhmG5lnW9MPt1aIeZEwKhQzoBUdTV0N3zuwWDZYVJatDvZ2OyzPUvdIAZDsCetk3coyMfcnQ==} engines: {node: '>=0.10.0'} dev: true - /foreground-child@2.0.0: + /foreground-child/2.0.0: resolution: {integrity: sha512-dCIq9FpEcyQyXKCkyzmlPTFNgrCzPudOe+mhvJU5zAtlBnGVy2yKxtfsxK2tQBThwq225jcvBjpw1Gr40uzZCA==} engines: {node: '>=8.0.0'} dependencies: @@ -15436,19 +13264,19 @@ packages: signal-exit: 3.0.7 dev: true - /foreground-child@3.1.1: + /foreground-child/3.1.1: resolution: {integrity: sha512-TMKDUnIte6bfb5nWv7V/caI169OHgvwjb7V4WkeUvbQQdjr5rWKqHFiKWb/fcOwB+CzBT+qbWjvj+DVwRskpIg==} engines: {node: '>=14'} dependencies: cross-spawn: 7.0.3 - signal-exit: 4.0.1 + signal-exit: 4.0.2 dev: true - /forever-agent@0.6.1: + /forever-agent/0.6.1: resolution: {integrity: sha512-j0KLYPhm6zeac4lz3oJ3o65qvgQCcPubiyotZrXqEaG4hNagNYO8qdlUrX5vwqv9ohqeT/Z3j6+yW067yWWdUw==} dev: true - /fork-ts-checker-webpack-plugin@4.1.6(eslint@8.4.1)(typescript@4.8.4)(webpack@4.46.0): + /fork-ts-checker-webpack-plugin/4.1.6_evijigonbo4skk2vlqtwtdqibu: resolution: {integrity: sha512-DUxuQaKoqfNne8iikd14SAkh5uw4+8vNifp6gmA73yYNS6ywLIWSLD/n/mBzHQRpW3J7rbATEakmiA8JvkTyZw==} engines: {node: '>=6.11.5', yarn: '>=1.0.0'} peerDependencies: @@ -15464,20 +13292,19 @@ packages: dependencies: '@babel/code-frame': 7.22.5 chalk: 2.4.2 - eslint: 8.4.1 micromatch: 3.1.10 minimatch: 3.1.2 - semver: 5.7.1 + semver: 5.7.2 tapable: 1.1.3 - typescript: 4.8.4 + typescript: 4.9.5 webpack: 4.46.0 worker-rpc: 0.1.1 transitivePeerDependencies: - supports-color dev: true - /fork-ts-checker-webpack-plugin@6.5.2(eslint@8.4.1)(typescript@4.8.4)(webpack@4.46.0): - resolution: {integrity: sha512-m5cUmF30xkZ7h4tWUgTAcEaKmUW7tfyUyTqNNOz7OxWJ0v1VWKTcOvH8FWHUwSjlW/356Ijc9vi3XfcPstpQKA==} + /fork-ts-checker-webpack-plugin/6.5.3_evijigonbo4skk2vlqtwtdqibu: + resolution: {integrity: sha512-SbH/l9ikmMWycd5puHJKTkZJKddF4iRLyW3DeZ08HTI7NGyLS38MXd/KGgeWumQO7YNQbW2u/NtPT2YowbPaGQ==} engines: {node: '>=10', yarn: '>=1.0.0'} peerDependencies: eslint: '>= 6' @@ -15491,29 +13318,28 @@ packages: optional: true dependencies: '@babel/code-frame': 7.22.5 - '@types/json-schema': 7.0.11 + '@types/json-schema': 7.0.12 chalk: 4.1.2 chokidar: 3.5.3 cosmiconfig: 6.0.0 deepmerge: 4.3.1 - eslint: 8.4.1 fs-extra: 9.1.0 glob: 7.2.3 - memfs: 3.4.7 + memfs: 3.5.3 minimatch: 3.1.2 schema-utils: 2.7.0 semver: 7.5.4 tapable: 1.1.3 - typescript: 4.8.4 + typescript: 4.9.5 webpack: 4.46.0 dev: true - /form-data-encoder@2.1.4: + /form-data-encoder/2.1.4: resolution: {integrity: sha512-yDYSgNMraqvnxiEXO4hi88+YZxaHC6QKzb5N84iRCTDeRO7ZALpir/lVmf/uXUhnwUr2O4HU8s/n6x+yNjQkHw==} engines: {node: '>= 14.17'} dev: true - /form-data@2.3.3: + /form-data/2.3.3: resolution: {integrity: sha512-1lLKB2Mu3aGP1Q/2eCOx0fNbRMe7XdwktwOruhfqqd0rIJWwN4Dh+E3hrPSlDCXnSR7UtZ1N38rVXm+6+MEhJQ==} engines: {node: '>= 0.12'} dependencies: @@ -15522,7 +13348,7 @@ packages: mime-types: 2.1.35 dev: true - /form-data@3.0.1: + /form-data/3.0.1: resolution: {integrity: sha512-RHkBKtLWUVwd7SqRIvCZMEvAMoGUp0XU+seQiZejj0COz3RI3hWP4sCv3gZWWLjJTd7rGwcsF5eKZGii0r/hbg==} engines: {node: '>= 6'} dependencies: @@ -15531,7 +13357,7 @@ packages: mime-types: 2.1.35 dev: true - /form-data@4.0.0: + /form-data/4.0.0: resolution: {integrity: sha512-ETEklSGi5t0QMZuiXoA/Q6vcnxcLQP5vdugSpuAyi6SVGi2clPPp+xgEhuMaHC+zGgn31Kd235W35f7Hykkaww==} engines: {node: '>= 6'} dependencies: @@ -15540,95 +13366,95 @@ packages: mime-types: 2.1.35 dev: true - /formidable@2.0.1: - resolution: {integrity: sha512-rjTMNbp2BpfQShhFbR3Ruk3qk2y9jKpvMW78nJgx8QKtxjDVrwbZG+wvDOmVbifHyOUOQJXxqEy6r0faRrPzTQ==} + /formidable/2.1.2: + resolution: {integrity: sha512-CM3GuJ57US06mlpQ47YcunuUZ9jpm8Vx+P2CGt2j7HpgkKZO/DJYQ0Bobim8G6PFQmK5lOqOOdUXboU+h73A4g==} dependencies: - dezalgo: 1.0.3 + dezalgo: 1.0.4 hexoid: 1.0.0 once: 1.4.0 - qs: 6.9.3 + qs: 6.11.2 dev: true - /forwarded@0.2.0: + /forwarded/0.2.0: resolution: {integrity: sha512-buRG0fpBtRHSTCOASe6hD258tEubFoRLb4ZNA6NxMVHNw2gOcwHo9wyablzMzOA5z9xA9L1KNjk/Nt6MT9aYow==} engines: {node: '>= 0.6'} dev: true - /fragment-cache@0.2.1: + /fragment-cache/0.2.1: resolution: {integrity: sha512-GMBAbW9antB8iZRHLoGw0b3HANt57diZYFO/HL1JGIC1MjKrdmhxvrJbupnVvpys0zsz7yBApXdQyfepKly2kA==} engines: {node: '>=0.10.0'} dependencies: map-cache: 0.2.2 dev: true - /fresh@0.5.2: + /fresh/0.5.2: resolution: {integrity: sha512-zJ2mQYM18rEFOudeV4GShTGIQ7RbzA7ozbU9I/XBpm7kqgMywgmylMwXHxZJmkVoYkna9d2pVXVXPdYTP9ej8Q==} engines: {node: '>= 0.6'} dev: true - /from2@2.3.0: + /from2/2.3.0: resolution: {integrity: sha512-OMcX/4IC/uqEPVgGeyfN22LJk6AZrMkRZHxcHBMBvHScDGgwTm2GT2Wkgtocyd3JfZffjj2kYUDXXII0Fk9W0g==} dependencies: inherits: 2.0.4 - readable-stream: 2.3.7 + readable-stream: 2.3.8 dev: true - /fs-constants@1.0.0: + /fs-constants/1.0.0: resolution: {integrity: sha512-y6OAwoSIf7FyjMIv94u+b5rdheZEjzR63GTyZJm5qh4Bi+2YgwLCcI/fPFZkL5PSixOt6ZNKm+w+Hfp/Bciwow==} dev: true - /fs-extra@10.1.0: + /fs-extra/10.1.0: resolution: {integrity: sha512-oRXApq54ETRj4eMiFzGnHWGy+zo5raudjuxN0b8H7s/RU2oW0Wvsx9O0ACRN/kRq9E8Vu/ReskGB5o3ji+FzHQ==} engines: {node: '>=12'} dependencies: - graceful-fs: 4.2.10 + graceful-fs: 4.2.11 jsonfile: 6.1.0 universalify: 2.0.0 dev: true - /fs-extra@11.1.1: + /fs-extra/11.1.1: resolution: {integrity: sha512-MGIE4HOvQCeUCzmlHs0vXpih4ysz4wg9qiSAu6cd42lVwPbTM1TjV7RusoyQqMmk/95gdQZX72u+YW+c3eEpFQ==} engines: {node: '>=14.14'} dependencies: - graceful-fs: 4.2.10 + graceful-fs: 4.2.11 jsonfile: 6.1.0 universalify: 2.0.0 dev: true - /fs-extra@9.1.0: + /fs-extra/9.1.0: resolution: {integrity: sha512-hcg3ZmepS30/7BSFqRvoo3DOMQu7IjqxO5nCDt+zM9XWjb33Wg7ziNT+Qvqbuc3+gWpzO02JubVyk2G4Zvo1OQ==} engines: {node: '>=10'} dependencies: at-least-node: 1.0.0 - graceful-fs: 4.2.10 + graceful-fs: 4.2.11 jsonfile: 6.1.0 universalify: 2.0.0 dev: true - /fs-minipass@2.1.0: + /fs-minipass/2.1.0: resolution: {integrity: sha512-V/JgOLFCS+R6Vcq0slCuaeWEdNC3ouDlJMNIsacH2VtALiu9mV4LPrHc5cDl8k5aw6J8jwgWWpiTo5RYhmIzvg==} engines: {node: '>= 8'} dependencies: - minipass: 3.3.4 + minipass: 3.3.6 dev: true - /fs-monkey@1.0.3: - resolution: {integrity: sha512-cybjIfiiE+pTWicSCLFHSrXZ6EilF30oh91FDP9S2B051prEa7QWfrVTQm10/dDpswBDXZugPa1Ogu8Yh+HV0Q==} + /fs-monkey/1.0.4: + resolution: {integrity: sha512-INM/fWAxMICjttnD0DX1rBvinKskj5G1w+oy/pnm9u/tSlnBrzFonJMcalKJ30P8RRsPzKcCG7Q8l0jx5Fh9YQ==} dev: true - /fs-write-stream-atomic@1.0.10: + /fs-write-stream-atomic/1.0.10: resolution: {integrity: sha512-gehEzmPn2nAwr39eay+x3X34Ra+M2QlVUTLhkXPjWdeO8RF9kszk116avgBJM3ZyNHgHXBNx+VmPaFC36k0PzA==} dependencies: - graceful-fs: 4.2.10 + graceful-fs: 4.2.11 iferr: 0.1.5 imurmurhash: 0.1.4 - readable-stream: 2.3.7 + readable-stream: 2.3.8 dev: true - /fs.realpath@1.0.0: + /fs.realpath/1.0.0: resolution: {integrity: sha512-OO0pH2lK6a0hZnAdau5ItzHPI6pUlvI7jMVnxUQRtw4owF2wk8lOSabtGDCTP4Ggrg2MbGnWO9X8K1t4+fGMDw==} - /fsevents@1.2.13: + /fsevents/1.2.13: resolution: {integrity: sha512-oWb1Z6mkHIskLzEJ/XWX0srkpkTQ7vaopMQkyaEIoq0fmtFVxOthb8cCxeT+p3ynTdkk/RZwbgG4brR5BeWECw==} engines: {node: '>= 4.0'} os: [darwin] @@ -15636,39 +13462,39 @@ packages: requiresBuild: true dependencies: bindings: 1.5.0 - nan: 2.16.0 + nan: 2.17.0 dev: true optional: true - /fsevents@2.3.2: + /fsevents/2.3.2: resolution: {integrity: sha512-xiqMQR4xAeHTuB9uWm+fFRcIOgKBMiOBP+eXiyT7jsgVCq1bkVygt00oASowB7EdtpOHaaPgKt812P9ab+DDKA==} engines: {node: ^8.16.0 || ^10.6.0 || >=11.0.0} os: [darwin] requiresBuild: true optional: true - /function-bind@1.1.1: + /function-bind/1.1.1: resolution: {integrity: sha512-yIovAzMX49sF8Yl58fSCWJ5svSLuaibPxXQJFLmBObTuCr0Mf1KiPopGM9NiFjiYBCbfaa2Fh6breQ6ANVTI0A==} - /function.prototype.name@1.1.5: + /function.prototype.name/1.1.5: resolution: {integrity: sha512-uN7m/BzVKQnCUF/iW8jYea67v++2u7m5UgENbHRtdDVclOUP+FMPlCNdmk0h/ysGyo2tavMJEDqJAkJdRa1vMA==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.20.4 + es-abstract: 1.21.2 functions-have-names: 1.2.3 dev: true - /functional-red-black-tree@1.0.1: + /functional-red-black-tree/1.0.1: resolution: {integrity: sha512-dsKNQNdj6xA3T+QlADDA7mOSlX0qiMINjn0cgr+eGHGsbSHzTabcIogz2+p/iqP1Xs6EP/sS2SbqH+brGTbq0g==} dev: true - /functions-have-names@1.2.3: + /functions-have-names/1.2.3: resolution: {integrity: sha512-xckBUXyTIqT97tq2x2AMb+g163b5JFysYk0x4qxNFwbfQkmNZoiRHb6sPzI9/QV33WeuvVYBUIiD4NzNIyqaRQ==} dev: true - /gauge@3.0.2: + /gauge/3.0.2: resolution: {integrity: sha512-+5J6MS/5XksCuXq++uFRsnUd7Ovu1XenbeuIuNRJxYWjgQbPuFhT14lAvsWfqfAmnwluf1OwMjz39HjfLPci0Q==} engines: {node: '>=10'} dependencies: @@ -15683,98 +13509,99 @@ packages: wide-align: 1.1.5 dev: true - /gensync@1.0.0-beta.2: + /gensync/1.0.0-beta.2: resolution: {integrity: sha512-3hN7NaskYvMDLQY55gnW3NQ+mesEAepTqlg+VEbj7zzqEMBVNhzcGYYeqFo/TlYz6eQiFcp1HcsCZO+nGgS8zg==} engines: {node: '>=6.9.0'} - /get-caller-file@2.0.5: + /get-caller-file/2.0.5: resolution: {integrity: sha512-DyFP3BM/3YHTQOCUL/w0OZHR0lpKeGrxotcHWcqNEdnltqFwXVfhEBQ94eIo34AfQpo0rGki4cyIiftY06h2Fg==} engines: {node: 6.* || 8.* || >= 10.*} dev: true - /get-func-name@2.0.0: + /get-func-name/2.0.0: resolution: {integrity: sha512-Hm0ixYtaSZ/V7C8FJrtZIuBBI+iSgL+1Aq82zSu8VQNB4S3Gk8e7Qs3VwBDJAhmRZcFqkl3tQu36g/Foh5I5ig==} dev: false - /get-intrinsic@1.2.0: - resolution: {integrity: sha512-L049y6nFOuom5wGyRc3/gdTLO94dySVKRACj1RmJZBQXlbTMhtNIgkWkUHq+jYmZvKf14EW1EoJnnjbmoHij0Q==} + /get-intrinsic/1.2.1: + resolution: {integrity: sha512-2DcsyfABl+gVHEfCOaTrWgyt+tb6MSEGmKq+kI5HwLbIYgjgmMcV8KQ41uaKz1xxUcn9tJtgFbQUEVcEbd0FYw==} dependencies: function-bind: 1.1.1 has: 1.0.3 + has-proto: 1.0.1 has-symbols: 1.0.3 dev: true - /get-own-enumerable-property-symbols@3.0.2: + /get-own-enumerable-property-symbols/3.0.2: resolution: {integrity: sha512-I0UBV/XOz1XkIJHEUDMZAbzCThU/H8DxmSfmdGcKPnVhu2VfFqr34jr9777IyaTYvxjedWhqVIilEDsCdP5G6g==} dev: true - /get-package-type@0.1.0: + /get-package-type/0.1.0: resolution: {integrity: sha512-pjzuKtY64GYfWizNAJ0fr9VqttZkNiK2iS430LtIHzjBEr6bX8Am2zm4sW4Ro5wjWW5cAlRL1qAMTcXbjNAO2Q==} engines: {node: '>=8.0.0'} dev: true - /get-stdin@4.0.1: + /get-stdin/4.0.1: resolution: {integrity: sha512-F5aQMywwJ2n85s4hJPTT9RPxGmubonuB10MNYo17/xph174n2MIR33HRguhzVag10O/npM7SPk73LMZNP+FaWw==} engines: {node: '>=0.10.0'} dev: true optional: true - /get-stdin@5.0.1: + /get-stdin/5.0.1: resolution: {integrity: sha512-jZV7n6jGE3Gt7fgSTJoz91Ak5MuTLwMwkoYdjxuJ/AmjIsE1UC03y/IWkZCQGEvVNS9qoRNwy5BCqxImv0FVeA==} engines: {node: '>=0.12.0'} dev: true - /get-stream@4.1.0: + /get-stream/4.1.0: resolution: {integrity: sha512-GMat4EJ5161kIy2HevLlr4luNjBgvmj413KaQA7jt4V8B4RDsfpHk7WQ9GVqfYyyx8OS/L66Kox+rJRNklLK7w==} engines: {node: '>=6'} dependencies: pump: 3.0.0 dev: true - /get-stream@5.2.0: + /get-stream/5.2.0: resolution: {integrity: sha512-nBF+F1rAZVCu/p7rjzgA+Yb4lfYXrpl7a6VmJrU8wF9I1CKvP/QwPNZHnOlwbTkY6dvtFIzFMSyQXbLoTQPRpA==} engines: {node: '>=8'} dependencies: pump: 3.0.0 dev: true - /get-stream@6.0.1: + /get-stream/6.0.1: resolution: {integrity: sha512-ts6Wi+2j3jQjqi70w5AlN8DFnkSwC+MqmxEzdEALB2qXZYV3X/b1CTfgPLGJNMeAWxdPfU8FO1ms3NUfaHCPYg==} engines: {node: '>=10'} dev: true - /get-symbol-description@1.0.0: + /get-symbol-description/1.0.0: resolution: {integrity: sha512-2EmdH1YvIQiZpltCNgkuiUnyukzxM/R6NDJX31Ke3BG1Nq5b0S2PhX59UKi9vZpPDQVdqn+1IcaAwnzTT5vCjw==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 - get-intrinsic: 1.2.0 + get-intrinsic: 1.2.1 dev: true - /get-tsconfig@4.6.2: + /get-tsconfig/4.6.2: resolution: {integrity: sha512-E5XrT4CbbXcXWy+1jChlZmrmCwd5KGx502kDCXJJ7y898TtWW9FwoG5HfOLVRKmlmDGkWN2HM9Ho+/Y8F0sJDg==} dependencies: resolve-pkg-maps: 1.0.0 dev: true - /get-value@2.0.6: + /get-value/2.0.6: resolution: {integrity: sha512-Ln0UQDlxH1BapMu3GPtf7CuYNwRZf2gwCuPqbyG6pB8WfmFpzqcy4xtAaAMUhnNqjMKTiCPZG2oMT3YSx8U2NA==} engines: {node: '>=0.10.0'} dev: true - /getos@3.2.1: + /getos/3.2.1: resolution: {integrity: sha512-U56CfOK17OKgTVqozZjUKNdkfEv6jk5WISBJ8SHoagjE6L69zOwl3Z+O8myjY9MEW3i2HPWQBt/LTbCgcC973Q==} dependencies: async: 3.2.4 dev: true - /getpass@0.1.7: + /getpass/0.1.7: resolution: {integrity: sha512-0fzj9JxOLfJ+XGLhR8ze3unN0KZCgZwiSSDz168VERjK8Wl8kVSdcu2kspd4s4wtAa1y/qrVRiAA0WclVsu0ng==} dependencies: assert-plus: 1.0.0 dev: true - /giget@1.1.2: + /giget/1.1.2: resolution: {integrity: sha512-HsLoS07HiQ5oqvObOI+Qb2tyZH4Gj5nYGfF9qQcZNrPw+uEFhdXtgJr01aO2pWadGHucajYDLxxbtQkm97ON2A==} hasBin: true dependencies: @@ -15784,54 +13611,54 @@ packages: mri: 1.2.0 node-fetch-native: 1.2.0 pathe: 1.1.1 - tar: 6.1.13 + tar: 6.1.15 transitivePeerDependencies: - supports-color dev: true - /github-from-package@0.0.0: + /github-from-package/0.0.0: resolution: {integrity: sha512-SyHy3T1v2NUXn29OsWdxmK6RwHD+vkj3v8en8AOBZ1wBQ/hCAQ5bAQTD02kW4W9tUp/3Qh6J8r9EvntiyCmOOw==} dev: true - /github-slugger@1.4.0: - resolution: {integrity: sha512-w0dzqw/nt51xMVmlaV1+JRzN+oCa1KfcgGEWhxUG16wbdA+Xnt/yoFO8Z8x/V82ZcZ0wy6ln9QDup5avbhiDhQ==} + /github-slugger/1.5.0: + resolution: {integrity: sha512-wIh+gKBI9Nshz2o46B0B3f5k/W+WI9ZAv6y5Dn5WJ5SK1t0TnDimB4WE5rmTD05ZAIn8HALCZVmCsvj0w0v0lw==} dev: true - /givens@1.3.9: + /givens/1.3.9: resolution: {integrity: sha512-4hYlStsEIaYeYvZTZwgD5yOS2WVP0dcDsOBqeImdEM8eLuclvv0IEMlQQ1kuA5DN4he7wVH1jsYtNe9uininxg==} dev: true - /glob-parent@3.1.0: + /glob-parent/3.1.0: resolution: {integrity: sha512-E8Ak/2+dZY6fnzlR7+ueWvhsH1SjHr4jjss4YS/h4py44jY9MhK/VFdaZJAWDz6BbL21KeteKxFSFpq8OS5gVA==} dependencies: is-glob: 3.1.0 path-dirname: 1.0.2 dev: true - /glob-parent@5.1.2: + /glob-parent/5.1.2: resolution: {integrity: sha512-AOIgSQCepiJYwP3ARnGx+5VnTu2HBYdzbGP45eLw1vr3zB3vZLeyed1sC9hnbcOc9/SrMyM5RPQrkGz4aS9Zow==} engines: {node: '>= 6'} dependencies: is-glob: 4.0.3 - /glob-parent@6.0.2: + /glob-parent/6.0.2: resolution: {integrity: sha512-XxwI8EOhVQgWp6iDL+3b0r86f4d6AX6zSU55HfB4ydCEuXLXc5FcYeOu+nnGftS4TEju/11rt4KJPTMgbfmv4A==} engines: {node: '>=10.13.0'} dependencies: is-glob: 4.0.3 dev: true - /glob-promise@3.4.0(glob@7.2.3): + /glob-promise/3.4.0_glob@7.2.3: resolution: {integrity: sha512-q08RJ6O+eJn+dVanerAndJwIcumgbDdYiUT7zFQl3Wm1xD6fBKtah7H8ZJChj4wP+8C+QfeVy8xautR7rdmKEw==} engines: {node: '>=4'} peerDependencies: glob: '*' dependencies: - '@types/glob': 8.0.0 + '@types/glob': 8.1.0 glob: 7.2.3 dev: true - /glob-promise@4.2.2(glob@7.2.3): + /glob-promise/4.2.2_glob@7.2.3: resolution: {integrity: sha512-xcUzJ8NWN5bktoTIX7eOclO1Npxd/dyVqUJxlLIDasT4C7KZyqlPIwkdJ0Ypiy3p2ZKahTjK4M9uC3sNSfNMzw==} engines: {node: '>=12'} peerDependencies: @@ -15841,27 +13668,27 @@ packages: glob: 7.2.3 dev: true - /glob-to-regexp@0.3.0: + /glob-to-regexp/0.3.0: resolution: {integrity: sha512-Iozmtbqv0noj0uDDqoL0zNq0VBEfK2YFoMAZoxJe4cwphvLR+JskfF30QhXHOR4m3KrE6NLRYw+U9MRXvifyig==} dev: true - /glob-to-regexp@0.4.1: + /glob-to-regexp/0.4.1: resolution: {integrity: sha512-lkX1HJXwyMcprw/5YUZc2s7DrpAiHB21/V+E1rHUrVNokkvB6bqMzT0VfV6/86ZNabt1k14YOIaT7nDvOX3Iiw==} dev: true - /glob@10.2.7: - resolution: {integrity: sha512-jTKehsravOJo8IJxUGfZILnkvVJM/MOfHRs8QcXolVef2zNI9Tqyy5+SeuOAZd3upViEZQLyFpQhYiHLrMUNmA==} + /glob/10.3.3: + resolution: {integrity: sha512-92vPiMb/iqpmEgsOoIDvTjc50wf9CCCvMzsi6W0JLPeUKE8TWP1a73PgqSrqy7iAZxaSD1YdzU7QZR5LF51MJw==} engines: {node: '>=16 || 14 >=14.17'} hasBin: true dependencies: foreground-child: 3.1.1 - jackspeak: 2.1.1 - minimatch: 9.0.1 - minipass: 5.0.0 - path-scurry: 1.7.0 + jackspeak: 2.2.1 + minimatch: 9.0.3 + minipass: 7.0.2 + path-scurry: 1.10.1 dev: true - /glob@7.1.6: + /glob/7.1.6: resolution: {integrity: sha512-LwaxwyZ72Lk7vZINtNNrywX0ZuLyStrdDtabefZKAY5ZGJhVtgdznluResxNmPitE0SAO+O26sWTHeKSI2wMBA==} dependencies: fs.realpath: 1.0.0 @@ -15872,7 +13699,7 @@ packages: path-is-absolute: 1.0.1 dev: true - /glob@7.2.3: + /glob/7.2.3: resolution: {integrity: sha512-nFR0zLpU2YCaRxwoCJvL6UvCH2JFyFVIvwTLsIf21AuHlMskA1hhTdk+LlYJtOlYt9v6dvszD2BGRqBL+iQK9Q==} dependencies: fs.realpath: 1.0.0 @@ -15882,66 +13709,62 @@ packages: once: 1.4.0 path-is-absolute: 1.0.1 - /glob@8.0.3: - resolution: {integrity: sha512-ull455NHSHI/Y1FqGaaYFaLGkNMMJbavMrEGFXG/PGrg6y7sutWHUHrz6gy6WEBH6akM1M414dWKCNs+IhKdiQ==} + /glob/8.1.0: + resolution: {integrity: sha512-r8hpEjiQEYlF2QU0df3dS+nxxSIreXQS1qRhMJM0Q5NDdR386C7jb7Hwwod8Fgiuex+k0GFjgft18yvxm5XoCQ==} engines: {node: '>=12'} dependencies: fs.realpath: 1.0.0 inflight: 1.0.6 inherits: 2.0.4 - minimatch: 5.1.1 + minimatch: 5.1.6 once: 1.4.0 dev: true - /global-dirs@3.0.0: - resolution: {integrity: sha512-v8ho2DS5RiCjftj1nD9NmnfaOzTdud7RRnVd9kFNOjqZbISlx5DQ+OrTkywgd0dIt7oFCvKetZSHoHcP3sDdiA==} + /global-dirs/3.0.1: + resolution: {integrity: sha512-NBcGGFbBA9s1VzD41QXDG+3++t9Mn5t1FpLdhESY6oKY4gYTFpX4wO3sqGUa0Srjtbfj3szX0RnemmrVRUdULA==} engines: {node: '>=10'} dependencies: ini: 2.0.0 dev: true - /global@4.4.0: + /global/4.4.0: resolution: {integrity: sha512-wv/LAoHdRE3BeTGz53FAamhGlPLhlssK45usmGFThIi4XqnBmjKQ16u+RNbP7WvigRZDxUsM0J3gcQ5yicaL0w==} dependencies: min-document: 2.19.0 process: 0.11.10 dev: true - /globals@11.12.0: + /globals/11.12.0: resolution: {integrity: sha512-WOBp/EEGUiIsJSp7wcv/y6MO+lV9UoncWqxuFfm8eBwzWNgyfBd6Gz+IeKQ9jCmyhoH99g15M3T+QaVHFjizVA==} engines: {node: '>=4'} - /globals@13.19.0: - resolution: {integrity: sha512-dkQ957uSRWHw7CFXLUtUHQI3g3aWApYhfNR2O6jn/907riyTYKVBmxYVROkBcY614FSSeSJh7Xm7SrUWCxvJMQ==} + /globals/13.20.0: + resolution: {integrity: sha512-Qg5QtVkCy/kv3FUSlu4ukeZDVf9ee0iXLAUYX13gbR17bnejFTzr4iS9bY7kwCf1NztRNm1t91fjOiyx4CSwPQ==} engines: {node: '>=8'} dependencies: type-fest: 0.20.2 dev: true - /globalthis@1.0.3: + /globalthis/1.0.3: resolution: {integrity: sha512-sFdI5LyBiNTHjRd7cGPWapiHWMOXKyuBNX/cWJ3NfzrZQVa8GI/8cofCl74AOVqq9W5kNmguTIzJ/1s2gyI9wA==} engines: {node: '>= 0.4'} dependencies: define-properties: 1.2.0 dev: true - /globalyzer@0.1.0: - resolution: {integrity: sha512-40oNTM9UfG6aBmuKxk/giHn5nQ8RVz/SS4Ir6zgzOv9/qC3kKZ9v4etGTcJbEl/NyVQH7FGU7d+X1egr57Md2Q==} - dev: true - - /globby@11.1.0: + /globby/11.1.0: resolution: {integrity: sha512-jhIXaOzy1sb8IyocaruWSn1TjmnBVs8Ayhcy83rmxNJ8q2uWKCAj3CnJY+KpGSXCueAPc0i05kVvVKtP1t9S3g==} engines: {node: '>=10'} dependencies: array-union: 2.1.0 dir-glob: 3.0.1 fast-glob: 3.3.0 - ignore: 5.2.0 + ignore: 5.2.4 merge2: 1.4.1 slash: 3.0.0 dev: true - /globby@9.2.0: + /globby/9.2.0: resolution: {integrity: sha512-ollPHROa5mcxDEkwg6bPt3QbEf4pDQSNtd6JPL1YvOvAo/7/0VAm9TccUeoTmarjPw4pfUthSCqcyfNB1I3ZSg==} engines: {node: '>=6'} dependencies: @@ -15957,28 +13780,24 @@ packages: - supports-color dev: true - /globrex@0.1.2: - resolution: {integrity: sha512-uHJgbwAMwNFf5mLst7IWLNg14x1CkeqglJb/K3doi4dw6q2IvAAmM/Y81kevy83wP+Sst+nutFTYOGg3d1lsxg==} - dev: true - - /glur@1.1.2: + /glur/1.1.2: resolution: {integrity: sha512-l+8esYHTKOx2G/Aao4lEQ0bnHWg4fWtJbVoZZT9Knxi01pB8C80BR85nONLFwkkQoFRCmXY+BUcGZN3yZ2QsRA==} dev: true - /gopd@1.0.1: + /gopd/1.0.1: resolution: {integrity: sha512-d65bNlIadxvpb/A2abVdlqKqV563juRnZ1Wtk6s1sIR8uNsXR70xqIzVqxVf1eTqDunwT2MkczEeaezCKTZhwA==} dependencies: - get-intrinsic: 1.2.0 + get-intrinsic: 1.2.1 dev: true - /got@12.6.1: + /got/12.6.1: resolution: {integrity: sha512-mThBblvlAF1d4O5oqyvN+ZxLAYwIJK7bpMxgYqPD9okW0C3qm5FFn7k811QrcuEBwaogR3ngOFoCfs6mRv7teQ==} engines: {node: '>=14.16'} dependencies: - '@sindresorhus/is': 5.3.0 + '@sindresorhus/is': 5.4.1 '@szmarczak/http-timer': 5.0.1 cacheable-lookup: 7.0.0 - cacheable-request: 10.2.8 + cacheable-request: 10.2.12 decompress-response: 6.0.0 form-data-encoder: 2.1.4 get-stream: 6.0.1 @@ -15988,44 +13807,53 @@ packages: responselike: 3.0.0 dev: true - /graceful-fs@4.2.10: - resolution: {integrity: sha512-9ByhssR2fPVsNZj478qUUbKfmL0+t5BDVyjShtyZZLiK7ZDAArFFfopyOTj0M05wE2tJPisA4iTnnXl2YoPvOA==} + /graceful-fs/4.2.11: + resolution: {integrity: sha512-RbJ5/jmFcNNCcDV5o9eTnBLJ/HszWV0P73bc+Ff4nS/rJj+YaS6IGyiOL0VoBYX+l1Wrl3k63h/KrH+nhJ0XvQ==} dev: true - /grapheme-splitter@1.0.4: + /grapheme-splitter/1.0.4: resolution: {integrity: sha512-bzh50DW9kTPM00T8y4o8vQg89Di9oLJVLW/KaOGIXJWP/iqCN6WKYkbNOF04vFLJhwcpYUh9ydh/+5vpOqV4YQ==} dev: true - /graphemer@1.4.0: + /graphemer/1.4.0: resolution: {integrity: sha512-EtKwoO6kxCL9WO5xipiHTZlSzBm7WLT627TqC/uVRd0HKmq8NXyebnNYxDoBi7wt8eTWrUrKXCOVaFq9x1kgag==} dev: true - /graphql-tag@2.12.6(graphql@16.6.0): + /graphql-tag/2.12.6: + resolution: {integrity: sha512-FdSNcu2QQcWnM2VNvSCCDCVS5PpPqpzgFT8+GXzqJuoDd0CBncxCY278u4mhRO7tMgo2JjgJA5aZ+nWSQ/Z+xg==} + engines: {node: '>=10'} + peerDependencies: + graphql: ^0.9.0 || ^0.10.0 || ^0.11.0 || ^0.12.0 || ^0.13.0 || ^14.0.0 || ^15.0.0 || ^16.0.0 + dependencies: + tslib: 2.6.0 + dev: false + + /graphql-tag/2.12.6_graphql@16.7.1: resolution: {integrity: sha512-FdSNcu2QQcWnM2VNvSCCDCVS5PpPqpzgFT8+GXzqJuoDd0CBncxCY278u4mhRO7tMgo2JjgJA5aZ+nWSQ/Z+xg==} engines: {node: '>=10'} peerDependencies: graphql: ^0.9.0 || ^0.10.0 || ^0.11.0 || ^0.12.0 || ^0.13.0 || ^14.0.0 || ^15.0.0 || ^16.0.0 dependencies: - graphql: 16.6.0 - tslib: 2.5.3 + graphql: 16.7.1 + tslib: 2.6.0 dev: false - /graphql@16.6.0: - resolution: {integrity: sha512-KPIBPDlW7NxrbT/eh4qPXz5FiFdL5UbaA0XUNz2Rp3Z3hqBSkbj0GVjwFDztsWVauZUWsbKHgMg++sk8UX0bkw==} + /graphql/16.7.1: + resolution: {integrity: sha512-DRYR9tf+UGU0KOsMcKAlXeFfX89UiiIZ0dRU3mR0yJfu6OjZqUcp68NnFLnqQU5RexygFoDy1EW+ccOYcPfmHg==} engines: {node: ^12.22.0 || ^14.16.0 || ^16.0.0 || >=17.0.0} - /gzip-size@6.0.0: + /gzip-size/6.0.0: resolution: {integrity: sha512-ax7ZYomf6jqPTQ4+XCpUGyXKHk5WweS+e05MBO4/y3WJ5RkmPXNKvX+bx1behVILVwr6JSQvZAku021CHPXG3Q==} engines: {node: '>=10'} dependencies: duplexer: 0.1.2 dev: true - /handle-thing@2.0.1: + /handle-thing/2.0.1: resolution: {integrity: sha512-9Qn4yBxelxoh2Ow62nP+Ka/kMnOXRi8BXnRaUwezLNhqelnN49xKz4F/dPP8OYLxLxq6JDtZb2i9XznUQbNPTg==} dev: true - /handlebars@4.7.7: + /handlebars/4.7.7: resolution: {integrity: sha512-aAcXm5OAfE/8IXkcZvCepKU3VzW1/39Fb5ZuqMtgI/hT8X2YgoMvBY5dLhq/cpOvw7Lk1nK/UF71aLG/ZnVYRA==} engines: {node: '>=0.4.7'} hasBin: true @@ -16035,10 +13863,21 @@ packages: source-map: 0.6.1 wordwrap: 1.0.0 optionalDependencies: - uglify-js: 3.17.0 + uglify-js: 3.17.4 + dev: true + + /happy-dom/10.1.1: + resolution: {integrity: sha512-/9AMl/rwMCAz/lAs55W0B2p9I/RfnMWmR2iBI1/twz0+XZYrVgHyJzrBTpHDZlbf00NRk/pFoaktKPtdAP5Tlg==} + dependencies: + css.escape: 1.5.1 + entities: 4.5.0 + iconv-lite: 0.6.3 + webidl-conversions: 7.0.0 + whatwg-encoding: 2.0.0 + whatwg-mimetype: 3.0.0 dev: true - /happy-dom@9.20.3: + /happy-dom/9.20.3: resolution: {integrity: sha512-eBsgauT435fXFvQDNcmm5QbGtYzxEzOaX35Ia+h6yP/wwa4xSWZh1CfP+mGby8Hk6Xu59mTkpyf72rUXHNxY7A==} dependencies: css.escape: 1.5.1 @@ -16049,55 +13888,60 @@ packages: whatwg-mimetype: 3.0.0 dev: true - /has-ansi@2.0.0: + /has-ansi/2.0.0: resolution: {integrity: sha512-C8vBJ8DwUCx19vhm7urhTuUsr4/IyP6l4VzNQDv+ryHQObW3TTTp9yB68WpYgRe2bbaGuZ/se74IqFeVnMnLZg==} engines: {node: '>=0.10.0'} dependencies: ansi-regex: 2.1.1 dev: true - /has-bigints@1.0.2: + /has-bigints/1.0.2: resolution: {integrity: sha512-tSvCKtBr9lkF0Ex0aQiP9N+OpV4zi2r/Nee5VkRDbaqv35RLYMzbwQfFSZZH0kR+Rd6302UJZ2p/bJCEoR3VoQ==} dev: true - /has-flag@3.0.0: + /has-flag/3.0.0: resolution: {integrity: sha512-sKJf1+ceQBr4SMkvQnBDNDtf4TXpVhVGateu0t918bl30FnbE2m4vNLX+VWe/dpjlb+HugGYzW7uQXH98HPEYw==} engines: {node: '>=4'} - /has-flag@4.0.0: + /has-flag/4.0.0: resolution: {integrity: sha512-EykJT/Q1KjTWctppgIAgfSO0tKVuZUjhgMr17kqTumMl6Afv3EISleU7qZUzoXDFTAHTDC4NOoG/ZxU3EvlMPQ==} engines: {node: '>=8'} - /has-glob@1.0.0: + /has-glob/1.0.0: resolution: {integrity: sha512-D+8A457fBShSEI3tFCj65PAbT++5sKiFtdCdOam0gnfBgw9D277OERk+HM9qYJXmdVLZ/znez10SqHN0BBQ50g==} engines: {node: '>=0.10.0'} dependencies: is-glob: 3.1.0 dev: true - /has-property-descriptors@1.0.0: + /has-property-descriptors/1.0.0: resolution: {integrity: sha512-62DVLZGoiEBDHQyqG4w9xCuZ7eJEwNmJRWw2VY84Oedb7WFcA27fiEVe8oUQx9hAUJ4ekurquucTGwsyO1XGdQ==} dependencies: - get-intrinsic: 1.2.0 + get-intrinsic: 1.2.1 + dev: true + + /has-proto/1.0.1: + resolution: {integrity: sha512-7qE+iP+O+bgF9clE5+UoBFzE65mlBiVj3tKCrlNQ0Ogwm0BjpT/gK4SlLYDMybDh5I3TCTKnPPa0oMG7JDYrhg==} + engines: {node: '>= 0.4'} dev: true - /has-symbols@1.0.3: + /has-symbols/1.0.3: resolution: {integrity: sha512-l3LCuF6MgDNwTDKkdYGEihYjt5pRPbEg46rtlmnSPlUbgmB8LOIrKJbYYFBSbnPaJexMKtiPO8hmeRjRz2Td+A==} engines: {node: '>= 0.4'} dev: true - /has-tostringtag@1.0.0: + /has-tostringtag/1.0.0: resolution: {integrity: sha512-kFjcSNhnlGV1kyoGk7OXKSawH5JOb/LzUc5w9B02hOTO0dfFRjbHQKvg1d6cf3HbeUmtU9VbbV3qzZ2Teh97WQ==} engines: {node: '>= 0.4'} dependencies: has-symbols: 1.0.3 dev: true - /has-unicode@2.0.1: + /has-unicode/2.0.1: resolution: {integrity: sha512-8Rf9Y83NBReMnx0gFzA8JImQACstCYWUplepDa9xprwwtmgEZUF0h/i5xSA625zB/I37EtrswSST6OXxwaaIJQ==} dev: true - /has-value@0.3.1: + /has-value/0.3.1: resolution: {integrity: sha512-gpG936j8/MzaeID5Yif+577c17TxaDmhuyVgSwtnL/q8UUTySg8Mecb+8Cf1otgLoD7DDH75axp86ER7LFsf3Q==} engines: {node: '>=0.10.0'} dependencies: @@ -16106,7 +13950,7 @@ packages: isobject: 2.1.0 dev: true - /has-value@1.0.0: + /has-value/1.0.0: resolution: {integrity: sha512-IBXk4GTsLYdQ7Rvt+GRBrFSVEkmuOUy4re0Xjd9kJSUQpnTrWR4/y9RpfexN9vkAPMFuQoeWKwqzPozRTlasGw==} engines: {node: '>=0.10.0'} dependencies: @@ -16115,12 +13959,12 @@ packages: isobject: 3.0.1 dev: true - /has-values@0.1.4: + /has-values/0.1.4: resolution: {integrity: sha512-J8S0cEdWuQbqD9//tlZxiMuMNmxB8PlEwvYwuxsTmR1G5RXUePEX/SJn7aD0GMLieuZYSwNH0cQuJGwnYunXRQ==} engines: {node: '>=0.10.0'} dev: true - /has-values@1.0.0: + /has-values/1.0.0: resolution: {integrity: sha512-ODYZC64uqzmtfGMEAX/FvZiRyWLpAC3vYnNunURUnkGVTS+mI0smVsWaPydRBsE3g+ok7h960jChO8mFcWlHaQ==} engines: {node: '>=0.10.0'} dependencies: @@ -16128,32 +13972,32 @@ packages: kind-of: 4.0.0 dev: true - /has@1.0.3: + /has/1.0.3: resolution: {integrity: sha512-f2dvO0VU6Oej7RkWJGrehjbzMAjFp5/VKPp5tTpWIV4JHHZK1/BxbFRtf/siA2SWTe09caDmVtYYzWEIbBS4zw==} engines: {node: '>= 0.4.0'} dependencies: function-bind: 1.1.1 - /hash-base@3.1.0: + /hash-base/3.1.0: resolution: {integrity: sha512-1nmYp/rhMDiE7AYkDw+lLwlAzz0AntGIe51F3RfFfEqyQ3feY2eI/NcwC6umIQVOASPMsWJLJScWKSSvzL9IVA==} engines: {node: '>=4'} dependencies: inherits: 2.0.4 - readable-stream: 3.6.0 + readable-stream: 3.6.2 safe-buffer: 5.2.1 dev: true - /hash.js@1.1.7: + /hash.js/1.1.7: resolution: {integrity: sha512-taOaskGt4z4SOANNseOviYDvjEJinIkRgmp7LbKP2YTTmVxWBl87s/uzK9r+44BclBSp2X7K1hqeNfz9JbBeXA==} dependencies: inherits: 2.0.4 minimalistic-assert: 1.0.1 dev: true - /hast-to-hyperscript@9.0.1: + /hast-to-hyperscript/9.0.1: resolution: {integrity: sha512-zQgLKqF+O2F72S1aa4y2ivxzSlko3MAvxkwG8ehGmNiqd98BIN3JM1rAJPmplEyLmGLO2QZYJtIneOSZ2YbJuA==} dependencies: - '@types/unist': 2.0.6 + '@types/unist': 2.0.7 comma-separated-tokens: 1.0.8 property-information: 5.6.0 space-separated-tokens: 1.1.5 @@ -16162,7 +14006,7 @@ packages: web-namespaces: 1.1.4 dev: true - /hast-util-from-parse5@6.0.1: + /hast-util-from-parse5/6.0.1: resolution: {integrity: sha512-jeJUWiN5pSxW12Rh01smtVkZgZr33wBokLzKLwinYOUfSzm1Nl/c3GUGebDyOKjdsRgMvoVbV0VpAcpjF4NrJA==} dependencies: '@types/parse5': 5.0.3 @@ -16173,14 +14017,14 @@ packages: web-namespaces: 1.1.4 dev: true - /hast-util-parse-selector@2.2.5: + /hast-util-parse-selector/2.2.5: resolution: {integrity: sha512-7j6mrk/qqkSehsM92wQjdIgWM2/BW61u/53G6xmC8i1OmEdKLHbk419QKQUjz6LglWsfqoiHmyMRkP1BGjecNQ==} dev: true - /hast-util-raw@6.0.1: + /hast-util-raw/6.0.1: resolution: {integrity: sha512-ZMuiYA+UF7BXBtsTBNcLBF5HzXzkyE6MLzJnL605LKE8GJylNjGc4jjxazAHUtcwT5/CEt6afRKViYB4X66dig==} dependencies: - '@types/hast': 2.3.4 + '@types/hast': 2.3.5 hast-util-from-parse5: 6.0.1 hast-util-to-parse5: 6.0.0 html-void-elements: 1.0.5 @@ -16192,7 +14036,7 @@ packages: zwitch: 1.0.5 dev: true - /hast-util-to-parse5@6.0.0: + /hast-util-to-parse5/6.0.0: resolution: {integrity: sha512-Lu5m6Lgm/fWuz8eWnrKezHtVY83JeRGaNQ2kn9aJgqaxvVkFCZQBEhgodZUDUvoodgyROHDb3r5IxAEdl6suJQ==} dependencies: hast-to-hyperscript: 9.0.1 @@ -16202,36 +14046,36 @@ packages: zwitch: 1.0.5 dev: true - /hastscript@6.0.0: + /hastscript/6.0.0: resolution: {integrity: sha512-nDM6bvd7lIqDUiYEiu5Sl/+6ReP0BMk/2f4U/Rooccxkj0P5nm+acM5PrGJ/t5I8qPGiqZSE6hVAwZEdZIvP4w==} dependencies: - '@types/hast': 2.3.4 + '@types/hast': 2.3.5 comma-separated-tokens: 1.0.8 hast-util-parse-selector: 2.2.5 property-information: 5.6.0 space-separated-tokens: 1.1.5 dev: true - /he@1.2.0: + /he/1.2.0: resolution: {integrity: sha512-F/1DnUGPopORZi0ni+CvrCgHQ5FyEAHRLSApuYWMmrbSwoN2Mn/7k+Gl38gJnR7yyDZk6WLXwiGod1JOWNDKGw==} hasBin: true dev: true - /headers-polyfill@3.1.2: + /headers-polyfill/3.1.2: resolution: {integrity: sha512-tWCK4biJ6hcLqTviLXVR9DTRfYGQMXEIUj3gwJ2rZ5wO/at3XtkI4g8mCvFdUF9l1KMBNCfmNAdnahm1cgavQA==} dev: true - /hexoid@1.0.0: + /hexoid/1.0.0: resolution: {integrity: sha512-QFLV0taWQOZtvIRIAdBChesmogZrtuXvVWsFHZTk2SU+anspqZ2vMnoLg7IE1+Uk16N19APic1BuF8bC8c2m5g==} engines: {node: '>=8'} dev: true - /history@5.3.0: + /history/5.3.0: resolution: {integrity: sha512-ZqaKwjjrAYUYfLG+htGaIIZ4nioX2L70ZUMIFysS3xvBsSG4x/n1V6TXV3N8ZYNuFGlDirFg32T7B6WOUPDYcQ==} dependencies: - '@babel/runtime': 7.18.9 + '@babel/runtime': 7.22.6 - /hmac-drbg@1.0.1: + /hmac-drbg/1.0.1: resolution: {integrity: sha512-Tti3gMqLdZfhOQY1Mzf/AanLiqh1WTiJgEj26ZuYQ9fbkLomzGchCws4FyrSd4VkpBfiNhaE1On+lOz894jvXg==} dependencies: hash.js: 1.1.7 @@ -16239,65 +14083,58 @@ packages: minimalistic-crypto-utils: 1.0.1 dev: true - /hoist-non-react-statics@3.3.2: + /hoist-non-react-statics/3.3.2: resolution: {integrity: sha512-/gGivxi8JPKWNm/W0jSmzcMPpfpPLc3dY/6GxhX2hQ9iGj3aDfklV4ET7NjKpSinLpJ5vafa9iiGIEZg10SfBw==} dependencies: react-is: 16.13.1 dev: false - /hosted-git-info@2.8.9: + /hosted-git-info/2.8.9: resolution: {integrity: sha512-mxIDAb9Lsm6DoOJ7xH+5+X4y1LU/4Hi50L9C5sIswK3JzULS4bwk1FvjdBgvYR4bzT4tuUQiC15FE2f5HbLvYw==} dev: true - /hosted-git-info@4.1.0: + /hosted-git-info/4.1.0: resolution: {integrity: sha512-kyCuEOWjJqZuDbRHzL8V93NzQhwIB71oFWSyzVo+KPZI+pnQPPxucdkrOZvkLRnrf5URsQM+IJ09Dw29cRALIA==} engines: {node: '>=10'} dependencies: lru-cache: 6.0.0 dev: true - /hpack.js@2.1.6: + /hpack.js/2.1.6: resolution: {integrity: sha512-zJxVehUdMGIKsRaNt7apO2Gqp0BdqW5yaiGHXXmbpvxgBYVZnAql+BJb4RO5ad2MgpbZKn5G6nMnegrH1FcNYQ==} dependencies: inherits: 2.0.4 obuf: 1.1.2 - readable-stream: 2.3.7 + readable-stream: 2.3.8 wbuf: 1.7.3 dev: true - /html-element-map@1.3.1: + /html-element-map/1.3.1: resolution: {integrity: sha512-6XMlxrAFX4UEEGxctfFnmrFaaZFNf9i5fNuV5wZ3WWQ4FVaNP1aX1LkX9j2mfEx1NpjeE/rL3nmgEn23GdFmrg==} dependencies: - array.prototype.filter: 1.0.1 + array.prototype.filter: 1.0.2 call-bind: 1.0.2 dev: true - /html-encoding-sniffer@2.0.1: - resolution: {integrity: sha512-D5JbOMBIR/TVZkubHT+OyT2705QvogUW4IBn6nHd756OwieSF9aDYFj4dv6HHEVGYbHaLETa3WggZYWWMyy3ZQ==} - engines: {node: '>=10'} - dependencies: - whatwg-encoding: 1.0.5 - dev: true - - /html-encoding-sniffer@3.0.0: + /html-encoding-sniffer/3.0.0: resolution: {integrity: sha512-oWv4T4yJ52iKrufjnyZPkrN0CH3QnrUqdB6In1g5Fe1mia8GmF36gnfNySxoZtxD5+NmYw1EElVXiBk93UeskA==} engines: {node: '>=12'} dependencies: whatwg-encoding: 2.0.0 dev: true - /html-entities@2.3.2: - resolution: {integrity: sha512-c3Ab/url5ksaT0WyleslpBEthOzWhrjQbg75y7XUsfSzi3Dgzt0l8w5e7DylRn15MTlMMD58dTfzddNS2kcAjQ==} + /html-entities/2.3.3: + resolution: {integrity: sha512-DV5Ln36z34NNTDgnz0EWGBLZENelNAtkiFA4kyNOG2tDI6Mz1uSWiq1wAKdyjnJwyDiDO7Fa2SO1CTxPXL8VxA==} dev: true - /html-entities@2.3.3: - resolution: {integrity: sha512-DV5Ln36z34NNTDgnz0EWGBLZENelNAtkiFA4kyNOG2tDI6Mz1uSWiq1wAKdyjnJwyDiDO7Fa2SO1CTxPXL8VxA==} + /html-entities/2.4.0: + resolution: {integrity: sha512-igBTJcNNNhvZFRtm8uA6xMY6xYleeDwn3PeBCkDz7tHttv4F2hsDI2aPgNERWzvRcNYHNT3ymRaQzllmXj4YsQ==} dev: true - /html-escaper@2.0.2: + /html-escaper/2.0.2: resolution: {integrity: sha512-H2iMtd0I4Mt5eYiapRdIDjp+XzelXQ0tFE4JS7YFwFevXXMmOp9myNrUvCg0D6ws8iqkRPBfKHgbwig1SmlLfg==} - /html-minifier-terser@5.1.1: + /html-minifier-terser/5.1.1: resolution: {integrity: sha512-ZPr5MNObqnV/T9akshPKbVgyOqLmy+Bxo7juKCfTfnjNniTAMdy4hz21YQqoofMBJD2kdREaqPPdThoR78Tgxg==} engines: {node: '>=6'} hasBin: true @@ -16311,16 +14148,16 @@ packages: terser: 4.8.1 dev: true - /html-tags@3.2.0: - resolution: {integrity: sha512-vy7ClnArOZwCnqZgvv+ddgHgJiAFXe3Ge9ML5/mBctVJoUoYPCdxVucOywjDARn6CVoh3dRSFdPHy2sX80L0Wg==} + /html-tags/3.3.1: + resolution: {integrity: sha512-ztqyC3kLto0e9WbNp0aeP+M3kTt+nbaIveGmUxAtZa+8iFgKLUOD4YKM5j+f3QD89bra7UeumolZHKuOXnTmeQ==} engines: {node: '>=8'} dev: true - /html-void-elements@1.0.5: + /html-void-elements/1.0.5: resolution: {integrity: sha512-uE/TxKuyNIcx44cIWnjr/rfIATDH7ZaOMmstu0CwhFG1Dunhlp4OC6/NMbhiwoq5BpW0ubi303qnEk/PZj614w==} dev: true - /html-webpack-plugin@4.5.2(webpack@4.46.0): + /html-webpack-plugin/4.5.2_webpack@4.46.0: resolution: {integrity: sha512-q5oYdzjKUIPQVjOosjgvCHQOv9Ett9CYYHlgvJeXG0qQvdSojnBq4vAdQBwn1+yGveAwHCoe/rMR86ozX3+c2A==} engines: {node: '>=6.9'} peerDependencies: @@ -16328,9 +14165,9 @@ packages: dependencies: '@types/html-minifier-terser': 5.1.2 '@types/tapable': 1.0.8 - '@types/webpack': 4.41.32 + '@types/webpack': 4.41.33 html-minifier-terser: 5.1.1 - loader-utils: 1.4.0 + loader-utils: 1.4.2 lodash: 4.17.21 pretty-error: 2.1.2 tapable: 1.1.3 @@ -16338,7 +14175,7 @@ packages: webpack: 4.46.0 dev: true - /htmlparser2-svelte@4.1.0: + /htmlparser2-svelte/4.1.0: resolution: {integrity: sha512-+4f4RBFz7Rj2Hp0ZbFbXC+Kzbd6S9PgjiuFtdT76VMNgKogrEZy0pG2UrPycPbrZzVEIM5lAT3lAdkSTCHLPjg==} dependencies: domelementtype: 2.3.0 @@ -16347,7 +14184,7 @@ packages: entities: 2.2.0 dev: true - /htmlparser2@6.1.0: + /htmlparser2/6.1.0: resolution: {integrity: sha512-gyyPk6rgonLFEDGoeRgQNaEUvdJ4ktTmmUh/h2t7s+M8oPpIPxgNACWa+6ESR57kXstwqPiCut0V8NRpcwgU7A==} dependencies: domelementtype: 2.3.0 @@ -16356,24 +14193,24 @@ packages: entities: 2.2.0 dev: true - /htmlparser2@8.0.1: - resolution: {integrity: sha512-4lVbmc1diZC7GUJQtRQ5yBAeUCL1exyMwmForWkRLnwyzWBFxN633SALPMGYaWZvKe9j1pRZJpauvmxENSp/EA==} + /htmlparser2/8.0.2: + resolution: {integrity: sha512-GYdjWKDkbRLkZ5geuHs5NY1puJ+PXwP7+fHPRz06Eirsb9ugf6d8kkXav6ADhcODhFFPMIXyxkxSuMf3D6NCFA==} dependencies: domelementtype: 2.3.0 domhandler: 5.0.3 - domutils: 3.0.1 + domutils: 3.1.0 entities: 4.5.0 dev: true - /http-cache-semantics@4.1.1: + /http-cache-semantics/4.1.1: resolution: {integrity: sha512-er295DKPVsV82j5kw1Gjt+ADA/XYHsajl82cGNQG2eyoPkvgUhX+nDIyelzhIWbbsXP39EHcI6l5tYs2FYqYXQ==} dev: true - /http-deceiver@1.2.7: + /http-deceiver/1.2.7: resolution: {integrity: sha512-LmpOGxTfbpgtGVxJrj5k7asXHCgNZp5nLfp+hWc8QQRqtb7fUy6kRY3BO1h9ddF6yIPYUARgxGOwB42DnxIaNw==} dev: true - /http-errors@2.0.0: + /http-errors/2.0.0: resolution: {integrity: sha512-FtwrG/euBzaEjYeRqOgly7G0qviiXoJWnvEH2Z1plBdXgbyjv34pHTSb9zoeHMyDy33+DWy5Wt9Wo+TURtOYSQ==} engines: {node: '>= 0.8'} dependencies: @@ -16384,29 +14221,18 @@ packages: toidentifier: 1.0.1 dev: true - /http-proxy-agent@4.0.1: - resolution: {integrity: sha512-k0zdNgqWTGA6aeIRVpvfVob4fL52dTfaehylg0Y4UvSySvOq/Y+BOyPrgpUrA7HylqvU8vIZGsRuXmspskV0Tg==} - engines: {node: '>= 6'} - dependencies: - '@tootallnate/once': 1.1.2 - agent-base: 6.0.2 - debug: 4.3.4(supports-color@8.1.1) - transitivePeerDependencies: - - supports-color - dev: true - - /http-proxy-agent@5.0.0: + /http-proxy-agent/5.0.0: resolution: {integrity: sha512-n2hY8YdoRE1i7r6M0w9DIw5GgZN0G25P8zLCRQ8rjXtTU3vsNFBI/vWK/UIeE6g5MUUz6avwAPXmL6Fy9D/90w==} engines: {node: '>= 6'} dependencies: '@tootallnate/once': 2.0.0 agent-base: 6.0.2 - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 transitivePeerDependencies: - supports-color dev: true - /http-signature@1.3.6: + /http-signature/1.3.6: resolution: {integrity: sha512-3adrsD6zqo4GsTqtO7FyrejHNv+NgiIfAfv68+jVlFmSr9OGy7zrxONceFRLKvnnZA5jbxQBX1u9PpB6Wi32Gw==} engines: {node: '>=0.10'} dependencies: @@ -16415,7 +14241,7 @@ packages: sshpk: 1.17.0 dev: true - /http2-wrapper@2.2.0: + /http2-wrapper/2.2.0: resolution: {integrity: sha512-kZB0wxMo0sh1PehyjJUWRFEd99KC5TLjZ2cULC4f9iqJBAmKQQXEICjxl5iPJRwP40dpeHFqqhm7tYCvODpqpQ==} engines: {node: '>=10.19.0'} dependencies: @@ -16423,140 +14249,127 @@ packages: resolve-alpn: 1.2.1 dev: true - /https-browserify@1.0.0: + /https-browserify/1.0.0: resolution: {integrity: sha512-J+FkSdyD+0mA0N+81tMotaRMfSL9SGi+xpD3T6YApKsc3bGSXJlfXri3VyFOeYkfLRQisDk1W+jIFFKBeUBbBg==} dev: true - /https-localhost@4.7.1: + /https-localhost/4.7.1: resolution: {integrity: sha512-rl+NFV0l67/0W7fZwk4LB5gS6HdhtSFLpCpf1N+KD5WQAXtPXX1QE8H0cP8VNJii18rtpTkE9eAHdUfJ0goAnQ==} hasBin: true dependencies: appdata-path: 1.0.0 compression: 1.7.4 cors: 2.8.5 - express: 4.18.1 + express: 4.18.2 spdy: 4.0.2 - uglify-js: 3.17.0 + uglify-js: 3.17.4 transitivePeerDependencies: - supports-color dev: true - /https-proxy-agent@5.0.1: + /https-proxy-agent/5.0.1: resolution: {integrity: sha512-dFcAjpTQFgoLMzC2VwU+C/CbS7uRL0lWmxDITmqm7C+7F0Odmj6s9l6alZc6AELXhrnggM2CeWSXHGOdX2YtwA==} engines: {node: '>= 6'} dependencies: agent-base: 6.0.2 - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 transitivePeerDependencies: - supports-color dev: true - /human-signals@1.1.1: + /human-signals/1.1.1: resolution: {integrity: sha512-SEQu7vl8KjNL2eoGBLF3+wAjpsNfA9XMlXAYj/3EdaNfAlxKthD1xjEQfGOUhllCGGJVNY34bRr6lPINhNjyZw==} engines: {node: '>=8.12.0'} dev: true - /human-signals@2.1.0: + /human-signals/2.1.0: resolution: {integrity: sha512-B4FFZ6q/T2jhhksgkbEW3HBvWIfDW85snkQgawt07S7J5QXTk6BkNV+0yAeZrM5QpMAdYlocGoljn0sJ/WQkFw==} engines: {node: '>=10.17.0'} dev: true - /human-signals@3.0.1: + /human-signals/3.0.1: resolution: {integrity: sha512-rQLskxnM/5OCldHo+wNXbpVgDn5A17CUoKX+7Sokwaknlq7CdSnphy0W39GU8dw59XiCXmFXDg4fRuckQRKewQ==} engines: {node: '>=12.20.0'} dev: true - /human-signals@4.3.0: - resolution: {integrity: sha512-zyzVyMjpGBX2+6cDVZeFPCdtOtdsxOeseRhB9tkQ6xXmGUNrcnBzdEKPy3VPNYz+4gy1oukVOXcrJCunSyc6QQ==} + /human-signals/4.3.1: + resolution: {integrity: sha512-nZXjEF2nbo7lIw3mgYjItAfgQXog3OjJogSbKa2CQIIvSGWcKgeJnQlNXip6NglNzYH45nSRiEVimMvYL8DDqQ==} engines: {node: '>=14.18.0'} dev: true - /ico-endec@0.1.6: + /ico-endec/0.1.6: resolution: {integrity: sha512-ZdLU38ZoED3g1j3iEyzcQj+wAkY2xfWNkymszfJPoxucIUhK7NayQ+/C4Kv0nDFMIsbtbEHldv3V8PU494/ueQ==} dev: true - /iconv-lite@0.4.24: + /iconv-lite/0.4.24: resolution: {integrity: sha512-v3MXnZAcvnywkTUEZomIActle7RXXeedOR31wwl7VlyoXO4Qi9arvSenNQWne1TcRwhCL1HwLI21bEqdpj8/rA==} engines: {node: '>=0.10.0'} dependencies: safer-buffer: 2.1.2 dev: true - /iconv-lite@0.6.3: + /iconv-lite/0.6.3: resolution: {integrity: sha512-4fCk79wshMdzMp2rH06qWrJE4iolqLhCUH+OiuIgU++RB0+94NlDL81atO7GX55uUKueo0txHNtvEyI6D7WdMw==} engines: {node: '>=0.10.0'} dependencies: safer-buffer: 2.1.2 dev: true - /icss-utils@4.1.1: + /icss-utils/4.1.1: resolution: {integrity: sha512-4aFq7wvWyMHKgxsH8QQtGpvbASCf+eM3wPRLI6R+MgAnTCZ6STYsRvttLvRWK0Nfif5piF394St3HeJDaljGPA==} engines: {node: '>= 6'} dependencies: postcss: 7.0.39 dev: true - /idb@7.1.1: + /idb/7.1.1: resolution: {integrity: sha512-gchesWBzyvGHRO9W8tzUWFDycow5gwjvFKfyV9FF32Y7F50yZMp7mP+T2mJIWFx49zicqyC4uefHM17o6xKIVQ==} dev: true - /ieee754@1.2.1: + /ieee754/1.2.1: resolution: {integrity: sha512-dcyqhDvX1C46lXZcVqCpK+FtMRQVdIMN6/Df5js2zouUsqG7I6sFxitIC+7KYK29KdXOLHdu9zL4sFnoVQnqaA==} dev: true - /if-node-version@1.1.1: + /if-node-version/1.1.1: resolution: {integrity: sha512-qMcJD7ftbSWlf+6w8nzZAWKOELmG3xH5Gu5XYW2+f9uaYj1t9JX5KNWxnvNMGhu8f+uIUgnqFHLlwyKTHaLWWA==} engines: {node: '>=0.10.0'} hasBin: true dependencies: cross-spawn: 5.1.0 - semver: 5.7.1 + semver: 5.7.2 dev: true - /iferr@0.1.5: + /iferr/0.1.5: resolution: {integrity: sha512-DUNFN5j7Tln0D+TxzloUjKB+CtVu6myn0JEFak6dG18mNt9YkQ6lzGCdafwofISZ1lLF3xRHJ98VKy9ynkcFaA==} dev: true - /ignore@4.0.6: + /ignore/4.0.6: resolution: {integrity: sha512-cyFDKrqc/YdcWFniJhzI42+AzS+gNwmUzOSFcRCQYwySuBBBy/KjuxWLZ/FHEH6Moq1NizMOBWyTcv8O4OZIMg==} engines: {node: '>= 4'} dev: true - /ignore@5.2.0: - resolution: {integrity: sha512-CmxgYGiEPCLhfLnpPp1MoRmifwEIOgjcHXxOBjv7mY96c+eWScsOP9c112ZyLdWHi0FxHjI+4uVhKYp/gcdRmQ==} + /ignore/5.2.4: + resolution: {integrity: sha512-MAb38BcSbH0eHNBxn7ql2NH/kX33OkB3lZ1BNdh7ENeRChHTYsTvWrMubiIAMNS2llXEEgZ1MUOBtXChP3kaFQ==} engines: {node: '>= 4'} dev: true - /import-fresh@3.3.0: + /import-fresh/3.3.0: resolution: {integrity: sha512-veYYhQa+D1QBKznvhUHxb8faxlrwUnxseDAbAp457E0wLNio2bOSKnjYDhMj+YiAq61xrMGhQk9iXVk5FzgQMw==} engines: {node: '>=6'} dependencies: parent-module: 1.0.1 resolve-from: 4.0.0 - /import-local@3.1.0: - resolution: {integrity: sha512-ASB07uLtnDs1o6EHjKpX34BKYDSqnFerfTOJL2HvMqF70LnxpjkzDB8J44oT9pu4AMPkQwf8jl6szgvNd2tRIg==} - engines: {node: '>=8'} - hasBin: true - dependencies: - pkg-dir: 4.2.0 - resolve-cwd: 3.0.0 - dev: true - - /import-meta-resolve@2.2.2: - resolution: {integrity: sha512-f8KcQ1D80V7RnqVm+/lirO9zkOxjGxhaTC1IPrBGd3MEfNgmNG67tSUO9gTi2F3Blr2Az6g1vocaxzkVnWl9MA==} - dev: true - - /import-meta-resolve@3.0.0: + /import-meta-resolve/3.0.0: resolution: {integrity: sha512-4IwhLhNNA8yy445rPjD/lWh++7hMDOml2eHtd58eG7h+qK3EryMuuRbsHGPikCoAgIkkDnckKfWSk2iDla/ejg==} dev: true - /imurmurhash@0.1.4: + /imurmurhash/0.1.4: resolution: {integrity: sha512-JmXMZ6wuvDmLiHEml9ykzqO6lwFbof0GG4IkcGaENdCRDDmMVnny7s5HsIgHCbaq0w2MyPhDqkhTUgS2LU2PHA==} engines: {node: '>=0.8.19'} dev: true - /indent-string@2.1.0: + /indent-string/2.1.0: resolution: {integrity: sha512-aqwDFWSgSgfRaEwao5lg5KEcVd/2a+D1rvoG7NdilmYz0NwRk6StWpWdz/Hpk34MKPpx7s8XxUqimfcQK6gGlg==} engines: {node: '>=0.10.0'} dependencies: @@ -16564,51 +14377,51 @@ packages: dev: true optional: true - /indent-string@4.0.0: + /indent-string/4.0.0: resolution: {integrity: sha512-EdDDZu4A2OyIK7Lr/2zG+w5jmbuk1DVBnEwREQvBzspBJkCEbRa8GxU1lghYcaGJCnRWibjDXlq779X1/y5xwg==} engines: {node: '>=8'} dev: true - /infer-owner@1.0.4: + /infer-owner/1.0.4: resolution: {integrity: sha512-IClj+Xz94+d7irH5qRyfJonOdfTzuDaifE6ZPWfx0N0+/ATZCbuTPq2prFl526urkQd90WyUKIh1DfBQ2hMz9A==} dev: true - /inflight@1.0.6: + /inflight/1.0.6: resolution: {integrity: sha512-k92I/b08q4wvFscXCLvqfsHCrjrF7yiXsQuIVvVE7N82W3+aqpzuUdBbfhWcy/FZR3/4IgflMgKLOsvPDrGCJA==} dependencies: once: 1.4.0 wrappy: 1.0.2 - /inherits@2.0.1: + /inherits/2.0.1: resolution: {integrity: sha512-8nWq2nLTAwd02jTqJExUYFSD/fKq6VH9Y/oG2accc/kdI0V98Bag8d5a4gi3XHz73rDWa2PvTtvcWYquKqSENA==} dev: true - /inherits@2.0.3: + /inherits/2.0.3: resolution: {integrity: sha512-x00IRNXNy63jwGkJmzPigoySHbaqpNuzKbBOmzK+g2OdZpQ9w+sxCN+VSB3ja7IAge2OP2qpfxTjeNcyjmW1uw==} dev: true - /inherits@2.0.4: + /inherits/2.0.4: resolution: {integrity: sha512-k/vGaX4/Yla3WzyMCvTQOXYeIHvqOKtnqBduzTHpzpQZzAskKMhZ2K+EnBiSM9zGSoIFeMpXKxa4dYeZIQqewQ==} - /ini@1.3.8: + /ini/1.3.8: resolution: {integrity: sha512-JV/yugV2uzW5iMRSiZAyDtQd+nxtUnjeLt0acNdw98kKLrvuRVyB80tsREOE7yvGVgalhZ6RNXCmEHkUKBKxew==} dev: true - /ini@2.0.0: + /ini/2.0.0: resolution: {integrity: sha512-7PnF4oN3CvZF23ADhA5wRaYEQpJ8qygSkbtTXWBeXWXmEVRXK+1ITciHWwHhsjv1TmW0MgacIv6hEi5pX5NQdA==} engines: {node: '>=10'} dev: true - /inline-style-parser@0.1.1: + /inline-style-parser/0.1.1: resolution: {integrity: sha512-7NXolsK4CAS5+xvdj5OMMbI962hU/wvwoxk+LWR9Ek9bVtyuuYScDN6eS0rUm6TxApFpw7CX1o4uJzcd4AyD3Q==} dev: true - /inquirer@8.2.4: - resolution: {integrity: sha512-nn4F01dxU8VeKfq192IjLsxu0/OmMZ4Lg3xKAns148rCaXP6ntAoEkVYZThWjwON8AlzdZZi6oqnhNbxUG9hVg==} + /inquirer/8.2.5: + resolution: {integrity: sha512-QAgPDQMEgrDssk1XiwwHoOGYF9BAbUcc1+j+FhEvaOt8/cKRqyLn0U5qA6F74fGhTMGxf92pOvPBeh29jQJDTQ==} engines: {node: '>=12.0.0'} dependencies: ansi-escapes: 4.3.2 - chalk: 4.1.2 + chalk: 4.1.1 cli-cursor: 3.1.0 cli-width: 3.0.0 external-editor: 3.1.0 @@ -16624,12 +14437,12 @@ packages: wrap-ansi: 7.0.0 dev: true - /inquirer@9.2.7: + /inquirer/9.2.7: resolution: {integrity: sha512-Bf52lnfvNxGPJPltiNO2tLBp3zC339KNlGMqOkW+dsvNikBhcVDK5kqU2lVX2FTPzuXUFX5WJDlsw//w3ZwoTw==} engines: {node: '>=14.18.0'} dependencies: ansi-escapes: 4.3.2 - chalk: 5.2.0 + chalk: 5.3.0 cli-cursor: 3.1.0 cli-width: 4.0.0 external-editor: 3.1.0 @@ -16645,65 +14458,65 @@ packages: wrap-ansi: 6.2.0 dev: true - /internal-slot@1.0.5: + /internal-slot/1.0.5: resolution: {integrity: sha512-Y+R5hJrzs52QCG2laLn4udYVnxsfny9CpOhNhUvk/SSSVyF6T27FzRbF0sroPidSu3X8oEAkOn2K804mjpt6UQ==} engines: {node: '>= 0.4'} dependencies: - get-intrinsic: 1.2.0 + get-intrinsic: 1.2.1 has: 1.0.3 side-channel: 1.0.4 dev: true - /internmap@2.0.3: + /internmap/2.0.3: resolution: {integrity: sha512-5Hh7Y1wQbvY5ooGgPbDaL5iYLAPzMTUrjMulskHLH6wnv/A+1q5rgEaiuqEjB+oxGXIVZs1FF+R/KPN3ZSQYYg==} engines: {node: '>=12'} dev: false - /interpret@2.2.0: + /interpret/2.2.0: resolution: {integrity: sha512-Ju0Bz/cEia55xDwUWEa8+olFpCiQoypjnQySseKtmjNrnps3P+xfpUmGr90T7yjlVJmOtybRvPXhKMbHr+fWnw==} engines: {node: '>= 0.10'} dev: true - /ip@2.0.0: + /ip/2.0.0: resolution: {integrity: sha512-WKa+XuLG1A1R0UWhl2+1XQSi+fZWMsYKffMZTTYsiZaUD8k2yDAj5atimTUD2TZkyCkNEeYE5NhFZmupOGtjYQ==} dev: true - /ipaddr.js@1.9.1: + /ipaddr.js/1.9.1: resolution: {integrity: sha512-0KI/607xoxSToH7GjN1FfSbLoU0+btTicjsQSWQlh/hZykN8KpmMf7uYwPW3R+akZ6R/w18ZlXSHBYXiYUPO3g==} engines: {node: '>= 0.10'} dev: true - /is-absolute-url@3.0.3: + /is-absolute-url/3.0.3: resolution: {integrity: sha512-opmNIX7uFnS96NtPmhWQgQx6/NYFgsUXYMllcfzwWKUMwfo8kku1TvE6hkNcH+Q1ts5cMVrsY7j0bxXQDciu9Q==} engines: {node: '>=8'} dev: true - /is-accessor-descriptor@0.1.6: + /is-accessor-descriptor/0.1.6: resolution: {integrity: sha512-e1BM1qnDbMRG3ll2U9dSK0UMHuWOs3pY3AtcFsmvwPtKL3MML/Q86i+GilLfvqEs4GW+ExB91tQ3Ig9noDIZ+A==} engines: {node: '>=0.10.0'} dependencies: kind-of: 3.2.2 dev: true - /is-accessor-descriptor@1.0.0: + /is-accessor-descriptor/1.0.0: resolution: {integrity: sha512-m5hnHTkcVsPfqx3AKlyttIPb7J+XykHvJP2B9bZDjlhLIoEq4XoK64Vg7boZlVWYK6LUY94dYPEE7Lh0ZkZKcQ==} engines: {node: '>=0.10.0'} dependencies: kind-of: 6.0.3 dev: true - /is-alphabetical@1.0.4: + /is-alphabetical/1.0.4: resolution: {integrity: sha512-DwzsA04LQ10FHTZuL0/grVDk4rFoVH1pjAToYwBrHSxcrBIGQuXrQMtD5U1b0U2XVgKZCTLLP8u2Qxqhy3l2Vg==} dev: true - /is-alphanumerical@1.0.4: + /is-alphanumerical/1.0.4: resolution: {integrity: sha512-UzoZUr+XfVz3t3v4KyGEniVL9BDRoQtY7tOyrRybkVNjDFWyo1yhXNGrrBTQxp3ib9BLAWs7k2YKBQsFRkZG9A==} dependencies: is-alphabetical: 1.0.4 is-decimal: 1.0.4 dev: true - /is-arguments@1.1.1: + /is-arguments/1.1.1: resolution: {integrity: sha512-8Q7EARjzEnKpt/PCD7e1cgUS0a6X8u5tdSiMqXhojOdoV9TsMsiO+9VLC5vAmO8N7/GmXn7yjR8qnA6bVAEzfA==} engines: {node: '>= 0.4'} dependencies: @@ -16711,28 +14524,28 @@ packages: has-tostringtag: 1.0.0 dev: true - /is-array-buffer@3.0.2: + /is-array-buffer/3.0.2: resolution: {integrity: sha512-y+FyyR/w8vfIRq4eQcM1EYgSTnmHXPqaF+IgzgraytCFq5Xh8lllDVmAZolPJiZttZLeFSINPYMaEJ7/vWUa1w==} dependencies: call-bind: 1.0.2 - get-intrinsic: 1.2.0 + get-intrinsic: 1.2.1 is-typed-array: 1.1.10 dev: true - /is-arrayish@0.2.1: + /is-arrayish/0.2.1: resolution: {integrity: sha512-zz06S8t0ozoDXMG+ube26zeCTNXcKIPJZJi8hBrF4idCLms4CG9QtK7qBl1boi5ODzFpjswb5JPmHCbMpjaYzg==} - /is-arrayish@0.3.2: + /is-arrayish/0.3.2: resolution: {integrity: sha512-eVRqCvVlZbuw3GrM63ovNSNAeA1K16kaR/LRY/92w0zxQ5/1YzwblUX652i4Xs9RwAGjW9d9y6X88t8OaAJfWQ==} dev: true - /is-bigint@1.0.4: + /is-bigint/1.0.4: resolution: {integrity: sha512-zB9CruMamjym81i2JZ3UMn54PKGsQzsJeo6xvN3HJJ4CAsQNB6iRutp2To77OfCNuoxspsIhzaPoO1zyCEhFOg==} dependencies: has-bigints: 1.0.2 dev: true - /is-binary-path@1.0.1: + /is-binary-path/1.0.1: resolution: {integrity: sha512-9fRVlXc0uCxEDj1nQzaWONSpbTfx0FmJfzHF7pwlI8DkWGoHBBea4Pg5Ky0ojwwxQmnSifgbKkI06Qv0Ljgj+Q==} engines: {node: '>=0.10.0'} dependencies: @@ -16740,14 +14553,14 @@ packages: dev: true optional: true - /is-binary-path@2.1.0: + /is-binary-path/2.1.0: resolution: {integrity: sha512-ZMERYes6pDydyuGidse7OsHxtbI7WVeUEozgR/g7rd0xUimYNlvZRE/K2MgZTjWy725IfelLeVcEM97mmtRGXw==} engines: {node: '>=8'} dependencies: binary-extensions: 2.2.0 dev: true - /is-boolean-object@1.1.2: + /is-boolean-object/1.1.2: resolution: {integrity: sha512-gDYaKHJmnj4aWxyj6YHyXVpdQawtVLHU5cb+eztPGczf6cjuTdwve5ZIEfgXqH4e57An1D1AKf8CZ3kYrQRqYA==} engines: {node: '>= 0.4'} dependencies: @@ -16755,77 +14568,72 @@ packages: has-tostringtag: 1.0.0 dev: true - /is-buffer@1.1.6: + /is-buffer/1.1.6: resolution: {integrity: sha512-NcdALwpXkTm5Zvvbk7owOUSvVvBKDgKP5/ewfXEznmQFfs4ZRmanOeKBTjRVjka3QFoN6XJ+9F3USqfHqTaU5w==} dev: true - /is-buffer@2.0.5: + /is-buffer/2.0.5: resolution: {integrity: sha512-i2R6zNFDwgEHJyQUtJEk0XFi1i0dPFn/oqjK3/vPCcDeJvW5NQ83V8QbicfF1SupOaB0h8ntgBC2YiE7dfyctQ==} engines: {node: '>=4'} dev: true - /is-builtin-module@3.2.1: + /is-builtin-module/3.2.1: resolution: {integrity: sha512-BSLE3HnV2syZ0FK0iMA/yUGplUeMmNz4AW5fnTunbCIqZi4vG3WjJT9FHMy5D69xmAYBHXQhJdALdpwVxV501A==} engines: {node: '>=6'} dependencies: builtin-modules: 3.3.0 dev: true - /is-callable@1.2.4: - resolution: {integrity: sha512-nsuwtxZfMX67Oryl9LCQ+upnC0Z0BgpwntpS89m1H/TLF0zNfzfLMV/9Wa/6MZsj0acpEjAO0KF1xT6ZdLl95w==} - engines: {node: '>= 0.4'} - dev: true - - /is-callable@1.2.7: + /is-callable/1.2.7: resolution: {integrity: sha512-1BC0BVFhS/p0qtw6enp8e+8OD0UrK0oFLztSjNzhcKA3WDuJxxAPXzPuPtKkjEY9UUoEWlX/8fgKeu2S8i9JTA==} engines: {node: '>= 0.4'} dev: true - /is-ci@2.0.0: + /is-ci/2.0.0: resolution: {integrity: sha512-YfJT7rkpQB0updsdHLGWrvhBJfcfzNNawYDNIyQXJz0IViGf75O8EBPKSdvw2rF+LGCsX4FZ8tcr3b19LcZq4w==} hasBin: true dependencies: ci-info: 2.0.0 dev: true - /is-ci@3.0.1: + /is-ci/3.0.1: resolution: {integrity: sha512-ZYvCgrefwqoQ6yTyYUbQu64HsITZ3NfKX1lzaEYdkTDcfKzzCI/wthRRYKkdjHKFVgNiXKAKm65Zo1pk2as/QQ==} hasBin: true dependencies: ci-info: 3.8.0 dev: true - /is-core-module@2.12.1: + /is-core-module/2.12.1: resolution: {integrity: sha512-Q4ZuBAe2FUsKtyQJoQHlvP8OvBERxO3jEmy1I7hcRXcJBGGHFh/aJBswbXuS9sgrDH2QUO8ilkwNPHvHMd8clg==} dependencies: has: 1.0.3 - /is-data-descriptor@0.1.4: + /is-data-descriptor/0.1.4: resolution: {integrity: sha512-+w9D5ulSoBNlmw9OHn3U2v51SyoCd0he+bB3xMl62oijhrspxowjU+AIcDY0N3iEJbUEkB15IlMASQsxYigvXg==} engines: {node: '>=0.10.0'} dependencies: kind-of: 3.2.2 dev: true - /is-data-descriptor@1.0.0: + /is-data-descriptor/1.0.0: resolution: {integrity: sha512-jbRXy1FmtAoCjQkVmIVYwuuqDFUbaOeDjmed1tOGPrsMhtJA4rD9tkgA0F1qJ3gRFRXcHYVkdeaP50Q5rE/jLQ==} engines: {node: '>=0.10.0'} dependencies: kind-of: 6.0.3 dev: true - /is-date-object@1.0.5: + /is-date-object/1.0.5: resolution: {integrity: sha512-9YQaSxsAiSwcvS33MBk3wTCVnWK+HhF8VZR2jRxehM16QcVOdHqPn4VPHmRK4lSr38n9JriurInLcP90xsYNfQ==} engines: {node: '>= 0.4'} dependencies: has-tostringtag: 1.0.0 dev: true - /is-decimal@1.0.4: + /is-decimal/1.0.4: resolution: {integrity: sha512-RGdriMmQQvZ2aqaQq3awNA6dCGtKpiDFcOzrTWrDAT2MiWrKQVPmxLGHl7Y2nNu6led0kEyoX0enY0qXYsv9zw==} dev: true - /is-descriptor@0.1.6: + /is-descriptor/0.1.6: resolution: {integrity: sha512-avDYr0SB3DwO9zsMov0gKCESFYqCnE4hq/4z3TdUlukEy5t9C0YRq7HLrsN52NAcqXKaepeCD0n+B0arnVG3Hg==} engines: {node: '>=0.10.0'} dependencies: @@ -16834,7 +14642,7 @@ packages: kind-of: 5.1.0 dev: true - /is-descriptor@1.0.2: + /is-descriptor/1.0.2: resolution: {integrity: sha512-2eis5WqQGV7peooDyLmNEPUrps9+SXX5c9pL3xEB+4e9HnGuDa7mB7kHxHw4CbqS9k1T2hOH3miL8n8WtiYVtg==} engines: {node: '>=0.10.0'} dependencies: @@ -16843,189 +14651,180 @@ packages: kind-of: 6.0.3 dev: true - /is-docker@2.2.1: + /is-docker/2.2.1: resolution: {integrity: sha512-F+i2BKsFrH66iaUFc0woD8sLy8getkwTwtOBjvs56Cx4CgJDeKQeqfz8wAYiSb8JOprWhHH5p77PbmYCvvUuXQ==} engines: {node: '>=8'} hasBin: true dev: true - /is-dom@1.1.0: + /is-dom/1.1.0: resolution: {integrity: sha512-u82f6mvhYxRPKpw8V1N0W8ce1xXwOrQtgGcxl6UCL5zBmZu3is/18K0rR7uFCnMDuAsS/3W54mGL4vsaFUQlEQ==} dependencies: is-object: 1.0.2 is-window: 1.0.2 dev: true - /is-extendable@0.1.1: + /is-extendable/0.1.1: resolution: {integrity: sha512-5BMULNob1vgFX6EjQw5izWDxrecWK9AM72rugNr0TFldMOi0fj6Jk+zeKIt0xGj4cEfQIJth4w3OKWOJ4f+AFw==} engines: {node: '>=0.10.0'} dev: true - /is-extendable@1.0.1: + /is-extendable/1.0.1: resolution: {integrity: sha512-arnXMxT1hhoKo9k1LZdmlNyJdDDfy2v0fXjFlmok4+i8ul/6WlbVge9bhM74OpNPQPMGUToDtz+KXa1PneJxOA==} engines: {node: '>=0.10.0'} dependencies: is-plain-object: 2.0.4 dev: true - /is-extglob@2.1.1: + /is-extglob/2.1.1: resolution: {integrity: sha512-SbKbANkN603Vi4jEZv49LeVJMn4yGwsbzZworEoyEiutsN3nJYdbO36zfhGJ6QEDpOZIFkDtnq5JRxmvl3jsoQ==} engines: {node: '>=0.10.0'} - /is-finite@1.1.0: + /is-finite/1.1.0: resolution: {integrity: sha512-cdyMtqX/BOqqNBBiKlIVkytNHm49MtMlYyn1zxzvJKWmFMlGzm+ry5BBfYyeY9YmNKbRSo/o7OX9w9ale0wg3w==} engines: {node: '>=0.10.0'} dev: true optional: true - /is-fullwidth-code-point@3.0.0: + /is-fullwidth-code-point/3.0.0: resolution: {integrity: sha512-zymm5+u+sCsSWyD9qNaejV3DFvhCKclKdizYaJUuHA83RLjb7nSuGnddCHGv0hk+KY7BMAlsWeK4Ueg6EV6XQg==} engines: {node: '>=8'} dev: true - /is-fullwidth-code-point@4.0.0: + /is-fullwidth-code-point/4.0.0: resolution: {integrity: sha512-O4L094N2/dZ7xqVdrXhh9r1KODPJpFms8B5sGdJLPy664AgvXsreZUyCQQNItZRDlYug4xStLjNp/sz3HvBowQ==} engines: {node: '>=12'} dev: true - /is-function@1.0.2: + /is-function/1.0.2: resolution: {integrity: sha512-lw7DUp0aWXYg+CBCN+JKkcE0Q2RayZnSvnZBlwgxHBQhqt5pZNVy4Ri7H9GmmXkdu7LUthszM+Tor1u/2iBcpQ==} dev: true - /is-generator-fn@2.1.0: - resolution: {integrity: sha512-cTIB4yPYL/Grw0EaSzASzg6bBy9gqCofvWN8okThAYIxKJZC+udlRAmGbM0XLeniEJSs8uEgHPGuHSe1XsOLSQ==} - engines: {node: '>=6'} - dev: true - - /is-generator-function@1.0.10: + /is-generator-function/1.0.10: resolution: {integrity: sha512-jsEjy9l3yiXEQ+PsXdmBwEPcOxaXWLspKdplFUVI9vq1iZgIekeC0L167qeu86czQaxed3q/Uzuw0swL0irL8A==} engines: {node: '>= 0.4'} dependencies: has-tostringtag: 1.0.0 dev: true - /is-glob@3.1.0: + /is-glob/3.1.0: resolution: {integrity: sha512-UFpDDrPgM6qpnFNI+rh/p3bUaq9hKLZN8bMUWzxmcnZVS3omf4IPK+BrewlnWjO1WmUsMYuSjKh4UJuV4+Lqmw==} engines: {node: '>=0.10.0'} dependencies: is-extglob: 2.1.1 dev: true - /is-glob@4.0.3: + /is-glob/4.0.3: resolution: {integrity: sha512-xelSayHH36ZgE7ZWhli7pW34hNbNl8Ojv5KVmkJD4hBdD3th8Tfk9vYasLM+mXWOZhFkgZfxhLSnrwRr4elSSg==} engines: {node: '>=0.10.0'} dependencies: is-extglob: 2.1.1 - /is-hexadecimal@1.0.4: + /is-hexadecimal/1.0.4: resolution: {integrity: sha512-gyPJuv83bHMpocVYoqof5VDiZveEoGoFL8m3BXNb2VW8Xs+rz9kqO8LOQ5DH6EsuvilT1ApazU0pyl+ytbPtlw==} dev: true - /is-installed-globally@0.4.0: + /is-installed-globally/0.4.0: resolution: {integrity: sha512-iwGqO3J21aaSkC7jWnHP/difazwS7SFeIqxv6wEtLU8Y5KlzFTjyqcSIT0d8s4+dDhKytsk9PJZ2BkS5eZwQRQ==} engines: {node: '>=10'} dependencies: - global-dirs: 3.0.0 + global-dirs: 3.0.1 is-path-inside: 3.0.3 dev: true - /is-interactive@1.0.0: + /is-interactive/1.0.0: resolution: {integrity: sha512-2HvIEKRoqS62guEC+qBjpvRubdX910WCMuJTZ+I9yvqKU2/12eSL549HMwtabb4oupdj2sMP50k+XJfB/8JE6w==} engines: {node: '>=8'} dev: true - /is-map@2.0.2: + /is-map/2.0.2: resolution: {integrity: sha512-cOZFQQozTha1f4MxLFzlgKYPTyj26picdZTx82hbc/Xf4K/tZOOXSCkMvU4pKioRXGDLJRn0GM7Upe7kR721yg==} dev: true - /is-module@1.0.0: + /is-module/1.0.0: resolution: {integrity: sha512-51ypPSPCoTEIN9dy5Oy+h4pShgJmPCygKfyRCISBI+JoWT/2oJvK8QPxmwv7b/p239jXrm9M1mlQbyKJ5A152g==} dev: true - /is-negative-zero@2.0.2: + /is-negative-zero/2.0.2: resolution: {integrity: sha512-dqJvarLawXsFbNDeJW7zAz8ItJ9cd28YufuuFzh0G8pNHjJMnY08Dv7sYX2uF5UpQOwieAeOExEYAWWfu7ZZUA==} engines: {node: '>= 0.4'} dev: true - /is-node-process@1.0.1: - resolution: {integrity: sha512-5IcdXuf++TTNt3oGl9EBdkvndXA8gmc4bz/Y+mdEpWh3Mcn/+kOw6hI7LD5CocqJWMzeb0I0ClndRVNdEPuJXQ==} - dev: true - - /is-node-process@1.2.0: + /is-node-process/1.2.0: resolution: {integrity: sha512-Vg4o6/fqPxIjtxgUH5QLJhwZ7gW5diGCVlXpuUfELC62CuxM1iHcRe51f2W1FDy04Ai4KJkagKjx3XaqyfRKXw==} dev: true - /is-number-object@1.0.7: + /is-number-object/1.0.7: resolution: {integrity: sha512-k1U0IRzLMo7ZlYIfzRu23Oh6MiIFasgpb9X76eqfFZAqwH44UI4KTBvBYIZ1dSL9ZzChTB9ShHfLkR4pdW5krQ==} engines: {node: '>= 0.4'} dependencies: has-tostringtag: 1.0.0 dev: true - /is-number@3.0.0: + /is-number/3.0.0: resolution: {integrity: sha512-4cboCqIpliH+mAvFNegjZQ4kgKc3ZUhQVr3HvWbSh5q3WH2v82ct+T2Y1hdU5Gdtorx/cLifQjqCbL7bpznLTg==} engines: {node: '>=0.10.0'} dependencies: kind-of: 3.2.2 dev: true - /is-number@7.0.0: + /is-number/7.0.0: resolution: {integrity: sha512-41Cifkg6e8TylSpdtTpeLVMqvSBEVzTttHvERD741+pnZ8ANv0004MRL43QKPDlK9cGvNp6NZWZUBlbGXYxxng==} engines: {node: '>=0.12.0'} - /is-obj@1.0.1: + /is-obj/1.0.1: resolution: {integrity: sha512-l4RyHgRqGN4Y3+9JHVrNqO+tN0rV5My76uW5/nuO4K1b6vw5G8d/cmFjP9tRfEsdhZNt0IFdZuK/c2Vr4Nb+Qg==} engines: {node: '>=0.10.0'} dev: true - /is-object@1.0.2: + /is-object/1.0.2: resolution: {integrity: sha512-2rRIahhZr2UWb45fIOuvZGpFtz0TyOZLf32KxBbSoUCeZR495zCKlWUKKUByk3geS2eAs7ZAABt0Y/Rx0GiQGA==} dev: true - /is-path-inside@3.0.3: + /is-path-inside/3.0.3: resolution: {integrity: sha512-Fd4gABb+ycGAmKou8eMftCupSir5lRxqf4aD/vd0cD2qc4HL07OjCeuHMr8Ro4CoMaeCKDB0/ECBOVWjTwUvPQ==} engines: {node: '>=8'} dev: true - /is-plain-obj@2.1.0: + /is-plain-obj/2.1.0: resolution: {integrity: sha512-YWnfyRwxL/+SsrWYfOpUtz5b3YD+nyfkHvjbcanzk8zgyO4ASD67uVMRt8k5bM4lLMDnXfriRhOpemw+NfT1eA==} engines: {node: '>=8'} dev: true - /is-plain-obj@4.1.0: + /is-plain-obj/4.1.0: resolution: {integrity: sha512-+Pgi+vMuUNkJyExiMBt5IlFoMyKnr5zhJ4Uspz58WOhBF5QoIZkFyNHIbBAtHwzVAgk5RtndVNsDRN61/mmDqg==} engines: {node: '>=12'} dev: true - /is-plain-object@2.0.4: + /is-plain-object/2.0.4: resolution: {integrity: sha512-h5PpgXkWitc38BBMYawTYMWJHFZJVnBquFE57xFpjB8pJFiF6gZ+bU+WyI/yqXiFR5mdLsgYNaPe8uao6Uv9Og==} engines: {node: '>=0.10.0'} dependencies: isobject: 3.0.1 dev: true - /is-plain-object@5.0.0: + /is-plain-object/5.0.0: resolution: {integrity: sha512-VRSzKkbMm5jMDoKLbltAkFQ5Qr7VDiTFGXxYFXXowVj387GeGNOCsOH6Msy00SGZ3Fp84b1Naa1psqgcCIEP5Q==} engines: {node: '>=0.10.0'} dev: true - /is-potential-custom-element-name@1.0.1: + /is-potential-custom-element-name/1.0.1: resolution: {integrity: sha512-bCYeRA2rVibKZd+s2625gGnGF/t7DSqDs4dP7CrLA1m7jKWz6pps0LpYLJN8Q64HtmPKJ1hrN3nzPNKFEKOUiQ==} dev: true - /is-reference@1.2.1: + /is-reference/1.2.1: resolution: {integrity: sha512-U82MsXXiFIrjCK4otLT+o2NA2Cd2g5MLoOVXUZjIOhLurrRxpEXzI8O0KZHr3IjLvlAH1kTPYSuqer5T9ZVBKQ==} dependencies: '@types/estree': 1.0.1 dev: true - /is-reference@3.0.1: + /is-reference/3.0.1: resolution: {integrity: sha512-baJJdQLiYaJdvFbJqXrcGv3WU3QCzBlUcI5QhbesIm6/xPsvmO+2CDoi/GMOFBQEQm+PXkwOPrp9KK5ozZsp2w==} dependencies: '@types/estree': 1.0.1 dev: true - /is-regex@1.1.4: + /is-regex/1.1.4: resolution: {integrity: sha512-kvRdxDsxZjhzUX07ZnLydzS1TU/TJlTUHHY4YLL87e37oUA49DfkLqgy+VjFocowy29cKvcSiu+kIv728jTTVg==} engines: {node: '>= 0.4'} dependencies: @@ -17033,55 +14832,55 @@ packages: has-tostringtag: 1.0.0 dev: true - /is-regexp@1.0.0: + /is-regexp/1.0.0: resolution: {integrity: sha512-7zjFAPO4/gwyQAAgRRmqeEeyIICSdmCqa3tsVHMdBzaXXRiqopZL4Cyghg/XulGWrtABTpbnYYzzIRffLkP4oA==} engines: {node: '>=0.10.0'} dev: true - /is-set@2.0.2: + /is-set/2.0.2: resolution: {integrity: sha512-+2cnTEZeY5z/iXGbLhPrOAaK/Mau5k5eXq9j14CpRTftq0pAJu2MwVRSZhyZWBzx3o6X795Lz6Bpb6R0GKf37g==} dev: true - /is-shared-array-buffer@1.0.2: + /is-shared-array-buffer/1.0.2: resolution: {integrity: sha512-sqN2UDu1/0y6uvXyStCOzyhAjCSlHceFoMKJW8W9EU9cvic/QdsZ0kEU93HEy3IUEFZIiH/3w+AH/UQbPHNdhA==} dependencies: call-bind: 1.0.2 dev: true - /is-stream@1.1.0: + /is-stream/1.1.0: resolution: {integrity: sha512-uQPm8kcs47jx38atAcWTVxyltQYoPT68y9aWYdV6yWXSyW8mzSat0TL6CiWdZeCdF3KrAvpVtnHbTv4RN+rqdQ==} engines: {node: '>=0.10.0'} dev: true - /is-stream@2.0.1: + /is-stream/2.0.1: resolution: {integrity: sha512-hFoiJiTl63nn+kstHGBtewWSKnQLpyb155KHheA1l39uvtO9nWIop1p3udqPcUd/xbF1VLMO4n7OI6p7RbngDg==} engines: {node: '>=8'} dev: true - /is-stream@3.0.0: + /is-stream/3.0.0: resolution: {integrity: sha512-LnQR4bZ9IADDRSkvpqMGvt/tEJWclzklNgSw48V5EAaAeDd6qGvN8ei6k5p0tvxSR171VmGyHuTiAOfxAbr8kA==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dev: true - /is-string@1.0.7: + /is-string/1.0.7: resolution: {integrity: sha512-tE2UXzivje6ofPW7l23cjDOMa09gb7xlAqG6jG5ej6uPV32TlWP3NKPigtaGeHNu9fohccRYvIiZMfOOnOYUtg==} engines: {node: '>= 0.4'} dependencies: has-tostringtag: 1.0.0 dev: true - /is-subset@0.1.1: + /is-subset/0.1.1: resolution: {integrity: sha512-6Ybun0IkarhmEqxXCNw/C0bna6Zb/TkfUX9UbwJtK6ObwAVCxmAP308WWTHviM/zAqXk05cdhYsUsZeGQh99iw==} dev: true - /is-symbol@1.0.4: + /is-symbol/1.0.4: resolution: {integrity: sha512-C/CPBqKWnvdcxqIARxyOh4v1UUEOCHpgDa0WYgpKDFMszcrPcffg5uhwSgPCLD2WWxmq6isisz87tzT01tuGhg==} engines: {node: '>= 0.4'} dependencies: has-symbols: 1.0.3 dev: true - /is-typed-array@1.1.10: + /is-typed-array/1.1.10: resolution: {integrity: sha512-PJqgEHiWZvMpaFZ3uTc8kHPM4+4ADTlDniuQL7cU/UDA0Ql7F70yGfHph3cLNe+c9toaigv+DFzTJKhc2CtO6A==} engines: {node: '>= 0.4'} dependencies: @@ -17092,404 +14891,222 @@ packages: has-tostringtag: 1.0.0 dev: true - /is-typedarray@1.0.0: + /is-typedarray/1.0.0: resolution: {integrity: sha512-cyA56iCMHAh5CdzjJIa4aohJyeO1YbwLi3Jc35MmRU6poroFjIGZzUzupGiRPOjgHg9TLu43xbpwXk523fMxKA==} dev: true - /is-unicode-supported@0.1.0: + /is-unicode-supported/0.1.0: resolution: {integrity: sha512-knxG2q4UC3u8stRGyAVJCOdxFmv5DZiRcdlIaAQXAbSfJya+OhopNotLQrstBhququ4ZpuKbDc/8S6mgXgPFPw==} engines: {node: '>=10'} dev: true - /is-unicode-supported@1.3.0: + /is-unicode-supported/1.3.0: resolution: {integrity: sha512-43r2mRvz+8JRIKnWJ+3j8JtjRKZ6GmjzfaE/qiBJnikNnYv/6bagRJ1kUhNk8R5EX/GkobD+r+sfxCPJsiKBLQ==} engines: {node: '>=12'} dev: true - /is-utf8@0.2.1: + /is-utf8/0.2.1: resolution: {integrity: sha512-rMYPYvCzsXywIsldgLaSoPlw5PfoB/ssr7hY4pLfcodrA5M/eArza1a9VmTiNIBNMjOGr1Ow9mTyU2o69U6U9Q==} dev: true optional: true - /is-weakmap@2.0.1: + /is-weakmap/2.0.1: resolution: {integrity: sha512-NSBR4kH5oVj1Uwvv970ruUkCV7O1mzgVFO4/rev2cLRda9Tm9HrL70ZPut4rOHgY0FNrUu9BCbXA2sdQ+x0chA==} dev: true - /is-weakref@1.0.2: + /is-weakref/1.0.2: resolution: {integrity: sha512-qctsuLZmIQ0+vSSMfoVvyFe2+GSEvnmZ2ezTup1SBse9+twCCeial6EEi3Nc2KFcf6+qz2FBPnjXsk8xhKSaPQ==} dependencies: call-bind: 1.0.2 dev: true - /is-weakset@2.0.2: + /is-weakset/2.0.2: resolution: {integrity: sha512-t2yVvttHkQktwnNNmBQ98AhENLdPUTDTE21uPqAQ0ARwQfGeQKRVS0NNurH7bTf7RrvcVn1OOge45CnBeHCSmg==} dependencies: call-bind: 1.0.2 - get-intrinsic: 1.2.0 + get-intrinsic: 1.2.1 dev: true - /is-what@4.1.8: - resolution: {integrity: sha512-yq8gMao5upkPoGEU9LsB2P+K3Kt8Q3fQFCGyNCWOAnJAMzEXVV9drYb0TXr42TTliLLhKIBvulgAXgtLLnwzGA==} + /is-what/4.1.15: + resolution: {integrity: sha512-uKua1wfy3Yt+YqsD6mTUEa2zSi3G1oPlqTflgaPJ7z63vUGN5pxFpnQfeSLMFnJDEsdvOtkp1rUWkYjB4YfhgA==} engines: {node: '>=12.13'} dev: true - /is-whitespace-character@1.0.4: + /is-whitespace-character/1.0.4: resolution: {integrity: sha512-SDweEzfIZM0SJV0EUga669UTKlmL0Pq8Lno0QDQsPnvECB3IM2aP0gdx5TrU0A01MAPfViaZiI2V1QMZLaKK5w==} dev: true - /is-whitespace@0.3.0: + /is-whitespace/0.3.0: resolution: {integrity: sha512-RydPhl4S6JwAyj0JJjshWJEFG6hNye3pZFBRZaTUfZFwGHxzppNaNOVgQuS/E/SlhrApuMXrpnK1EEIXfdo3Dg==} engines: {node: '>=0.10.0'} dev: true - /is-window@1.0.2: + /is-window/1.0.2: resolution: {integrity: sha512-uj00kdXyZb9t9RcAUAwMZAnkBUwdYGhYlt7djMXhfyhUCzwNba50tIiBKR7q0l7tdoBtFVw/3JmLY6fI3rmZmg==} dev: true - /is-windows@1.0.2: + /is-windows/1.0.2: resolution: {integrity: sha512-eXK1UInq2bPmjyX6e3VHIzMLobc4J94i4AWn+Hpq3OU5KkrRC96OAcR3PRJ/pGu6m8TRnBHP9dkXQVsT/COVIA==} engines: {node: '>=0.10.0'} dev: true - /is-word-character@1.0.4: + /is-word-character/1.0.4: resolution: {integrity: sha512-5SMO8RVennx3nZrqtKwCGyyetPE9VDba5ugvKLaD4KopPG5kR4mQ7tNt/r7feL5yt5h3lpuBbIUmCOG2eSzXHA==} dev: true - /is-wsl@1.1.0: + /is-wsl/1.1.0: resolution: {integrity: sha512-gfygJYZ2gLTDlmbWMI0CE2MwnFzSN/2SZfkMlItC4K/JBlsWVDB0bO6XhqcY13YXE7iMcAJnzTCJjPiTeJJ0Mw==} engines: {node: '>=4'} dev: true - /is-wsl@2.2.0: + /is-wsl/2.2.0: resolution: {integrity: sha512-fKzAra0rGJUUBwGBgNkHZuToZcn+TtXHpeCgmkMJMMYx1sQDYaCSyjJBSCa2nH1DGm7s3n1oBnohoVTBaN7Lww==} engines: {node: '>=8'} dependencies: is-docker: 2.2.1 dev: true - /isarray@1.0.0: + /isarray/1.0.0: resolution: {integrity: sha512-VLghIWNM6ELQzo7zwmcg0NmTVyWKYjvIeM83yjp0wRDTmUnrM678fQbcKBo6n2CJEF0szoG//ytg+TKla89ALQ==} dev: true - /isarray@2.0.5: + /isarray/2.0.5: resolution: {integrity: sha512-xHjhDr3cNBK0BzdUJSPXZntQUx/mwMS5Rw4A7lPJ90XGAO6ISP/ePDNuo0vhqOZU+UD5JoodwCAAoZQd3FeAKw==} dev: true - /isexe@2.0.0: + /isexe/2.0.0: resolution: {integrity: sha512-RHxMLp9lnKHGHRng9QFhRCMbYAcVpn69smSGcq3f36xjgVVWThj4qqLbTLlq7Ssj8B+fIQ1EuCEGI2lKsyQeIw==} dev: true - /isobject@2.1.0: + /isobject/2.1.0: resolution: {integrity: sha512-+OUdGJlgjOBZDfxnDjYYG6zp487z0JGNQq3cYQYg5f5hKR+syHMsaztzGeml/4kGG55CSpKSpWTY+jYGgsHLgA==} engines: {node: '>=0.10.0'} dependencies: isarray: 1.0.0 dev: true - /isobject@3.0.1: + /isobject/3.0.1: resolution: {integrity: sha512-WhB9zCku7EGTj/HQQRz5aUQEUeoQZH2bWcltRErOpymJ4boYE6wL9Tbr23krRPSZ+C5zqNSrSw+Cc7sZZ4b7vg==} engines: {node: '>=0.10.0'} dev: true - /isobject@4.0.0: + /isobject/4.0.0: resolution: {integrity: sha512-S/2fF5wH8SJA/kmwr6HYhK/RI/OkhD84k8ntalo0iJjZikgq1XFvR5M8NPT1x5F7fBwCG3qHfnzeP/Vh/ZxCUA==} engines: {node: '>=0.10.0'} dev: true - /isomorphic-unfetch@3.1.0: + /isomorphic-unfetch/3.1.0: resolution: {integrity: sha512-geDJjpoZ8N0kWexiwkX8F9NkTsXhetLPVbZFQ+JTW239QNOwvB0gniuR1Wc6f0AMTn7/mFGyXvHTifrCp/GH8Q==} dependencies: - node-fetch: 2.6.11 + node-fetch: 2.6.12 unfetch: 4.2.0 transitivePeerDependencies: - encoding dev: true - /isstream@0.1.2: + /isstream/0.1.2: resolution: {integrity: sha512-Yljz7ffyPbrLpLngrMtZ7NduUgVvi6wG9RJ9IUcyCd59YQ911PBJphODUcbOVbqYfxe1wuYf/LJ8PauMRwsM/g==} dev: true - /istanbul-lib-coverage@3.2.0: + /istanbul-lib-coverage/3.2.0: resolution: {integrity: sha512-eOeJ5BHCmHYvQK7xt9GkdHuzuCGS1Y6g9Gvnx3Ym33fz/HpLRYxiS0wHNr+m/MBC8B647Xt608vCDEvhl9c6Mw==} engines: {node: '>=8'} - /istanbul-lib-instrument@5.2.1: + /istanbul-lib-instrument/5.2.1: resolution: {integrity: sha512-pzqtp31nLv/XFOzXGuvhCb8qhjmTVo5vjVk19XE4CRlSWz0KoeJ3bw9XsA7nOp9YBf4qHjwBxkDzKcME/J29Yg==} engines: {node: '>=8'} dependencies: - '@babel/core': 7.18.13 - '@babel/parser': 7.18.13 + '@babel/core': 7.22.8 + '@babel/parser': 7.22.7 '@istanbuljs/schema': 0.1.3 istanbul-lib-coverage: 3.2.0 - semver: 6.3.0 + semver: 6.3.1 transitivePeerDependencies: - supports-color dev: true - /istanbul-lib-instrument@6.0.0: - resolution: {integrity: sha512-x58orMzEVfzPUKqlbLd1hXCnySCxKdDKa6Rjg97CwuLLRI4g3FHTdnExu1OqffVFay6zeMW+T6/DowFLndWnIw==} - engines: {node: '>=10'} - dependencies: - '@babel/core': 7.22.5 - '@babel/parser': 7.22.5 - '@istanbuljs/schema': 0.1.3 - istanbul-lib-coverage: 3.2.0 - semver: 7.5.4 - transitivePeerDependencies: - - supports-color - dev: false - - /istanbul-lib-report@3.0.1: - resolution: {integrity: sha512-GCfE1mtsHGOELCU8e/Z7YWzpmybrx/+dSTfLrvY8qRmaY6zXTKWn6WQIjaAFw069icm6GVMNkgu0NzI4iPZUNw==} - engines: {node: '>=10'} + /istanbul-lib-report/3.0.0: + resolution: {integrity: sha512-wcdi+uAKzfiGT2abPpKZ0hSU1rGQjUQnLvtY5MpQ7QCTahD3VODhcu4wcfY1YtkGaDD5yuydOLINXsfbus9ROw==} + engines: {node: '>=8'} dependencies: istanbul-lib-coverage: 3.2.0 make-dir: 4.0.0 supports-color: 7.2.0 - /istanbul-lib-source-maps@4.0.1: + /istanbul-lib-source-maps/4.0.1: resolution: {integrity: sha512-n3s8EwkdFIJCG3BPKBYvskgXGoy88ARzvegkitk60NxRdwltLOTaH7CUiMRXvwYorl0Q712iEjcWB+fK/MrWVw==} engines: {node: '>=10'} - dependencies: - debug: 4.3.4(supports-color@8.1.1) - istanbul-lib-coverage: 3.2.0 - source-map: 0.6.1 - transitivePeerDependencies: - - supports-color - - /istanbul-reports@3.1.5: - resolution: {integrity: sha512-nUsEMa9pBt/NOHqbcbeJEgqIlY/K7rVWUX6Lql2orY5e9roQOthbR3vtY4zzf2orPELg80fnxxk9zUyPlgwD1w==} - engines: {node: '>=8'} - dependencies: - html-escaper: 2.0.2 - istanbul-lib-report: 3.0.1 - - /iterate-iterator@1.0.2: - resolution: {integrity: sha512-t91HubM4ZDQ70M9wqp+pcNpu8OyJ9UAtXntT/Bcsvp5tZMnz9vRa+IunKXeI8AnfZMTv0jNuVEmGeLSMjVvfPw==} - dev: true - - /iterate-value@1.0.2: - resolution: {integrity: sha512-A6fMAio4D2ot2r/TYzr4yUWrmwNdsN5xL7+HUiyACE4DXm+q8HtPcnFTp+NnW3k4N05tZ7FVYFFb2CR13NxyHQ==} - dependencies: - es-get-iterator: 1.1.3 - iterate-iterator: 1.0.2 - dev: true - - /jackspeak@2.1.1: - resolution: {integrity: sha512-juf9stUEwUaILepraGOWIJTLwg48bUnBmRqd2ln2Os1sW987zeoj/hzhbvRB95oMuS2ZTpjULmdwHNX4rzZIZw==} - engines: {node: '>=14'} - dependencies: - cliui: 8.0.1 - optionalDependencies: - '@pkgjs/parseargs': 0.11.0 - dev: true - - /jake@10.8.5: - resolution: {integrity: sha512-sVpxYeuAhWt0OTWITwT98oyV0GsXyMlXCF+3L1SuafBVUIr/uILGRB+NqwkzhgXKvoJpDIpQvqkUALgdmQsQxw==} - engines: {node: '>=10'} - hasBin: true - dependencies: - async: 3.2.4 - chalk: 4.1.2 - filelist: 1.0.4 - minimatch: 3.1.2 - dev: true - - /jest-changed-files@27.5.1: - resolution: {integrity: sha512-buBLMiByfWGCoMsLLzGUUSpAmIAGnbR2KJoMN10ziLhOLvP4e0SlypHnAel8iqQXTrcbmfEY9sSqae5sgUsTvw==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - '@jest/types': 27.5.1 - execa: 5.1.1 - throat: 6.0.2 - dev: true - - /jest-circus@27.5.1: - resolution: {integrity: sha512-D95R7x5UtlMA5iBYsOHFFbMD/GVA4R/Kdq15f7xYWUfWHBto9NYRsOvnSauTgdF+ogCpJ4tyKOXhUifxS65gdw==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - '@jest/environment': 27.5.1 - '@jest/test-result': 27.5.1 - '@jest/types': 27.5.1 - '@types/node': 20.4.1 - chalk: 4.1.2 - co: 4.6.0 - dedent: 0.7.0 - expect: 27.5.1 - is-generator-fn: 2.1.0 - jest-each: 27.5.1 - jest-matcher-utils: 27.5.1 - jest-message-util: 27.5.1 - jest-runtime: 27.5.1 - jest-snapshot: 27.5.1 - jest-util: 27.5.1 - pretty-format: 27.5.1 - slash: 3.0.0 - stack-utils: 2.0.5 - throat: 6.0.2 - transitivePeerDependencies: - - supports-color - dev: true - - /jest-cli@27.5.1(ts-node@10.9.1): - resolution: {integrity: sha512-Hc6HOOwYq4/74/c62dEE3r5elx8wjYqxY0r0G/nFrLDPMFRu6RA/u8qINOIkvhxG7mMQ5EJsOGfRpI8L6eFUVw==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - hasBin: true - peerDependencies: - node-notifier: ^8.0.1 || ^9.0.0 || ^10.0.0 - peerDependenciesMeta: - node-notifier: - optional: true - dependencies: - '@jest/core': 27.5.1(ts-node@10.9.1) - '@jest/test-result': 27.5.1 - '@jest/types': 27.5.1 - chalk: 4.1.2 - exit: 0.1.2 - graceful-fs: 4.2.10 - import-local: 3.1.0 - jest-config: 27.5.1(ts-node@10.9.1) - jest-util: 27.5.1 - jest-validate: 27.5.1 - prompts: 2.4.2 - yargs: 16.2.0 - transitivePeerDependencies: - - bufferutil - - canvas - - supports-color - - ts-node - - utf-8-validate - dev: true - - /jest-config@27.5.1(ts-node@10.9.1): - resolution: {integrity: sha512-5sAsjm6tGdsVbW9ahcChPAFCk4IlkQUknH5AvKjuLTSlcO/wCZKyFdn7Rg0EkC+OGgWODEy2hDpWB1PgzH0JNA==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - peerDependencies: - ts-node: '>=9.0.0' - peerDependenciesMeta: - ts-node: - optional: true - dependencies: - '@babel/core': 7.22.5 - '@jest/test-sequencer': 27.5.1 - '@jest/types': 27.5.1 - babel-jest: 27.5.1(@babel/core@7.22.5) - chalk: 4.1.2 - ci-info: 3.8.0 - deepmerge: 4.3.1 - glob: 7.2.3 - graceful-fs: 4.2.10 - jest-circus: 27.5.1 - jest-environment-jsdom: 27.5.1 - jest-environment-node: 27.5.1 - jest-get-type: 27.5.1 - jest-jasmine2: 27.5.1 - jest-regex-util: 27.5.1 - jest-resolve: 27.5.1 - jest-runner: 27.5.1 - jest-util: 27.5.1 - jest-validate: 27.5.1 - micromatch: 4.0.5 - parse-json: 5.2.0 - pretty-format: 27.5.1 - slash: 3.0.0 - strip-json-comments: 3.1.1 - ts-node: 10.9.1(@types/node@18.16.19)(typescript@5.1.6) + dependencies: + debug: 4.3.4 + istanbul-lib-coverage: 3.2.0 + source-map: 0.6.1 transitivePeerDependencies: - - bufferutil - - canvas - supports-color - - utf-8-validate - dev: true + dev: false - /jest-diff@27.5.1: - resolution: {integrity: sha512-m0NvkX55LDt9T4mctTEgnZk3fmEg3NRYutvMPWM/0iPnkFj2wIeF45O1718cMSOFO1vINkqmxqD8vE37uTEbqw==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + /istanbul-reports/3.1.5: + resolution: {integrity: sha512-nUsEMa9pBt/NOHqbcbeJEgqIlY/K7rVWUX6Lql2orY5e9roQOthbR3vtY4zzf2orPELg80fnxxk9zUyPlgwD1w==} + engines: {node: '>=8'} dependencies: - chalk: 4.1.2 - diff-sequences: 27.5.1 - jest-get-type: 27.5.1 - pretty-format: 27.5.1 - dev: true + html-escaper: 2.0.2 + istanbul-lib-report: 3.0.1 - /jest-diff@29.0.1: - resolution: {integrity: sha512-l8PYeq2VhcdxG9tl5cU78ClAlg/N7RtVSp0v3MlXURR0Y99i6eFnegmasOandyTmO6uEdo20+FByAjBFEO9nuw==} - engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} - dependencies: - chalk: 4.1.2 - diff-sequences: 29.4.3 - jest-get-type: 29.0.0 - pretty-format: 29.5.0 + /iterate-iterator/1.0.2: + resolution: {integrity: sha512-t91HubM4ZDQ70M9wqp+pcNpu8OyJ9UAtXntT/Bcsvp5tZMnz9vRa+IunKXeI8AnfZMTv0jNuVEmGeLSMjVvfPw==} dev: true - /jest-docblock@27.5.1: - resolution: {integrity: sha512-rl7hlABeTsRYxKiUfpHrQrG4e2obOiTQWfMEH3PxPjOtdsfLQO4ReWSZaQ7DETm4xu07rl4q/h4zcKXyU0/OzQ==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + /iterate-value/1.0.2: + resolution: {integrity: sha512-A6fMAio4D2ot2r/TYzr4yUWrmwNdsN5xL7+HUiyACE4DXm+q8HtPcnFTp+NnW3k4N05tZ7FVYFFb2CR13NxyHQ==} dependencies: - detect-newline: 3.1.0 + es-get-iterator: 1.1.3 + iterate-iterator: 1.0.2 dev: true - /jest-each@27.5.1: - resolution: {integrity: sha512-1Ff6p+FbhT/bXQnEouYy00bkNSY7OUpfIcmdl8vZ31A1UUaurOLPA8a8BbJOF2RDUElwJhmeaV7LnagI+5UwNQ==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + /jackspeak/2.2.1: + resolution: {integrity: sha512-MXbxovZ/Pm42f6cDIDkl3xpwv1AGwObKwfmjs2nQePiy85tP3fatofl3FC1aBsOtP/6fq5SbtgHwWcMsLP+bDw==} + engines: {node: '>=14'} dependencies: - '@jest/types': 27.5.1 - chalk: 4.1.2 - jest-get-type: 27.5.1 - jest-util: 27.5.1 - pretty-format: 27.5.1 + '@isaacs/cliui': 8.0.2 + optionalDependencies: + '@pkgjs/parseargs': 0.11.0 dev: true - /jest-environment-jsdom@27.5.1: - resolution: {integrity: sha512-TFBvkTC1Hnnnrka/fUb56atfDtJ9VMZ94JkjTbggl1PEpwrYtUBKMezB3inLmWqQsXYLcMwNoDQwoBTAvFfsfw==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + /jake/10.8.7: + resolution: {integrity: sha512-ZDi3aP+fG/LchyBzUM804VjddnwfSfsdeYkwt8NcbKRvo4rFkjhs456iLFn3k2ZUWvNe4i48WACDbza8fhq2+w==} + engines: {node: '>=10'} + hasBin: true dependencies: - '@jest/environment': 27.5.1 - '@jest/fake-timers': 27.5.1 - '@jest/types': 27.5.1 - '@types/node': 20.4.1 - jest-mock: 27.5.1 - jest-util: 27.5.1 - jsdom: 16.7.0 - transitivePeerDependencies: - - bufferutil - - canvas - - supports-color - - utf-8-validate + async: 3.2.4 + chalk: 4.1.2 + filelist: 1.0.4 + minimatch: 3.1.2 dev: true - /jest-environment-node@27.5.1: - resolution: {integrity: sha512-Jt4ZUnxdOsTGwSRAfKEnE6BcwsSPNOijjwifq5sDFSA2kesnXTvNqKHYgM0hDq3549Uf/KzdXNYn4wMZJPlFLw==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + /jest-diff/29.6.1: + resolution: {integrity: sha512-FsNCvinvl8oVxpNLttNQX7FAq7vR+gMDGj90tiP7siWw1UdakWUGqrylpsYrpvj908IYckm5Y0Q7azNAozU1Kg==} + engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: - '@jest/environment': 27.5.1 - '@jest/fake-timers': 27.5.1 - '@jest/types': 27.5.1 - '@types/node': 20.4.1 - jest-mock: 27.5.1 - jest-util: 27.5.1 - dev: true - - /jest-get-type@27.5.1: - resolution: {integrity: sha512-2KY95ksYSaK7DMBWQn6dQz3kqAf3BB64y2udeG+hv4KfSOb9qwcYQstTJc1KCbsix+wLZWZYN8t7nwX3GOBLRw==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + chalk: 4.1.2 + diff-sequences: 29.4.3 + jest-get-type: 29.4.3 + pretty-format: 29.6.1 dev: true - /jest-get-type@29.0.0: - resolution: {integrity: sha512-83X19z/HuLKYXYHskZlBAShO7UfLFXu/vWajw9ZNJASN32li8yHMaVGAQqxFW1RCFOkB7cubaL6FaJVQqqJLSw==} + /jest-get-type/29.4.3: + resolution: {integrity: sha512-J5Xez4nRRMjk8emnTpWrlkyb9pfRQQanDrvWHhsR1+VUfbwxi30eVcZFlcdGInRibU4G5LwHXpI7IRHU0CY+gg==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dev: true - /jest-haste-map@26.6.2: + /jest-haste-map/26.6.2: resolution: {integrity: sha512-easWIJXIw71B2RdR8kgqpjQrbMRWQBgiBwXYEhtGUTaX+doCjBheluShdDMeR8IMfJiTqH4+zfhtg29apJf/8w==} engines: {node: '>= 10.14.2'} dependencies: '@jest/types': 26.6.2 - '@types/graceful-fs': 4.1.5 + '@types/graceful-fs': 4.1.6 '@types/node': 20.4.1 - anymatch: 3.1.2 - fb-watchman: 2.0.1 - graceful-fs: 4.2.10 + anymatch: 3.1.3 + fb-watchman: 2.0.2 + graceful-fs: 4.2.11 jest-regex-util: 26.0.0 jest-serializer: 26.6.2 jest-util: 26.6.2 @@ -17503,27 +15120,7 @@ packages: - supports-color dev: true - /jest-haste-map@27.5.1: - resolution: {integrity: sha512-7GgkZ4Fw4NFbMSDSpZwXeBiIbx+t/46nJ2QitkOjvwPYyZmqttu2TDSimMHP1EkPOi4xUZAN1doE5Vd25H4Jng==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - '@jest/types': 27.5.1 - '@types/graceful-fs': 4.1.5 - '@types/node': 20.4.1 - anymatch: 3.1.2 - fb-watchman: 2.0.1 - graceful-fs: 4.2.10 - jest-regex-util: 27.5.1 - jest-serializer: 27.5.1 - jest-util: 27.5.1 - jest-worker: 27.5.1 - micromatch: 4.0.5 - walker: 1.0.8 - optionalDependencies: - fsevents: 2.3.2 - dev: true - - /jest-image-snapshot@4.5.1(jest@27.5.1): + /jest-image-snapshot/4.5.1: resolution: {integrity: sha512-0YkgupgkkCx0wIZkxvqs/oNiUT0X0d2WTpUhaAp+Dy6CpqBUZMRTIZo4KR1f+dqmx6WXrLCvecjnHLIsLkI+gQ==} engines: {node: '>= 10.14.2'} peerDependencies: @@ -17532,7 +15129,6 @@ packages: chalk: 1.1.3 get-stdin: 5.0.1 glur: 1.1.2 - jest: 27.5.1(ts-node@10.9.1) lodash: 4.17.21 mkdirp: 0.5.6 pixelmatch: 5.3.0 @@ -17541,316 +15137,69 @@ packages: ssim.js: 3.5.0 dev: true - /jest-jasmine2@27.5.1: - resolution: {integrity: sha512-jtq7VVyG8SqAorDpApwiJJImd0V2wv1xzdheGHRGyuT7gZm6gG47QEskOlzsN1PG/6WNaCo5pmwMHDf3AkG2pQ==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - '@jest/environment': 27.5.1 - '@jest/source-map': 27.5.1 - '@jest/test-result': 27.5.1 - '@jest/types': 27.5.1 - '@types/node': 20.4.1 - chalk: 4.1.2 - co: 4.6.0 - expect: 27.5.1 - is-generator-fn: 2.1.0 - jest-each: 27.5.1 - jest-matcher-utils: 27.5.1 - jest-message-util: 27.5.1 - jest-runtime: 27.5.1 - jest-snapshot: 27.5.1 - jest-util: 27.5.1 - pretty-format: 27.5.1 - throat: 6.0.2 - transitivePeerDependencies: - - supports-color - dev: true - - /jest-leak-detector@27.5.1: - resolution: {integrity: sha512-POXfWAMvfU6WMUXftV4HolnJfnPOGEu10fscNCA76KBpRRhcMN2c8d3iT2pxQS3HLbA+5X4sOUPzYO2NUyIlHQ==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - jest-get-type: 27.5.1 - pretty-format: 27.5.1 - dev: true - - /jest-matcher-utils@27.5.1: - resolution: {integrity: sha512-z2uTx/T6LBaCoNWNFWwChLBKYxTMcGBRjAt+2SbP929/Fflb9aa5LGma654Rz8z9HLxsrUaYzxE9T/EFIL/PAw==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - chalk: 4.1.2 - jest-diff: 27.5.1 - jest-get-type: 27.5.1 - pretty-format: 27.5.1 - dev: true - - /jest-matcher-utils@29.0.1: - resolution: {integrity: sha512-/e6UbCDmprRQFnl7+uBKqn4G22c/OmwriE5KCMVqxhElKCQUDcFnq5XM9iJeKtzy4DUjxT27y9VHmKPD8BQPaw==} + /jest-matcher-utils/29.6.1: + resolution: {integrity: sha512-SLaztw9d2mfQQKHmJXKM0HCbl2PPVld/t9Xa6P9sgiExijviSp7TnZZpw2Fpt+OI3nwUO/slJbOfzfUMKKC5QA==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: chalk: 4.1.2 - jest-diff: 29.0.1 - jest-get-type: 29.0.0 - pretty-format: 29.5.0 + jest-diff: 29.6.1 + jest-get-type: 29.4.3 + pretty-format: 29.6.1 dev: true - /jest-message-util@27.5.1: - resolution: {integrity: sha512-rMyFe1+jnyAAf+NHwTclDz0eAaLkVDdKVHHBFWsBWHnnh5YeJMNWWsv7AbFYXfK3oTqvL7VTWkhNLu1jX24D+g==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - '@babel/code-frame': 7.22.5 - '@jest/types': 27.5.1 - '@types/stack-utils': 2.0.1 - chalk: 4.1.2 - graceful-fs: 4.2.10 - micromatch: 4.0.5 - pretty-format: 27.5.1 - slash: 3.0.0 - stack-utils: 2.0.5 - dev: true - - /jest-message-util@29.0.1: - resolution: {integrity: sha512-wRMAQt3HrLpxSubdnzOo68QoTfQ+NLXFzU0Heb18ZUzO2S9GgaXNEdQ4rpd0fI9dq2NXkpCk1IUWSqzYKji64A==} + /jest-message-util/29.6.1: + resolution: {integrity: sha512-KoAW2zAmNSd3Gk88uJ56qXUWbFk787QKmjjJVOjtGFmmGSZgDBrlIL4AfQw1xyMYPNVD7dNInfIbur9B2rd/wQ==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: '@babel/code-frame': 7.22.5 - '@jest/types': 29.0.1 + '@jest/types': 29.6.1 '@types/stack-utils': 2.0.1 chalk: 4.1.2 - graceful-fs: 4.2.10 + graceful-fs: 4.2.11 micromatch: 4.0.5 - pretty-format: 29.5.0 + pretty-format: 29.6.1 slash: 3.0.0 - stack-utils: 2.0.5 - dev: true - - /jest-mock@27.5.1: - resolution: {integrity: sha512-K4jKbY1d4ENhbrG2zuPWaQBvDly+iZ2yAW+T1fATN78hc0sInwn7wZB8XtlNnvHug5RMwV897Xm4LqmPM4e2Og==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - '@jest/types': 27.5.1 - '@types/node': 20.4.1 - dev: true - - /jest-pnp-resolver@1.2.3(jest-resolve@27.5.1): - resolution: {integrity: sha512-+3NpwQEnRoIBtx4fyhblQDPgJI0H1IEIkX7ShLUjPGA7TtUTvI1oiKi3SR4oBR0hQhQR80l4WAe5RrXBwWMA8w==} - engines: {node: '>=6'} - peerDependencies: - jest-resolve: '*' - peerDependenciesMeta: - jest-resolve: - optional: true - dependencies: - jest-resolve: 27.5.1 + stack-utils: 2.0.6 dev: true - /jest-regex-util@26.0.0: + /jest-regex-util/26.0.0: resolution: {integrity: sha512-Gv3ZIs/nA48/Zvjrl34bf+oD76JHiGDUxNOVgUjh3j890sblXryjY4rss71fPtD/njchl6PSE2hIhvyWa1eT0A==} engines: {node: '>= 10.14.2'} dev: true - /jest-regex-util@27.5.1: - resolution: {integrity: sha512-4bfKq2zie+x16okqDXjXn9ql2B0dScQu+vcwe4TvFVhkVyuWLqpZrZtXxLLWoXYgn0E87I6r6GRYHF7wFZBUvg==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dev: true - - /jest-resolve-dependencies@27.5.1: - resolution: {integrity: sha512-QQOOdY4PE39iawDn5rzbIePNigfe5B9Z91GDD1ae/xNDlu9kaat8QQ5EKnNmVWPV54hUdxCVwwj6YMgR2O7IOg==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - '@jest/types': 27.5.1 - jest-regex-util: 27.5.1 - jest-snapshot: 27.5.1 - transitivePeerDependencies: - - supports-color - dev: true - - /jest-resolve@27.5.1: - resolution: {integrity: sha512-FFDy8/9E6CV83IMbDpcjOhumAQPDyETnU2KZ1O98DwTnz8AOBsW/Xv3GySr1mOZdItLR+zDZ7I/UdTFbgSOVCw==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - '@jest/types': 27.5.1 - chalk: 4.1.2 - graceful-fs: 4.2.10 - jest-haste-map: 27.5.1 - jest-pnp-resolver: 1.2.3(jest-resolve@27.5.1) - jest-util: 27.5.1 - jest-validate: 27.5.1 - resolve: 1.22.2 - resolve.exports: 1.1.1 - slash: 3.0.0 - dev: true - - /jest-runner@27.5.1: - resolution: {integrity: sha512-g4NPsM4mFCOwFKXO4p/H/kWGdJp9V8kURY2lX8Me2drgXqG7rrZAx5kv+5H7wtt/cdFIjhqYx1HrlqWHaOvDaQ==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - '@jest/console': 27.5.1 - '@jest/environment': 27.5.1 - '@jest/test-result': 27.5.1 - '@jest/transform': 27.5.1 - '@jest/types': 27.5.1 - '@types/node': 20.4.1 - chalk: 4.1.2 - emittery: 0.8.1 - graceful-fs: 4.2.10 - jest-docblock: 27.5.1 - jest-environment-jsdom: 27.5.1 - jest-environment-node: 27.5.1 - jest-haste-map: 27.5.1 - jest-leak-detector: 27.5.1 - jest-message-util: 27.5.1 - jest-resolve: 27.5.1 - jest-runtime: 27.5.1 - jest-util: 27.5.1 - jest-worker: 27.5.1 - source-map-support: 0.5.21 - throat: 6.0.2 - transitivePeerDependencies: - - bufferutil - - canvas - - supports-color - - utf-8-validate - dev: true - - /jest-runtime@27.5.1: - resolution: {integrity: sha512-o7gxw3Gf+H2IGt8fv0RiyE1+r83FJBRruoA+FXrlHw6xEyBsU8ugA6IPfTdVyA0w8HClpbK+DGJxH59UrNMx8A==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - '@jest/environment': 27.5.1 - '@jest/fake-timers': 27.5.1 - '@jest/globals': 27.5.1 - '@jest/source-map': 27.5.1 - '@jest/test-result': 27.5.1 - '@jest/transform': 27.5.1 - '@jest/types': 27.5.1 - chalk: 4.1.2 - cjs-module-lexer: 1.2.2 - collect-v8-coverage: 1.0.1 - execa: 5.1.1 - glob: 7.2.3 - graceful-fs: 4.2.10 - jest-haste-map: 27.5.1 - jest-message-util: 27.5.1 - jest-mock: 27.5.1 - jest-regex-util: 27.5.1 - jest-resolve: 27.5.1 - jest-snapshot: 27.5.1 - jest-util: 27.5.1 - slash: 3.0.0 - strip-bom: 4.0.0 - transitivePeerDependencies: - - supports-color - dev: true - - /jest-serializer@26.6.2: + /jest-serializer/26.6.2: resolution: {integrity: sha512-S5wqyz0DXnNJPd/xfIzZ5Xnp1HrJWBczg8mMfMpN78OJ5eDxXyf+Ygld9wX1DnUWbIbhM1YDY95NjR4CBXkb2g==} engines: {node: '>= 10.14.2'} dependencies: '@types/node': 20.4.1 - graceful-fs: 4.2.10 - dev: true - - /jest-serializer@27.5.1: - resolution: {integrity: sha512-jZCyo6iIxO1aqUxpuBlwTDMkzOAJS4a3eYz3YzgxxVQFwLeSA7Jfq5cbqCY+JLvTDrWirgusI/0KwxKMgrdf7w==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - '@types/node': 20.4.1 - graceful-fs: 4.2.10 - dev: true - - /jest-snapshot@27.5.1: - resolution: {integrity: sha512-yYykXI5a0I31xX67mgeLw1DZ0bJB+gpq5IpSuCAoyDi0+BhgU/RIrL+RTzDmkNTchvDFWKP8lp+w/42Z3us5sA==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - '@babel/core': 7.22.5 - '@babel/generator': 7.22.5 - '@babel/plugin-syntax-typescript': 7.20.0(@babel/core@7.22.5) - '@babel/traverse': 7.22.5 - '@babel/types': 7.22.5 - '@jest/transform': 27.5.1 - '@jest/types': 27.5.1 - '@types/babel__traverse': 7.18.3 - '@types/prettier': 2.7.0 - babel-preset-current-node-syntax: 1.0.1(@babel/core@7.22.5) - chalk: 4.1.2 - expect: 27.5.1 - graceful-fs: 4.2.10 - jest-diff: 27.5.1 - jest-get-type: 27.5.1 - jest-haste-map: 27.5.1 - jest-matcher-utils: 27.5.1 - jest-message-util: 27.5.1 - jest-util: 27.5.1 - natural-compare: 1.4.0 - pretty-format: 27.5.1 - semver: 7.5.4 - transitivePeerDependencies: - - supports-color + graceful-fs: 4.2.11 dev: true - /jest-util@26.6.2: + /jest-util/26.6.2: resolution: {integrity: sha512-MDW0fKfsn0OI7MS7Euz6h8HNDXVQ0gaM9uW6RjfDmd1DAFcaxX9OqIakHIqhbnmF08Cf2DLDG+ulq8YQQ0Lp0Q==} engines: {node: '>= 10.14.2'} dependencies: '@jest/types': 26.6.2 '@types/node': 20.4.1 chalk: 4.1.2 - graceful-fs: 4.2.10 + graceful-fs: 4.2.11 is-ci: 2.0.0 micromatch: 4.0.5 dev: true - /jest-util@27.5.1: - resolution: {integrity: sha512-Kv2o/8jNvX1MQ0KGtw480E/w4fBCDOnH6+6DmeKi6LZUIlKA5kwY0YNdlzaWTiVgxqAqik11QyxDOKk543aKXw==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - '@jest/types': 27.5.1 - '@types/node': 20.4.1 - chalk: 4.1.2 - ci-info: 3.8.0 - graceful-fs: 4.2.10 - picomatch: 2.3.1 - dev: true - - /jest-util@29.0.1: - resolution: {integrity: sha512-GIWkgNfkeA9d84rORDHPGGTFBrRD13A38QVSKE0bVrGSnoR1KDn8Kqz+0yI5kezMgbT/7zrWaruWP1Kbghlb2A==} + /jest-util/29.6.1: + resolution: {integrity: sha512-NRFCcjc+/uO3ijUVyNOQJluf8PtGCe/W6cix36+M3cTFgiYqFOOW5MgN4JOOcvbUhcKTYVd1CvHz/LWi8d16Mg==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: - '@jest/types': 29.0.1 + '@jest/types': 29.6.1 '@types/node': 20.4.1 chalk: 4.1.2 - ci-info: 3.7.0 - graceful-fs: 4.2.10 + ci-info: 3.8.0 + graceful-fs: 4.2.11 picomatch: 2.3.1 dev: true - /jest-validate@27.5.1: - resolution: {integrity: sha512-thkNli0LYTmOI1tDB3FI1S1RTp/Bqyd9pTarJwL87OIBFuqEb5Apv5EaApEudYg4g86e3CT6kM0RowkhtEnCBQ==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - '@jest/types': 27.5.1 - camelcase: 6.3.0 - chalk: 4.1.2 - jest-get-type: 27.5.1 - leven: 3.1.0 - pretty-format: 27.5.1 - dev: true - - /jest-watcher@27.5.1: - resolution: {integrity: sha512-z676SuD6Z8o8qbmEGhoEUFOM1+jfEiL3DXHK/xgEiG2EyNYfFG60jluWcupY6dATjfEsKQuibReS1djInQnoVw==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - dependencies: - '@jest/test-result': 27.5.1 - '@jest/types': 27.5.1 - '@types/node': 20.4.1 - ansi-escapes: 4.3.2 - chalk: 4.1.2 - jest-util: 27.5.1 - string-length: 4.0.2 - dev: true - - /jest-worker@26.6.2: + /jest-worker/26.6.2: resolution: {integrity: sha512-KWYVV1c4i+jbMpaBC+U++4Va0cp8OisU185o73T1vo99hqi7w8tSJfUXYswwqqrjzwxa6KpRK54WhPvwf5w6PQ==} engines: {node: '>= 10.13.0'} dependencies: @@ -17859,74 +15208,64 @@ packages: supports-color: 7.2.0 dev: true - /jest-worker@27.5.1: + /jest-worker/27.5.1: resolution: {integrity: sha512-7vuh85V5cdDofPyxn58nrPjBktZo0u9x1g8WtjQol+jZDaE+fhN+cIvTj11GndBnMnyfrUOG1sZQxCdjKh+DKg==} engines: {node: '>= 10.13.0'} dependencies: - '@types/node': 20.4.1 + '@types/node': 16.18.38 merge-stream: 2.0.0 supports-color: 8.1.1 dev: true - /jest@27.5.1(ts-node@10.9.1): - resolution: {integrity: sha512-Yn0mADZB89zTtjkPJEXwrac3LHudkQMR+Paqa8uxJHCBr9agxztUifWCyiYrjhMPBoUVBjyny0I7XH6ozDr7QQ==} - engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} - hasBin: true - peerDependencies: - node-notifier: ^8.0.1 || ^9.0.0 || ^10.0.0 - peerDependenciesMeta: - node-notifier: - optional: true - dependencies: - '@jest/core': 27.5.1(ts-node@10.9.1) - import-local: 3.1.0 - jest-cli: 27.5.1(ts-node@10.9.1) - transitivePeerDependencies: - - bufferutil - - canvas - - supports-color - - ts-node - - utf-8-validate - dev: true - - /jiti@1.18.2: - resolution: {integrity: sha512-QAdOptna2NYiSSpv0O/BwoHBSmz4YhpzJHyi+fnMRTXFjp7B8i/YG5Z8IfusxB1ufjcD2Sre1F3R+nX3fvy7gg==} + /jiti/1.19.1: + resolution: {integrity: sha512-oVhqoRDaBXf7sjkll95LHVS6Myyyb1zaunVwk4Z0+WPSW4gjS0pl01zYKHScTuyEhQsFxV5L4DR5r+YqSyqyyg==} hasBin: true - /joycon@3.1.1: + /joycon/3.1.1: resolution: {integrity: sha512-34wB/Y7MW7bzjKRjUKTa46I2Z7eV62Rkhva+KkopW7Qvv/OSWBqvkSY7vusOPrNuZcUG3tApvdVgNB8POj3SPw==} engines: {node: '>=10'} dev: true - /js-beautify@1.14.6: + /js-beautify/1.14.6: resolution: {integrity: sha512-GfofQY5zDp+cuHc+gsEXKPpNw2KbPddreEo35O6jT6i0RVK6LhsoYBhq5TvK4/n74wnA0QbK8gGd+jUZwTMKJw==} engines: {node: '>=10'} hasBin: true dependencies: config-chain: 1.1.13 editorconfig: 0.15.3 - glob: 8.0.3 + glob: 8.1.0 + nopt: 6.0.0 + dev: true + + /js-beautify/1.14.8: + resolution: {integrity: sha512-4S7HFeI9YfRvRgKnEweohs0tgJj28InHVIj4Nl8Htf96Y6pHg3+tJrmo4ucAM9f7l4SHbFI3IvFAZ2a1eQPbyg==} + engines: {node: '>=12'} + hasBin: true + dependencies: + config-chain: 1.1.13 + editorconfig: 0.15.3 + glob: 8.1.0 nopt: 6.0.0 dev: true - /js-levenshtein@1.1.6: + /js-levenshtein/1.1.6: resolution: {integrity: sha512-X2BB11YZtrRqY4EnQcLX5Rh373zbK4alC1FW7D7MBhL2gtcC17cTnr6DmfHZeS0s2rTHjUTMMHfG7gO8SSdw+g==} engines: {node: '>=0.10.0'} dev: true - /js-sha3@0.8.0: + /js-sha3/0.8.0: resolution: {integrity: sha512-gF1cRrHhIzNfToc802P800N8PpXS+evLLXfsVpowqmAFR9uwbi89WvXg2QspOmXL8QL86J4T1EpFu+yUkwJY3Q==} dev: false - /js-string-escape@1.0.1: + /js-string-escape/1.0.1: resolution: {integrity: sha512-Smw4xcfIQ5LVjAOuJCvN/zIodzA/BBSsluuoSykP+lUvScIi4U6RJLfwHet5cxFnCswUjISV8oAXaqaJDY3chg==} engines: {node: '>= 0.8'} dev: true - /js-tokens@4.0.0: + /js-tokens/4.0.0: resolution: {integrity: sha512-RdJUflcE3cUzKiMqQgsCu06FPu9UdIJO0beYbPhHN4k6apgJtifcoCtT9bcxOpYBtpD2kCM6Sbzg4CausW/PKQ==} - /js-yaml@3.14.1: + /js-yaml/3.14.1: resolution: {integrity: sha512-okMH7OXXJ7YrN9Ok3/SXrnu4iX9yOk+25nqX4imS2npuvTYDmo/QEZoqwZkYaIDk3jVvBOTOIEgEhaLOynBS9g==} hasBin: true dependencies: @@ -17934,102 +15273,18 @@ packages: esprima: 4.0.1 dev: true - /js-yaml@4.1.0: + /js-yaml/4.1.0: resolution: {integrity: sha512-wpxZs9NoxZaJESJGIZTyDEaYpl0FKSA+FB9aJiyemKhMwkxQg63h4T1KJgUGHpTqPDNRcmmYLugrRjJlBtWvRA==} hasBin: true dependencies: argparse: 2.0.1 dev: true - - /jsbn@0.1.1: - resolution: {integrity: sha512-UVU9dibq2JcFWxQPA6KCqj5O42VOmAY3zQUfEKxU0KpTGXwNoCjkX1e13eHNvw/xPynt6pU0rZ1htjWTNTSXsg==} - dev: true - - /jsdom@16.7.0: - resolution: {integrity: sha512-u9Smc2G1USStM+s/x1ru5Sxrl6mPYCbByG1U/hUmqaVsm4tbNyS7CicOSRyuGQYZhTu0h84qkZZQ/I+dzizSVw==} - engines: {node: '>=10'} - peerDependencies: - canvas: ^2.5.0 - peerDependenciesMeta: - canvas: - optional: true - dependencies: - abab: 2.0.6 - acorn: 8.9.0 - acorn-globals: 6.0.0 - cssom: 0.4.4 - cssstyle: 2.3.0 - data-urls: 2.0.0 - decimal.js: 10.4.3 - domexception: 2.0.1 - escodegen: 2.0.0 - form-data: 3.0.1 - html-encoding-sniffer: 2.0.1 - http-proxy-agent: 4.0.1 - https-proxy-agent: 5.0.1 - is-potential-custom-element-name: 1.0.1 - nwsapi: 2.2.4 - parse5: 6.0.1 - saxes: 5.0.1 - symbol-tree: 3.2.4 - tough-cookie: 4.1.2 - w3c-hr-time: 1.0.2 - w3c-xmlserializer: 2.0.0 - webidl-conversions: 6.1.0 - whatwg-encoding: 1.0.5 - whatwg-mimetype: 2.3.0 - whatwg-url: 8.7.0 - ws: 7.5.9 - xml-name-validator: 3.0.0 - transitivePeerDependencies: - - bufferutil - - supports-color - - utf-8-validate - dev: true - - /jsdom@20.0.0: - resolution: {integrity: sha512-x4a6CKCgx00uCmP+QakBDFXwjAJ69IkkIWHmtmjd3wvXPcdOS44hfX2vqkOQrVrq8l9DhNNADZRXaCEWvgXtVA==} - engines: {node: '>=14'} - peerDependencies: - canvas: ^2.5.0 - peerDependenciesMeta: - canvas: - optional: true - dependencies: - abab: 2.0.6 - acorn: 8.9.0 - acorn-globals: 6.0.0 - cssom: 0.5.0 - cssstyle: 2.3.0 - data-urls: 3.0.2 - decimal.js: 10.4.0 - domexception: 4.0.0 - escodegen: 2.0.0 - form-data: 4.0.0 - html-encoding-sniffer: 3.0.0 - http-proxy-agent: 5.0.0 - https-proxy-agent: 5.0.1 - is-potential-custom-element-name: 1.0.1 - nwsapi: 2.2.1 - parse5: 7.0.0 - saxes: 6.0.0 - symbol-tree: 3.2.4 - tough-cookie: 4.1.2 - w3c-hr-time: 1.0.2 - w3c-xmlserializer: 3.0.0 - webidl-conversions: 7.0.0 - whatwg-encoding: 2.0.0 - whatwg-mimetype: 3.0.0 - whatwg-url: 11.0.0 - ws: 8.13.0 - xml-name-validator: 4.0.0 - transitivePeerDependencies: - - bufferutil - - supports-color - - utf-8-validate + + /jsbn/0.1.1: + resolution: {integrity: sha512-UVU9dibq2JcFWxQPA6KCqj5O42VOmAY3zQUfEKxU0KpTGXwNoCjkX1e13eHNvw/xPynt6pU0rZ1htjWTNTSXsg==} dev: true - /jsdom@20.0.3: + /jsdom/20.0.3: resolution: {integrity: sha512-SYhBvTh89tTfCD/CRdSOm13mOBa42iTaTyfyEWBdKcGdPxPtLFBXuHR8XHb33YNYaP+lLbmSvBTsnoesCNJEsQ==} engines: {node: '>=14'} peerDependencies: @@ -18039,30 +15294,30 @@ packages: optional: true dependencies: abab: 2.0.6 - acorn: 8.8.2 + acorn: 8.10.0 acorn-globals: 7.0.1 cssom: 0.5.0 cssstyle: 2.3.0 data-urls: 3.0.2 - decimal.js: 10.4.2 + decimal.js: 10.4.3 domexception: 4.0.0 - escodegen: 2.0.0 + escodegen: 2.1.0 form-data: 4.0.0 html-encoding-sniffer: 3.0.0 http-proxy-agent: 5.0.0 https-proxy-agent: 5.0.1 is-potential-custom-element-name: 1.0.1 - nwsapi: 2.2.2 - parse5: 7.1.1 + nwsapi: 2.2.7 + parse5: 7.1.2 saxes: 6.0.0 symbol-tree: 3.2.4 - tough-cookie: 4.1.2 + tough-cookie: 4.1.3 w3c-xmlserializer: 4.0.0 webidl-conversions: 7.0.0 whatwg-encoding: 2.0.0 whatwg-mimetype: 3.0.0 whatwg-url: 11.0.0 - ws: 8.11.0 + ws: 8.13.0 xml-name-validator: 4.0.0 transitivePeerDependencies: - bufferutil @@ -18070,8 +15325,8 @@ packages: - utf-8-validate dev: true - /jsdom@21.0.0: - resolution: {integrity: sha512-AIw+3ZakSUtDYvhwPwWHiZsUi3zHugpMEKlNPaurviseYoBqo0zBd3zqoUi3LPCNtPFlEP8FiW9MqCZdjb2IYA==} + /jsdom/21.1.2: + resolution: {integrity: sha512-sCpFmK2jv+1sjff4u7fzft+pUh2KSUbUrEHYHyfSIbGTIcmnjyp83qg6qLwdJ/I3LpTXx33ACxeRL7Lsyc6lGQ==} engines: {node: '>=14'} peerDependencies: canvas: ^2.5.0 @@ -18080,29 +15335,29 @@ packages: optional: true dependencies: abab: 2.0.6 - acorn: 8.9.0 + acorn: 8.10.0 acorn-globals: 7.0.1 - cssom: 0.5.0 - cssstyle: 2.3.0 - data-urls: 3.0.2 + cssstyle: 3.0.0 + data-urls: 4.0.0 decimal.js: 10.4.3 domexception: 4.0.0 - escodegen: 2.0.0 + escodegen: 2.1.0 form-data: 4.0.0 html-encoding-sniffer: 3.0.0 http-proxy-agent: 5.0.0 https-proxy-agent: 5.0.1 is-potential-custom-element-name: 1.0.1 - nwsapi: 2.2.4 + nwsapi: 2.2.7 parse5: 7.1.2 + rrweb-cssom: 0.6.0 saxes: 6.0.0 symbol-tree: 3.2.4 - tough-cookie: 4.1.2 + tough-cookie: 4.1.3 w3c-xmlserializer: 4.0.0 webidl-conversions: 7.0.0 whatwg-encoding: 2.0.0 whatwg-mimetype: 3.0.0 - whatwg-url: 11.0.0 + whatwg-url: 12.0.1 ws: 8.13.0 xml-name-validator: 4.0.0 transitivePeerDependencies: @@ -18111,7 +15366,7 @@ packages: - utf-8-validate dev: true - /jsdom@22.1.0: + /jsdom/22.1.0: resolution: {integrity: sha512-/9AVW7xNbsBv6GfWho4TTNjEo9fe6Zhf9O7s0Fhhr3u+awPwAJMKwAMXnkk5vBxflqLW9hTHX/0cs+P3gW+cQw==} engines: {node: '>=16'} peerDependencies: @@ -18130,12 +15385,12 @@ packages: http-proxy-agent: 5.0.0 https-proxy-agent: 5.0.1 is-potential-custom-element-name: 1.0.1 - nwsapi: 2.2.4 + nwsapi: 2.2.7 parse5: 7.1.2 rrweb-cssom: 0.6.0 saxes: 6.0.0 symbol-tree: 3.2.4 - tough-cookie: 4.1.2 + tough-cookie: 4.1.3 w3c-xmlserializer: 4.0.0 webidl-conversions: 7.0.0 whatwg-encoding: 2.0.0 @@ -18149,97 +15404,92 @@ packages: - utf-8-validate dev: true - /jsesc@0.5.0: + /jsesc/0.5.0: resolution: {integrity: sha512-uZz5UnB7u4T9LvwmFqXii7pZSouaRPorGs5who1Ip7VO0wxanFvBL7GkM6dTHlgX+jhBApRetaWpnDabOeTcnA==} hasBin: true dev: true - /jsesc@2.5.2: + /jsesc/2.5.2: resolution: {integrity: sha512-OYu7XEzjkCQ3C5Ps3QIZsQfNpqoJyZZA99wd9aWd05NCtC5pWOkShK2mkL6HXQR6/Cy2lbNdPlZBpuQHXE63gA==} engines: {node: '>=4'} hasBin: true - /jsesc@3.0.2: + /jsesc/3.0.2: resolution: {integrity: sha512-xKqzzWXDttJuOcawBt4KnKHHIf5oQ/Cxax+0PWFG+DFDgHNAdi+TXECADI+RYiFUMmx8792xsMbbgXj4CwnP4g==} engines: {node: '>=6'} hasBin: true dev: true - /json-buffer@3.0.1: + /json-buffer/3.0.1: resolution: {integrity: sha512-4bV5BfR2mqfQTJm+V5tPPdf+ZpuhiIvTuAB5g8kcrXOZpTT/QwwVRWBywX1ozr6lEuPdbHxwaJlm9G6mI2sfSQ==} dev: true - /json-parse-better-errors@1.0.2: + /json-parse-better-errors/1.0.2: resolution: {integrity: sha512-mrqyZKfX5EhL7hvqcV6WG1yYjnjeuYDzDhhcAAUrq8Po85NBQBJP+ZDUT75qZQ98IkUoBqdkExkukOU7Ts2wrw==} dev: true - /json-parse-even-better-errors@2.3.1: + /json-parse-even-better-errors/2.3.1: resolution: {integrity: sha512-xyFwyhro/JEof6Ghe2iz2NcXoj2sloNsWr/XsERDK/oiPCfaNhl5ONfp+jQdAZRQQ0IJWNzH9zIZF7li91kh2w==} - /json-schema-traverse@0.4.1: + /json-schema-traverse/0.4.1: resolution: {integrity: sha512-xbbCH5dCYU5T8LcEhhuh7HJ88HXuW3qsI3Y0zOZFKfZEHcpWiHU/Jxzk629Brsab/mMiHQti9wMP+845RPe3Vg==} dev: true - /json-schema-traverse@1.0.0: + /json-schema-traverse/1.0.0: resolution: {integrity: sha512-NM8/P9n3XjXhIZn1lLhkFaACTOURQXjWhV4BA/RnOv8xvgqtqpAX9IO4mRQxSx1Rlo4tqzeqb0sOlruaOy3dug==} dev: true - /json-schema@0.4.0: + /json-schema/0.4.0: resolution: {integrity: sha512-es94M3nTIfsEPisRafak+HDLfHXnKBhV3vU5eqPcS3flIWqcxJWgXHXiey3YrpaNsanY5ei1VoYEbOzijuq9BA==} dev: true - /json-stable-stringify-without-jsonify@1.0.1: + /json-stable-stringify-without-jsonify/1.0.1: resolution: {integrity: sha512-Bdboy+l7tA3OGW6FjyFHWkP5LuByj1Tk33Ljyq0axyzdk9//JSi2u3fP1QSmd1KNwq6VOKYGlAu87CisVir6Pw==} dev: true - /json-stringify-safe@5.0.1: + /json-stringify-safe/5.0.1: resolution: {integrity: sha512-ZClg6AaYvamvYEE82d3Iyd3vSSIjQ+odgjaTzRuO3s7toCdFKczob2i0zCh7JE8kWn17yvAWhUVxvqGwUalsRA==} dev: true - /json5@1.0.1: - resolution: {integrity: sha512-aKS4WQjPenRxiQsC93MNfjx+nbF4PAdYzmd/1JIj8HYzqfbu86beTuNgXDzPknWk0n0uARlyewZo4s++ES36Ow==} + /json5/1.0.2: + resolution: {integrity: sha512-g1MWMLBiz8FKi1e4w0UyVL3w+iJceWAFBAaBnnGKOpNa5f8TLktkbre1+s6oICydWAm+HRUGTmI+//xv2hvXYA==} hasBin: true dependencies: minimist: 1.2.8 dev: true - /json5@2.2.1: - resolution: {integrity: sha512-1hqLFMSrGHRHxav9q9gNjJ5EXznIxGVO09xQRrwplcS8qs28pZ8s8hupZAmqDwZUmVZ2Qb2jnyPOWcDH8m8dlA==} - engines: {node: '>=6'} - hasBin: true - - /json5@2.2.3: + /json5/2.2.3: resolution: {integrity: sha512-XmOWe7eyHYH14cLdVPoyg+GOH3rYX++KpzrylJwSW98t3Nk+U8XOl8FWKOgwtzdb8lXGf6zYwDUzeHMWfxasyg==} engines: {node: '>=6'} hasBin: true - /jsonc-eslint-parser@2.3.0: + /jsonc-eslint-parser/2.3.0: resolution: {integrity: sha512-9xZPKVYp9DxnM3sd1yAsh/d59iIaswDkai8oTxbursfKYbg/ibjX0IzFt35+VZ8iEW453TVTXztnRvYUQlAfUQ==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dependencies: - acorn: 8.9.0 + acorn: 8.10.0 eslint-visitor-keys: 3.4.1 - espree: 9.5.2 - semver: 7.5.2 + espree: 9.6.0 + semver: 7.5.4 dev: true - /jsonc-parser@3.2.0: + /jsonc-parser/3.2.0: resolution: {integrity: sha512-gfFQZrcTc8CnKXp6Y4/CBT3fTc0OVuDofpre4aEeEpSBPV5X5v4+Vmx+8snU7RLPrNHPKSgLxGo9YuQzz20o+w==} - /jsonfile@6.1.0: + /jsonfile/6.1.0: resolution: {integrity: sha512-5dgndWOriYSm5cnYaJNhalLNDKOqFwyDB/rr1E9ZsGciGvKPs8R2xYGCacuf3z6K1YKDz182fd+fY3cn3pMqXQ==} dependencies: universalify: 2.0.0 optionalDependencies: - graceful-fs: 4.2.10 + graceful-fs: 4.2.11 dev: true - /jsonpointer@5.0.1: + /jsonpointer/5.0.1: resolution: {integrity: sha512-p/nXbhSEcu3pZRdkW1OfJhpsVtW1gd4Wa1fnQc9YLiTfAjn0312eMKimbdIQzuZl9aa9xUGaRlP9T/CJE/ditQ==} engines: {node: '>=0.10.0'} dev: true - /jsprim@2.0.2: + /jsprim/2.0.2: resolution: {integrity: sha512-gqXddjPqQ6G40VdnI6T6yObEC+pDNvyP95wdQhkWkg7crHH3km5qP1FsOXEkzEQwnz6gz5qGTn1c2Y52wP3OyQ==} engines: {'0': node >=0.6.0} dependencies: @@ -18249,102 +15499,94 @@ packages: verror: 1.10.0 dev: true - /junk@3.1.0: + /junk/3.1.0: resolution: {integrity: sha512-pBxcB3LFc8QVgdggvZWyeys+hnrNWg4OcZIU/1X59k5jQdLBlCsYGRQaz234SqoRLTCgMH00fY0xRJH+F9METQ==} engines: {node: '>=8'} dev: true - /keyv@4.5.2: + /keyv/4.5.2: resolution: {integrity: sha512-5MHbFaKn8cNSmVW7BYnijeAVlE4cYA/SVkifVgrh7yotnfhKmjuXpDKjrABLnT0SfHWV21P8ow07OGfRrNDg8g==} dependencies: json-buffer: 3.0.1 dev: true - /kind-of@3.2.2: + /kind-of/3.2.2: resolution: {integrity: sha512-NOW9QQXMoZGg/oqnVNoNTTIFEIid1627WCffUBJEdMxYApq7mNE7CpzucIPc+ZQg25Phej7IJSmX3hO+oblOtQ==} engines: {node: '>=0.10.0'} dependencies: is-buffer: 1.1.6 dev: true - /kind-of@4.0.0: + /kind-of/4.0.0: resolution: {integrity: sha512-24XsCxmEbRwEDbz/qz3stgin8TTzZ1ESR56OMCN0ujYg+vRutNSiOj9bHH9u85DKgXguraugV5sFuvbD4FW/hw==} engines: {node: '>=0.10.0'} dependencies: is-buffer: 1.1.6 dev: true - /kind-of@5.1.0: + /kind-of/5.1.0: resolution: {integrity: sha512-NGEErnH6F2vUuXDh+OlbcKW7/wOcfdRHaZ7VWtqCztfHri/++YKmP51OdWeGPuqCOba6kk2OTe5d02VmTB80Pw==} engines: {node: '>=0.10.0'} dev: true - /kind-of@6.0.3: + /kind-of/6.0.3: resolution: {integrity: sha512-dcS1ul+9tmeD95T+x28/ehLgd9mENa3LsvDTtzm3vyBEO7RPptvAD+t44WVXaUjTBRcrpFeFlC8WCruUR456hw==} engines: {node: '>=0.10.0'} dev: true - /kleur@3.0.3: + /kleur/3.0.3: resolution: {integrity: sha512-eTIzlVOSUR+JxdDFepEYcBMtZ9Qqdef+rnzWdRZuMbOywu5tO2w2N7rqjoANZ5k9vywhL6Br1VRjUIgTQx4E8w==} engines: {node: '>=6'} dev: true - /kleur@4.1.5: + /kleur/4.1.5: resolution: {integrity: sha512-o+NO+8WrRiQEE4/7nwRJhN1HWpVmJm511pBHUxPLtp0BUISzlBplORYSmTclCnJvQq2tKu/sgl3xVpkc7ZWuQQ==} engines: {node: '>=6'} dev: true - /klona@2.0.5: - resolution: {integrity: sha512-pJiBpiXMbt7dkzXe8Ghj/u4FfXOOa98fPW+bihOJ4SjnoijweJrNThJfd3ifXpXhREjpoF2mZVH1GfS9LV3kHQ==} + /klona/2.0.6: + resolution: {integrity: sha512-dhG34DXATL5hSxJbIexCft8FChFXtmskoZYnoPWjXQuebWYCNkVeV3KkGegCK9CP1oswI/vQibS2GY7Em/sJJA==} engines: {node: '>= 8'} dev: true - /kolorist@1.8.0: + /kolorist/1.8.0: resolution: {integrity: sha512-Y+60/zizpJ3HRH8DCss+q95yr6145JXZo46OTpFvDZWLfRCE4qChOyk1b26nMaNpfHHgxagk9dXT5OP0Tfe+dQ==} dev: true - /ky@0.33.3: + /ky/0.33.3: resolution: {integrity: sha512-CasD9OCEQSFIam2U8efFK81Yeg8vNMTBUqtMOHlrcWQHqUX3HeCl9Dr31u4toV7emlH8Mymk5+9p0lL6mKb/Xw==} engines: {node: '>=14.16'} dev: true - /lazy-ass@1.6.0: + /lazy-ass/1.6.0: resolution: {integrity: sha512-cc8oEVoctTvsFZ/Oje/kGnHbpWHYBe8IAJe4C0QNc3t8uM/0Y8+erSz/7Y1ALuXTEZTMvxXwO6YbX1ey3ujiZw==} engines: {node: '> 0.8'} dev: true - /lazy-universal-dotenv@3.0.1: + /lazy-universal-dotenv/3.0.1: resolution: {integrity: sha512-prXSYk799h3GY3iOWnC6ZigYzMPjxN2svgjJ9shk7oMadSNX3wXy0B6F32PMJv7qtMnrIbUxoEHzbutvxR2LBQ==} engines: {node: '>=6.0.0', npm: '>=6.0.0', yarn: '>=1.0.0'} dependencies: - '@babel/runtime': 7.18.9 + '@babel/runtime': 7.22.6 app-root-dir: 1.0.2 - core-js: 3.25.0 + core-js: 3.31.1 dotenv: 8.6.0 dotenv-expand: 5.1.0 dev: true - /lazystream@1.0.1: + /lazystream/1.0.1: resolution: {integrity: sha512-b94GiNHQNy6JNTrt5w6zNyffMrNkXZb3KTkCZJb2V1xaEGCk093vkZ2jk3tpaeP33/OiXC+WvK9AxUebnf5nbw==} engines: {node: '>= 0.6.3'} dependencies: - readable-stream: 2.3.7 + readable-stream: 2.3.8 dev: true - /leven@3.1.0: + /leven/3.1.0: resolution: {integrity: sha512-qsda+H8jTaUaN/x5vzW2rzc+8Rw4TAQ/4KjB46IwK5VH+IlVeeeje/EoZRpiXvIqjFgK84QffqPztGI3VBLG1A==} engines: {node: '>=6'} dev: true - /levn@0.3.0: - resolution: {integrity: sha512-0OO4y2iOHix2W6ujICbKIaEQXvFQHue65vUG3pb5EUomzPI90z9hsA1VsO/dbIIpC53J8gxM9Q4Oho0jrCM/yA==} - engines: {node: '>= 0.8.0'} - dependencies: - prelude-ls: 1.1.2 - type-check: 0.3.2 - dev: true - - /levn@0.4.1: + /levn/0.4.1: resolution: {integrity: sha512-+bT2uH4E5LGE7h/n3evcS/sQlJXCpIp6ym8OWJ5eV6+67Dsql/LaaT7qJBAt2rzfoa/5QBGBhxDix1dMt2kQKQ==} engines: {node: '>= 0.8.0'} dependencies: @@ -18352,16 +15594,16 @@ packages: type-check: 0.4.0 dev: true - /light-my-request@5.5.1: - resolution: {integrity: sha512-Zd4oZjF7axSyc5rYQsbB0qsgY4LFFviZSbEywxf7Vi5UE3y3c7tYF/GeheQjBNYY+pQ55BF8UGGJTjneoxOS1w==} + /light-my-request/5.10.0: + resolution: {integrity: sha512-ZU2D9GmAcOUculTTdH9/zryej6n8TzT+fNGdNtm6SDp5MMMpHrJJkvAdE3c6d8d2chE9i+a//dS9CWZtisknqA==} dependencies: cookie: 0.5.0 - process-warning: 2.0.0 - set-cookie-parser: 2.5.1 + process-warning: 2.2.0 + set-cookie-parser: 2.6.0 dev: true - /lighthouse-logger@1.3.0: - resolution: {integrity: sha512-BbqAKApLb9ywUli+0a+PcV04SyJ/N1q/8qgCNe6U97KbPCS1BTksEuHFLYdvc8DltuhfxIUBqDZsC0bBGtl3lA==} + /lighthouse-logger/1.4.2: + resolution: {integrity: sha512-gPWxznF6TKmUHrOQjlVo2UbaL2EJ71mb2CCeRs/2qBpi4L/g4LUVc9+3lKQ6DTUZwJswfM7ainGrLO1+fOqa2g==} dependencies: debug: 2.6.9 marky: 1.2.5 @@ -18369,23 +15611,23 @@ packages: - supports-color dev: true - /lilconfig@2.1.0: + /lilconfig/2.1.0: resolution: {integrity: sha512-utWOt/GHzuUxnLKxB6dk81RoOeoNeHgbrXiuGk4yyF5qlRz+iIVWu56E2fqGHFrXz0QNUhLB/8nKqvRH66JKGQ==} engines: {node: '>=10'} dev: true - /lines-and-columns@1.2.4: + /lines-and-columns/1.2.4: resolution: {integrity: sha512-7ylylesZQ/PV29jhEDl3Ufjo6ZX7gCqJr5F7PKrqc93v7fzSymt1BpwEU8nAUXs8qzzvqhbjhK5QZg6Mt/HkBg==} - /lint-staged@13.2.3: + /lint-staged/13.2.3: resolution: {integrity: sha512-zVVEXLuQIhr1Y7R7YAWx4TZLdvuzk7DnmrsTNL0fax6Z3jrpFcas+vKbzxhhvp6TA55m1SQuWkpzI1qbfDZbAg==} engines: {node: ^14.13.1 || >=16.0.0} hasBin: true dependencies: chalk: 5.2.0 cli-truncate: 3.1.0 - commander: 10.0.0 - debug: 4.3.4(supports-color@8.1.1) + commander: 10.0.1 + debug: 4.3.4 execa: 7.1.1 lilconfig: 2.1.0 listr2: 5.0.8 @@ -18393,14 +15635,14 @@ packages: normalize-path: 3.0.0 object-inspect: 1.12.3 pidtree: 0.6.0 - string-argv: 0.3.1 + string-argv: 0.3.2 yaml: 2.3.1 transitivePeerDependencies: - enquirer - supports-color dev: true - /listr2@3.14.0(enquirer@2.3.6): + /listr2/3.14.0_enquirer@2.3.6: resolution: {integrity: sha512-TyWI8G99GX9GjE54cJ+RrNMcIFBfwMPxc3XTFiAYGN4s10hWROGtOg7+O6u6LE3mNkyld7RSLE6nrKBvTfcs3g==} engines: {node: '>=10.0.0'} peerDependencies: @@ -18420,7 +15662,7 @@ packages: wrap-ansi: 7.0.0 dev: true - /listr2@5.0.8: + /listr2/5.0.8: resolution: {integrity: sha512-mC73LitKHj9w6v30nLNGPetZIlfpUniNSsxxrbaPcWOjDb92SHPzJPi/t+v1YC/lxKz/AJ9egOjww0qUuFxBpA==} engines: {node: ^14.13.1 || >=16.0.0} peerDependencies: @@ -18439,32 +15681,33 @@ packages: wrap-ansi: 7.0.0 dev: true - /lit-element@3.2.2: - resolution: {integrity: sha512-6ZgxBR9KNroqKb6+htkyBwD90XGRiqKDHVrW/Eh0EZ+l+iC+u+v+w3/BA5NGi4nizAVHGYvQBHUDuSmLjPp7NQ==} + /lit-element/3.3.2: + resolution: {integrity: sha512-xXAeVWKGr4/njq0rGC9dethMnYCq5hpKYrgQZYTzawt9YQhMiXfD+T1RgrdY3NamOxwq2aXlb0vOI6e29CKgVQ==} dependencies: - '@lit/reactive-element': 1.4.1 - lit-html: 2.3.1 + '@lit-labs/ssr-dom-shim': 1.1.1 + '@lit/reactive-element': 1.6.2 + lit-html: 2.7.5 dev: false - /lit-html@2.3.1: - resolution: {integrity: sha512-FyKH6LTW6aBdkfNhNSHyZTnLgJSTe5hMk7HFtc/+DcN1w74C215q8B+Cfxc2OuIEpBNcEKxgF64qL8as30FDHA==} + /lit-html/2.7.5: + resolution: {integrity: sha512-YqUzpisJodwKIlbMFCtyrp58oLloKGnnPLMJ1t23cbfIJjg/H9pvLWK4XS69YeubK5HUs1UE4ys9w5dP1zg6IA==} dependencies: - '@types/trusted-types': 2.0.2 + '@types/trusted-types': 2.0.3 dev: false - /lit@2.3.1: - resolution: {integrity: sha512-TejktDR4mqG3qB32Y8Lm5Lye3c8SUehqz7qRsxe1PqGYL6me2Ef+jeQAEqh20BnnGncv4Yxy2njEIT0kzK1WCw==} + /lit/2.7.6: + resolution: {integrity: sha512-1amFHA7t4VaaDe+vdQejSVBklwtH9svGoG6/dZi9JhxtJBBlqY5D1RV7iLUYY0trCqQc4NfhYYZilZiVHt7Hxg==} dependencies: - '@lit/reactive-element': 1.4.1 - lit-element: 3.2.2 - lit-html: 2.3.1 + '@lit/reactive-element': 1.6.2 + lit-element: 3.3.2 + lit-html: 2.7.5 dev: false - /load-json-file@1.1.0: + /load-json-file/1.1.0: resolution: {integrity: sha512-cy7ZdNRXdablkXYNI049pthVeXFurRyb9+hA/dZzerZ0pGTx42z+y+ssxBaVV2l70t1muq5IdKhn4UtcoGUY9A==} engines: {node: '>=0.10.0'} dependencies: - graceful-fs: 4.2.10 + graceful-fs: 4.2.11 parse-json: 2.2.0 pify: 2.3.0 pinkie-promise: 2.0.1 @@ -18472,42 +15715,42 @@ packages: dev: true optional: true - /load-json-file@4.0.0: + /load-json-file/4.0.0: resolution: {integrity: sha512-Kx8hMakjX03tiGTLAIdJ+lL0htKnXjEZN6hk/tozf/WOuYGdZBJrZ+rCJRbVCugsjB3jMLn9746NsQIf5VjBMw==} engines: {node: '>=4'} dependencies: - graceful-fs: 4.2.10 + graceful-fs: 4.2.11 parse-json: 4.0.0 pify: 3.0.0 strip-bom: 3.0.0 dev: true - /load-tsconfig@0.2.3: - resolution: {integrity: sha512-iyT2MXws+dc2Wi6o3grCFtGXpeMvHmJqS27sMPGtV2eUu4PeFnG+33I8BlFK1t1NWMjOpcx9bridn5yxLDX2gQ==} + /load-tsconfig/0.2.5: + resolution: {integrity: sha512-IXO6OCs9yg8tMKzfPZ1YmheJbZCiEsnBdcB03l0OcfK9prKnJb96siuHCr5Fl37/yo9DnKU+TLpxzTUspw9shg==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dev: true - /loader-runner@2.4.0: + /loader-runner/2.4.0: resolution: {integrity: sha512-Jsmr89RcXGIwivFY21FcRrisYZfvLMTWx5kOLc+JTxtpBOG6xML0vzbc6SEQG2FO9/4Fc3wW4LVcB5DmGflaRw==} engines: {node: '>=4.3.0 <5.0.0 || >=5.10'} dev: true - /loader-runner@4.3.0: + /loader-runner/4.3.0: resolution: {integrity: sha512-3R/1M+yS3j5ou80Me59j7F9IMs4PXs3VqRrm0TU3AbKPxlmpoY1TNscJV/oGJXo8qCatFGTfDbY6W6ipGOYXfg==} engines: {node: '>=6.11.5'} dev: true - /loader-utils@1.4.0: - resolution: {integrity: sha512-qH0WSMBtn/oHuwjy/NucEgbx5dbxxnxup9s4PVXJUDHZBQY+s0NWA9rJf53RBnQZxfch7euUui7hpoAPvALZdA==} + /loader-utils/1.4.2: + resolution: {integrity: sha512-I5d00Pd/jwMD2QCduo657+YM/6L3KZu++pmX9VFncxaxvHcru9jx1lBaFft+r4Mt2jK0Yhp41XlRAihzPxHNCg==} engines: {node: '>=4.0.0'} dependencies: big.js: 5.2.2 emojis-list: 3.0.0 - json5: 1.0.1 + json5: 1.0.2 dev: true - /loader-utils@2.0.2: - resolution: {integrity: sha512-TM57VeHptv569d/GKh6TAYdzKblwDNiumOdkFnejjD0XwTH87K90w3O7AiJRqdQoXygvi1VQTJTLGhJl7WqA7A==} + /loader-utils/2.0.4: + resolution: {integrity: sha512-xXqpXoINfFhgua9xiqD8fPFHgkoq1mmmpE92WlDbm9rNRd/EbRb+Gqf908T2DMfuHjjJlksiK2RbHVOdD/MqSw==} engines: {node: '>=8.9.0'} dependencies: big.js: 5.2.2 @@ -18515,15 +15758,15 @@ packages: json5: 2.2.3 dev: true - /local-pkg@0.4.3: + /local-pkg/0.4.3: resolution: {integrity: sha512-SFppqq5p42fe2qcZQqqEOiVRXl+WCP1MdT6k7BDEW1j++sp5fIY+/fdRQitvKgB5BrBcmrs5m/L0v2FrU5MY1g==} engines: {node: '>=14'} - /locate-character@3.0.0: + /locate-character/3.0.0: resolution: {integrity: sha512-SW13ws7BjaeJ6p7Q6CO2nchbYEc3X3J6WrmTTDto7yMPqVSZTUyY5Tjbid+Ab8gLnATtygYtiDIJGQRRn2ZOiA==} dev: true - /locate-path@3.0.0: + /locate-path/3.0.0: resolution: {integrity: sha512-7AO748wWnIhNqAuaty2ZWHkQHRSNfPVIsPIfwEOWO22AmaoVrWavlOcMR5nzTLNYvp36X220/maaRsrec1G65A==} engines: {node: '>=6'} dependencies: @@ -18531,91 +15774,91 @@ packages: path-exists: 3.0.0 dev: true - /locate-path@5.0.0: + /locate-path/5.0.0: resolution: {integrity: sha512-t7hw9pI+WvuwNJXwk5zVHpyhIqzg2qTlklJOf0mVxGSbe3Fp2VieZcduNYjaLDoy6p9uGpQEGWG87WpMKlNq8g==} engines: {node: '>=8'} dependencies: p-locate: 4.1.0 dev: true - /locate-path@6.0.0: + /locate-path/6.0.0: resolution: {integrity: sha512-iPZK6eYjbxRu3uB4/WZ3EsEIMJFMqAoopl3R+zuq0UjcAm/MO6KCweDgPfP3elTztoKP3KtnVHxTn2NHBSDVUw==} engines: {node: '>=10'} dependencies: p-locate: 5.0.0 dev: true - /locate-path@7.1.1: - resolution: {integrity: sha512-vJXaRMJgRVD3+cUZs3Mncj2mxpt5mP0EmNOsxRSZRMlbqjvxzDEOIUWXGmavo0ZC9+tNZCBLQ66reA11nbpHZg==} + /locate-path/7.2.0: + resolution: {integrity: sha512-gvVijfZvn7R+2qyPX8mAuKcFGDf6Nc61GdvGafQsHL0sBIxfKzA+usWn4GFC/bk+QdwPUD4kWFJLhElipq+0VA==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dependencies: p-locate: 6.0.0 dev: true - /lodash.clonedeep@4.5.0: + /lodash.clonedeep/4.5.0: resolution: {integrity: sha512-H5ZhCF25riFd9uB5UCkVKo61m3S/xZk1x4wA6yp/L3RFP6Z/eHH1ymQcGLo7J3GMPfm0V/7m1tryHuGVxpqEBQ==} dev: true - /lodash.debounce@4.0.8: + /lodash.debounce/4.0.8: resolution: {integrity: sha512-FT1yDzDYEoYWhnSGnpE/4Kj1fLZkDFyqRb7fNt6FdYOSxlUWAtp42Eh6Wb0rGIv/m9Bgo7x4GhQbm5Ys4SG5ow==} dev: true - /lodash.defaults@4.2.0: + /lodash.defaults/4.2.0: resolution: {integrity: sha512-qjxPLHd3r5DnsdGacqOMU6pb/avJzdh9tFX2ymgoZE27BmjXrNy/y4LoaiTeAb+O3gL8AfpJGtqfX/ae2leYYQ==} dev: true - /lodash.difference@4.5.0: + /lodash.difference/4.5.0: resolution: {integrity: sha512-dS2j+W26TQ7taQBGN8Lbbq04ssV3emRw4NY58WErlTO29pIqS0HmoT5aJ9+TUQ1N3G+JOZSji4eugsWwGp9yPA==} dev: true - /lodash.escape@4.0.1: + /lodash.escape/4.0.1: resolution: {integrity: sha512-nXEOnb/jK9g0DYMr1/Xvq6l5xMD7GDG55+GSYIYmS0G4tBk/hURD4JR9WCavs04t33WmJx9kCyp9vJ+mr4BOUw==} dev: true - /lodash.flatten@4.4.0: + /lodash.flatten/4.4.0: resolution: {integrity: sha512-C5N2Z3DgnnKr0LOpv/hKCgKdb7ZZwafIrsesve6lmzvZIRZRGaZ/l6Q8+2W7NaT+ZwO3fFlSCzCzrDCFdJfZ4g==} dev: true - /lodash.flattendeep@4.4.0: + /lodash.flattendeep/4.4.0: resolution: {integrity: sha512-uHaJFihxmJcEX3kT4I23ABqKKalJ/zDrDg0lsFtc1h+3uw49SIJ5beyhx5ExVRti3AvKoOJngIj7xz3oylPdWQ==} dev: true - /lodash.isequal@4.5.0: + /lodash.isequal/4.5.0: resolution: {integrity: sha512-pDo3lu8Jhfjqls6GkMgpahsF9kCyayhgykjyLMNFTKWrpVdAQtYyB4muAMWozBB4ig/dtWAmsMxLEI8wuz+DYQ==} dev: true - /lodash.isplainobject@4.0.6: + /lodash.isplainobject/4.0.6: resolution: {integrity: sha512-oSXzaWypCMHkPC3NvBEaPHf0KsA5mvPrOPgQWDsbg8n7orZ290M0BmC/jgRZ4vcJ6DTAhjrsSYgdsW/F+MFOBA==} dev: true - /lodash.merge@4.6.2: + /lodash.merge/4.6.2: resolution: {integrity: sha512-0KpjqXRVvrYyCsX1swR/XTK0va6VQkQM6MNo7PqW77ByjAhoARA8EfrP1N4+KlKj8YS0ZUCtRT/YUuhyYDujIQ==} dev: true - /lodash.once@4.1.1: + /lodash.once/4.1.1: resolution: {integrity: sha512-Sb487aTOCr9drQVL8pIxOzVhafOjZN9UU54hiN8PU3uAiSV7lx1yYNpbNmex2PK6dSJoNTSJUUswT651yww3Mg==} dev: true - /lodash.sortby@4.7.0: + /lodash.sortby/4.7.0: resolution: {integrity: sha512-HDWXG8isMntAyRF5vZ7xKuEvOhT4AhlRt/3czTSjvGUxjYCBVRQY48ViDHyfYz9VIoBkW4TMGQNapx+l3RUwdA==} dev: true - /lodash.union@4.6.0: + /lodash.union/4.6.0: resolution: {integrity: sha512-c4pB2CdGrGdjMKYLA+XiRDO7Y0PRQbm/Gzg8qMj+QH+pFVAoTp5sBpO0odL3FjoPCGjK96p6qsP+yQoiLoOBcw==} dev: true - /lodash.uniq@4.5.0: + /lodash.uniq/4.5.0: resolution: {integrity: sha512-xfBaXQd9ryd9dlSDvnvI0lvxfLJlYAZzXomUYzLKtUeOQvOP5piqAWuGtrhWeqaXK9hhoM/iyJc5AV+XfsX3HQ==} dev: true - /lodash.zip@4.2.0: + /lodash.zip/4.2.0: resolution: {integrity: sha512-C7IOaBBK/0gMORRBd8OETNx3kmOkgIWIPvyDpZSCTwUrpYmgZwJkjZeOD8ww4xbOUOs4/attY+pciKvadNfFbg==} dev: true - /lodash@4.17.21: + /lodash/4.17.21: resolution: {integrity: sha512-v2kDEe57lecTulaDIuNTPy3Ry4gLGJ6Z1O3vE1krgXZNrsQ+LFTGHVxVjcXPs17LhbZVGedAJv8XZ1tvj5FvSg==} - /log-symbols@4.1.0: + /log-symbols/4.1.0: resolution: {integrity: sha512-8XPvpAA8uyhfteu8pIvQxpJZ7SYYdpUivZpGy6sFsBuKRY/7rQGavedeB8aK+Zkyq6upMFVL/9AW6vOYzfRyLg==} engines: {node: '>=10'} dependencies: @@ -18623,7 +15866,7 @@ packages: is-unicode-supported: 0.1.0 dev: true - /log-update@4.0.0: + /log-update/4.0.0: resolution: {integrity: sha512-9fkkDevMefjg0mmzWFBW8YkFP91OrizzkW3diF7CpG+S2EYdy4+TVfGwz1zeF8x7hCx1ovSPTOE9Ngib74qqUg==} engines: {node: '>=10'} dependencies: @@ -18633,7 +15876,7 @@ packages: wrap-ansi: 6.2.0 dev: true - /log-update@5.0.1: + /log-update/5.0.1: resolution: {integrity: sha512-5UtUDQ/6edw4ofyljDNcOVJQ4c7OjDro4h3y8e1GQL5iYElYclVHJ3zeWchylvMaKnDbDilC8irOVyexnA/Slw==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dependencies: @@ -18641,25 +15884,25 @@ packages: cli-cursor: 4.0.0 slice-ansi: 5.0.0 strip-ansi: 7.1.0 - wrap-ansi: 8.0.1 + wrap-ansi: 8.1.0 dev: true - /loglevel-plugin-prefix@0.8.4: + /loglevel-plugin-prefix/0.8.4: resolution: {integrity: sha512-WpG9CcFAOjz/FtNht+QJeGpvVl/cdR6P0z6OcXSkr8wFJOsV2GRj2j10JLfjuA4aYkcKCNIEqRGCyTife9R8/g==} dev: true - /loglevel@1.8.1: + /loglevel/1.8.1: resolution: {integrity: sha512-tCRIJM51SHjAayKwC+QAg8hT8vg6z7GSgLJKGvzuPb1Wc+hLzqtuVLxp6/HzSPOozuK+8ErAhy7U/sVzw8Dgfg==} engines: {node: '>= 0.6.0'} dev: true - /loose-envify@1.4.0: + /loose-envify/1.4.0: resolution: {integrity: sha512-lyuxPGr/Wfhrlem2CL/UcnUc1zcqKAImBDzukY7Y5F/yQiNdko6+fRLevlw1HgMySw7f611UIY408EtxRSoK3Q==} hasBin: true dependencies: js-tokens: 4.0.0 - /loud-rejection@1.6.0: + /loud-rejection/1.6.0: resolution: {integrity: sha512-RPNliZOFkqFumDhvYqOaNY4Uz9oJM2K9tC6JWsJJsNdhuONW4LQHRBpb0qf4pJApVffI5N39SwzWZJuEhfd7eQ==} engines: {node: '>=0.10.0'} dependencies: @@ -18668,162 +15911,144 @@ packages: dev: true optional: true - /loupe@2.3.6: + /loupe/2.3.6: resolution: {integrity: sha512-RaPMZKiMy8/JruncMU5Bt6na1eftNoo++R4Y+N2FrxkDVTrGvcyzFTsaGif4QTeKESheMGegbhw6iUAq+5A8zA==} dependencies: get-func-name: 2.0.0 dev: false - /lower-case@2.0.2: + /lower-case/2.0.2: resolution: {integrity: sha512-7fm3l3NAF9WfN6W3JOmf5drwpVqX78JtoGJ3A6W0a6ZnldM41w2fV5D490psKFTpMds8TJse/eHLFFsNHHjHgg==} dependencies: - tslib: 2.5.3 + tslib: 2.6.0 dev: true - /lowercase-keys@3.0.0: + /lowercase-keys/3.0.0: resolution: {integrity: sha512-ozCC6gdQ+glXOQsveKD0YsDy8DSQFjDTz4zyzEHNV5+JP5D62LmfDZ6o1cycFx9ouG940M5dE8C8CTewdj2YWQ==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dev: true - /lru-cache@4.1.5: + /lru-cache/10.0.0: + resolution: {integrity: sha512-svTf/fzsKHffP42sujkO/Rjs37BCIsQVRCeNYIm9WN8rgT7ffoUnRtZCqU+6BqcSBdv8gwJeTz8knJpgACeQMw==} + engines: {node: 14 || >=16.14} + dev: true + + /lru-cache/4.1.5: resolution: {integrity: sha512-sWZlbEP2OsHNkXrMl5GYk/jKk70MBng6UU4YI/qGDYbgf6YbP4EvmqISbXCoJiRKs+1bSpFHVgQxvJ17F2li5g==} dependencies: pseudomap: 1.0.2 yallist: 2.1.2 dev: true - /lru-cache@5.1.1: + /lru-cache/5.1.1: resolution: {integrity: sha512-KpNARQA3Iwv+jTA0utUVVbrh+Jlrr1Fv0e56GGzAFOXN7dk/FviaDW8LHmK52DlcH4WP2n6gI8vN1aesBFgo9w==} dependencies: yallist: 3.1.1 - /lru-cache@6.0.0: + /lru-cache/6.0.0: resolution: {integrity: sha512-Jo6dJ04CmSjuznwJSS3pUeWmd/H0ffTlkXXgwZi+eq1UCmqQwCh+eLsYOYCwY991i2Fah4h1BEMCx4qThGbsiA==} engines: {node: '>=10'} dependencies: yallist: 4.0.0 dev: true - /lru-cache@9.1.1: - resolution: {integrity: sha512-65/Jky17UwSb0BuB9V+MyDpsOtXKmYwzhyl+cOa9XUiI4uV2Ouy/2voFP3+al0BjZbJgMBD8FojMpAf+Z+qn4A==} - engines: {node: 14 || >=16.14} - dev: true - - /lz-string@1.4.4: - resolution: {integrity: sha512-0ckx7ZHRPqb0oUm8zNr+90mtf9DQB60H1wMCjBtfi62Kl3a7JbHob6gA2bC+xRvZoOL+1hzUK8jeuEIQE8svEQ==} - hasBin: true - dev: true - - /lz-string@1.5.0: + /lz-string/1.5.0: resolution: {integrity: sha512-h5bgJWpxJNswbU7qCrV0tIKQCaS3blPDrqKWx+QxzuzL1zGUzij9XCWLrSLsJPu5t+eWA/ycetzYAO5IOMcWAQ==} hasBin: true dev: true - /magic-string@0.25.9: + /magic-string/0.25.9: resolution: {integrity: sha512-RmF0AsMzgt25qzqqLc1+MbHmhdx0ojF2Fvs4XnOqz2ZOBXzzkEwc/dJQZCYHAn7v1jbVOjAZfK8msRn4BxO4VQ==} dependencies: sourcemap-codec: 1.4.8 + dev: true - /magic-string@0.26.7: + /magic-string/0.26.7: resolution: {integrity: sha512-hX9XH3ziStPoPhJxLq1syWuZMxbDvGNbVchfrdCtanC7D13888bMFow61x8axrx+GfHLtVeAx2kxL7tTGRl+Ow==} engines: {node: '>=12'} dependencies: sourcemap-codec: 1.4.8 dev: true - /magic-string@0.27.0: + /magic-string/0.27.0: resolution: {integrity: sha512-8UnnX2PeRAPZuN12svgR9j7M1uWMovg/CEnIwIG0LFkXSJJe4PdfUGiTGl8V9bsBHFUtfVINcSyYxd7q+kx9fA==} engines: {node: '>=12'} dependencies: '@jridgewell/sourcemap-codec': 1.4.15 dev: true - /magic-string@0.30.0: - resolution: {integrity: sha512-LA+31JYDJLs82r2ScLrlz1GjSgu66ZV518eyWT+S8VhyQn/JL0u9MeBOvQMGYiPk1DBiSN9DDMOcXvigJZaViQ==} - engines: {node: '>=12'} - dependencies: - '@jridgewell/sourcemap-codec': 1.4.15 - dev: true - - /magic-string@0.30.1: + /magic-string/0.30.1: resolution: {integrity: sha512-mbVKXPmS0z0G4XqFDCTllmDQ6coZzn94aMlb0o/A4HEHJCKcanlDZwYJgwnkmgD3jyWhUgj9VsPrfd972yPffA==} engines: {node: '>=12'} dependencies: '@jridgewell/sourcemap-codec': 1.4.15 - /make-dir@2.1.0: + /make-dir/2.1.0: resolution: {integrity: sha512-LS9X+dc8KLxXCb8dni79fLIIUA5VyZoyjSMCwTluaXA0o27cCK0bhXkpgw+sTXVpPy/lSO57ilRixqk0vDmtRA==} engines: {node: '>=6'} dependencies: pify: 4.0.1 - semver: 5.7.1 + semver: 5.7.2 dev: true - /make-dir@3.1.0: + /make-dir/3.1.0: resolution: {integrity: sha512-g3FeP20LNwhALb/6Cz6Dd4F2ngze0jz7tbzrD2wAV+o9FeNHe4rL+yK2md0J/fiSf1sa1ADhXqi5+oVwOM/eGw==} engines: {node: '>=8'} dependencies: - semver: 6.3.0 - dev: true - - /make-dir@4.0.0: - resolution: {integrity: sha512-hXdUTZYIVOt1Ex//jAQi+wTZZpUpwBj/0QsOzqegb3rGMMeJiSEu5xLHnYfBrRV4RH2+OCSOO95Is/7x1WJ4bw==} - engines: {node: '>=10'} - dependencies: - semver: 7.5.4 + semver: 6.3.1 - /make-error@1.3.6: + /make-error/1.3.6: resolution: {integrity: sha512-s8UhlNe7vPKomQhC1qFelMokr/Sc3AgNbso3n74mVPA5LTZwkB9NlXf4XPamLxJE8h0gh73rM94xvwRT2CVInw==} dev: true - /makeerror@1.0.12: + /makeerror/1.0.12: resolution: {integrity: sha512-JmqCvUhmt43madlpFzG4BQzG2Z3m6tvQDNKdClZnO3VbIudJYmxsT0FNJMeiB2+JTSlTQTSbU8QdesVmwJcmLg==} dependencies: tmpl: 1.0.5 dev: true - /map-cache@0.2.2: + /map-cache/0.2.2: resolution: {integrity: sha512-8y/eV9QQZCiyn1SprXSrCmqJN0yNRATe+PO8ztwqrvrbdRLA3eYJF0yaR0YayLWkMbsQSKWS9N2gPcGEc4UsZg==} engines: {node: '>=0.10.0'} dev: true - /map-obj@1.0.1: + /map-obj/1.0.1: resolution: {integrity: sha512-7N/q3lyZ+LVCp7PzuxrJr4KMbBE2hW7BT7YNia330OFxIf4d3r5zVpicP2650l7CPN6RM9zOJRl3NGpqSiw3Eg==} engines: {node: '>=0.10.0'} dev: true optional: true - /map-or-similar@1.5.0: + /map-or-similar/1.5.0: resolution: {integrity: sha512-0aF7ZmVon1igznGI4VS30yugpduQW3y3GkcgGJOp7d8x8QrizhigUxjI/m2UojsXXto+jLAH3KSz+xOJTiORjg==} dev: true - /map-visit@1.0.0: + /map-visit/1.0.0: resolution: {integrity: sha512-4y7uGv8bd2WdM9vpQsiQNo41Ln1NvhvDRuVt0k2JZQ+ezN2uaQes7lZeZ+QQUHOLQAtDaBJ+7wCbi+ab/KFs+w==} engines: {node: '>=0.10.0'} dependencies: object-visit: 1.0.1 dev: true - /mark.js@8.11.1: + /mark.js/8.11.1: resolution: {integrity: sha512-1I+1qpDt4idfgLQG+BNWmrqku+7/2bi5nLf4YwF8y8zXvmfiTBY3PV3ZibfrjBueCByROpuBjLLFCajqkgYoLQ==} dev: true - /markdown-escapes@1.0.4: + /markdown-escapes/1.0.4: resolution: {integrity: sha512-8z4efJYk43E0upd0NbVXwgSTQs6cT3T06etieCMEg7dRbzCbxUCK/GHlX8mhHRDcp+OLlHkPKsvqQTCvsRl2cg==} dev: true - /marky@1.2.5: + /marky/1.2.5: resolution: {integrity: sha512-q9JtQJKjpsVxCRVgQ+WapguSbKC3SQ5HEzFGPAJMStgh3QjCawp00UKv3MTTAArTmGmmPUvllHZoNbZ3gs0I+Q==} dev: true - /match-sorter@6.3.1: + /match-sorter/6.3.1: resolution: {integrity: sha512-mxybbo3pPNuA+ZuCUhm5bwNkXrJTbsk5VWbR5wiwz/GC6LIiegBGn2w3O08UG/jdbYLinw51fSQ5xNU1U3MgBw==} dependencies: - '@babel/runtime': 7.18.9 + '@babel/runtime': 7.22.6 remove-accents: 0.4.2 dev: false - /md5.js@1.3.5: + /md5.js/1.3.5: resolution: {integrity: sha512-xitP+WxNPcTTOgnTJcrhM0xvdPepipPSf3I8EIpGKeFLjt3PlJLIDG3u8EX53ZIubkb+5U2+3rELYpEhHhzdkg==} dependencies: hash-base: 3.1.0 @@ -18831,22 +16056,22 @@ packages: safe-buffer: 5.2.1 dev: true - /mdast-squeeze-paragraphs@4.0.0: + /mdast-squeeze-paragraphs/4.0.0: resolution: {integrity: sha512-zxdPn69hkQ1rm4J+2Cs2j6wDEv7O17TfXTJ33tl/+JPIoEmtV9t2ZzBM5LPHE8QlHsmVD8t3vPKCyY3oH+H8MQ==} dependencies: unist-util-remove: 2.1.0 dev: true - /mdast-util-definitions@4.0.0: + /mdast-util-definitions/4.0.0: resolution: {integrity: sha512-k8AJ6aNnUkB7IE+5azR9h81O5EQ/cTDXtWdMq9Kk5KcEW/8ritU5CeLg/9HhOC++nALHBlaogJ5jz0Ybk3kPMQ==} dependencies: unist-util-visit: 2.0.3 dev: true - /mdast-util-from-markdown@0.8.5: + /mdast-util-from-markdown/0.8.5: resolution: {integrity: sha512-2hkTXtYYnr+NubD/g6KGBS/0mFmBcifAsI0yIWRiRo0PjVs6SSOSOdtzbp6kSGnShDN6G5aWZpKQ2lWRy27mWQ==} dependencies: - '@types/mdast': 3.0.10 + '@types/mdast': 3.0.12 mdast-util-to-string: 2.0.0 micromark: 2.11.4 parse-entities: 2.0.0 @@ -18855,11 +16080,11 @@ packages: - supports-color dev: true - /mdast-util-to-hast@10.0.1: + /mdast-util-to-hast/10.0.1: resolution: {integrity: sha512-BW3LM9SEMnjf4HXXVApZMt8gLQWVNXc3jryK0nJu/rOXPOnlkUjmdkDlmxMirpbU9ILncGFIwLH/ubnWBbcdgA==} dependencies: - '@types/mdast': 3.0.10 - '@types/unist': 2.0.6 + '@types/mdast': 3.0.12 + '@types/unist': 2.0.7 mdast-util-definitions: 4.0.0 mdurl: 1.0.1 unist-builder: 2.0.3 @@ -18868,61 +16093,61 @@ packages: unist-util-visit: 2.0.3 dev: true - /mdast-util-to-string@1.1.0: + /mdast-util-to-string/1.1.0: resolution: {integrity: sha512-jVU0Nr2B9X3MU4tSK7JP1CMkSvOj7X5l/GboG1tKRw52lLF1x2Ju92Ms9tNetCcbfX3hzlM73zYo2NKkWSfF/A==} dev: true - /mdast-util-to-string@2.0.0: + /mdast-util-to-string/2.0.0: resolution: {integrity: sha512-AW4DRS3QbBayY/jJmD8437V1Gombjf8RSOUCMFBuo5iHi58AGEgVCKQ+ezHkZZDpAQS75hcBMpLqjpJTjtUL7w==} dev: true - /mdn-data@2.0.30: + /mdn-data/2.0.30: resolution: {integrity: sha512-GaqWWShW4kv/G9IEucWScBx9G1/vsFZZJUO+tD26M8J8z3Kw5RDQjaoZe03YAClgeS/SWPOcb4nkFBTEi5DUEA==} dev: true - /mdurl@1.0.1: + /mdurl/1.0.1: resolution: {integrity: sha512-/sKlQJCBYVY9Ers9hqzKou4H6V5UWc/M59TH2dvkt+84itfnq7uFOMLpOiOS4ujvHP4etln18fmIxA5R5fll0g==} dev: true - /media-typer@0.3.0: - resolution: {integrity: sha1-hxDXrwqmJvj/+hzgAWhUUmMlV0g=} + /media-typer/0.3.0: + resolution: {integrity: sha512-dq+qelQ9akHpcOl/gUVRTxVIOkAJ1wR3QAvb4RsVjS8oVoFjDGTc679wJYmUmknUF5HwMLOgb5O+a3KxfWapPQ==} engines: {node: '>= 0.6'} dev: true - /memfs@3.4.7: - resolution: {integrity: sha512-ygaiUSNalBX85388uskeCyhSAoOSgzBbtVCr9jA2RROssFL9Q19/ZXFqS+2Th2sr1ewNIWgFdLzLC3Yl1Zv+lw==} + /memfs/3.5.3: + resolution: {integrity: sha512-UERzLsxzllchadvbPs5aolHh65ISpKpM+ccLbOJ8/vvpBKmAWf+la7dXFy7Mr0ySHbdHrFv5kGFCUHHe6GFEmw==} engines: {node: '>= 4.0.0'} dependencies: - fs-monkey: 1.0.3 + fs-monkey: 1.0.4 dev: true - /memoizerific@1.11.3: + /memoizerific/1.11.3: resolution: {integrity: sha512-/EuHYwAPdLtXwAwSZkh/Gutery6pD2KYd44oQLhAvQp/50mpyduZh8Q7PYHXTCJ+wuXxt7oij2LXyIJOOYFPog==} dependencies: map-or-similar: 1.5.0 dev: true - /memory-fs@0.4.1: + /memory-fs/0.4.1: resolution: {integrity: sha512-cda4JKCxReDXFXRqOHPQscuIYg1PvxbE2S2GP45rnwfEK+vZaXC8C1OFvdHIbgw0DLzowXGVoxLaAmlgRy14GQ==} dependencies: errno: 0.1.8 - readable-stream: 2.3.7 + readable-stream: 2.3.8 dev: true - /memory-fs@0.5.0: + /memory-fs/0.5.0: resolution: {integrity: sha512-jA0rdU5KoQMC0e6ppoNRtpp6vjFq6+NY7r8hywnC7V+1Xj/MtHwGIbB1QaK/dunyjWteJzmkpd7ooeWg10T7GA==} engines: {node: '>=4.3.0 <5.0.0 || >=5.10'} dependencies: errno: 0.1.8 - readable-stream: 2.3.7 + readable-stream: 2.3.8 dev: true - /memorystream@0.3.1: + /memorystream/0.3.1: resolution: {integrity: sha512-S3UwM3yj5mtUSEfP41UZmt/0SCoVYUcU1rkXv+BQ5Ig8ndL4sPoJNBUJERafdPb5jjHJGuMgytgKvKIf58XNBw==} engines: {node: '>= 0.10.0'} dev: true - /meow@3.7.0: + /meow/3.7.0: resolution: {integrity: sha512-TNdwZs0skRlpPpCUK25StC4VH+tP5GgeY1HQOOGP+lQ2xtdkN2VtT/5tiX9k3IWpkBPV9b3LsAWXn4GGi/PrSA==} engines: {node: '>=0.10.0'} dependencies: @@ -18939,44 +16164,44 @@ packages: dev: true optional: true - /merge-anything@5.1.4: - resolution: {integrity: sha512-7PWKwGOs5WWcpw+/OvbiFiAvEP6bv/QHiicigpqMGKIqPPAtGhBLR8LFJW+Zu6m9TXiR/a8+AiPlGG0ko1ruoQ==} + /merge-anything/5.1.7: + resolution: {integrity: sha512-eRtbOb1N5iyH0tkQDAoQ4Ipsp/5qSR79Dzrz8hEPxRX10RWWR/iQXdoKmBSRCThY1Fh5EhISDtpSc93fpxUniQ==} engines: {node: '>=12.13'} dependencies: - is-what: 4.1.8 + is-what: 4.1.15 dev: true - /merge-descriptors@1.0.1: - resolution: {integrity: sha1-sAqqVW3YtEVoFQ7J0blT8/kMu2E=} + /merge-descriptors/1.0.1: + resolution: {integrity: sha512-cCi6g3/Zr1iqQi6ySbseM1Xvooa98N0w31jzUYrXPX2xqObmFGHJ0tQ5u74H3mVh7wLouTseZyYIq39g8cNp1w==} dev: true - /merge-stream@2.0.0: + /merge-stream/2.0.0: resolution: {integrity: sha512-abv/qOcuPfk3URPfDzmZU1LKmuw8kT+0nIHvKrKgFrwifol/doWcdA4ZqsWQ8ENrFKkd67Mfpo/LovbIUsbt3w==} dev: true - /merge2@1.4.1: + /merge2/1.4.1: resolution: {integrity: sha512-8q7VEgMJW4J8tcfVPy8g09NcQwZdbwFEqhe/WZkoIzjn/3TGDwtOCYtXGxA3O8tPzpczCCDgv+P2P5y00ZJOOg==} engines: {node: '>= 8'} - /methods@1.1.2: + /methods/1.1.2: resolution: {integrity: sha512-iclAHeNqNm68zFtnZ0e+1L2yUIdvzNoauKU4WBA3VvH/vPFieF7qfRlwUZU+DA9P9bPXIS90ulxoUoCH23sV2w==} engines: {node: '>= 0.6'} dev: true - /microevent.ts@0.1.1: + /microevent.ts/0.1.1: resolution: {integrity: sha512-jo1OfR4TaEwd5HOrt5+tAZ9mqT4jmpNAusXtyfNzqVm9uiSYFZlKM1wYL4oU7azZW/PxQW53wM0S6OR1JHNa2g==} dev: true - /micromark@2.11.4: + /micromark/2.11.4: resolution: {integrity: sha512-+WoovN/ppKolQOFIAajxi7Lu9kInbPxFuTBVEavFcL8eAfVstoc5MocPmqBeAdBOJV00uaVjegzH4+MA0DN/uA==} dependencies: - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 parse-entities: 2.0.0 transitivePeerDependencies: - supports-color dev: true - /micromatch@3.1.10: + /micromatch/3.1.10: resolution: {integrity: sha512-MWikgl9n9M3w+bpsY3He8L+w9eF9338xRl8IAO5viDizwSzziFEyUzo2xrrloB64ADbTf8uA8vRqqttDTOmccg==} engines: {node: '>=0.10.0'} dependencies: @@ -18997,18 +16222,18 @@ packages: - supports-color dev: true - /micromatch@4.0.5: + /micromatch/4.0.5: resolution: {integrity: sha512-DMy+ERcEW2q8Z2Po+WNXuw3c5YaUSFjAO5GsJqfEl7UjvtIuFKO6ZrKvcItdy98dwFI2N1tg3zNIdKaQT+aNdA==} engines: {node: '>=8.6'} dependencies: braces: 3.0.2 picomatch: 2.3.1 - /microseconds@0.2.0: + /microseconds/0.2.0: resolution: {integrity: sha512-n7DHHMjR1avBbSpsTBj6fmMGh2AGrifVV4e+WYc3Q9lO+xnSZ3NyhcBND3vzzatt05LFhoKFRxrIyklmLlUtyA==} dev: false - /miller-rabin@4.0.1: + /miller-rabin/4.0.1: resolution: {integrity: sha512-115fLhvZVqWwHPbClyntxEVfVDfl9DLLTuJvq3g2O/Oxi8AiNouAHvDSzHS0viUJc+V5vm3eq91Xwqn9dp4jRA==} hasBin: true dependencies: @@ -19016,153 +16241,149 @@ packages: brorand: 1.1.0 dev: true - /mime-db@1.52.0: + /mime-db/1.52.0: resolution: {integrity: sha512-sPU4uV7dYlvtWJxwwxHD0PuihVNiE7TyAbQ5SWxDCB9mUYvOgroQOwYQQOKPJ8CIbE+1ETVlOoK1UC2nU3gYvg==} engines: {node: '>= 0.6'} dev: true - /mime-types@2.1.35: + /mime-types/2.1.35: resolution: {integrity: sha512-ZDY+bPm5zTTF+YpCrAU9nK0UgICYPT0QtT1NZWFv4s++TNkcgVaT0g6+4R2uI4MjQjzysHB1zxuWL50hzaeXiw==} engines: {node: '>= 0.6'} dependencies: mime-db: 1.52.0 dev: true - /mime@1.6.0: + /mime/1.6.0: resolution: {integrity: sha512-x0Vn8spI+wuJ1O6S7gnbaQg8Pxh4NNHb7KSINmEWKiPE4RKOplvijn+NkmYmmRgP68mc70j2EbeTFRsrswaQeg==} engines: {node: '>=4'} hasBin: true dev: true - /mime@2.6.0: + /mime/2.6.0: resolution: {integrity: sha512-USPkMeET31rOMiarsBNIHZKLGgvKc/LrjofAnBlOttf5ajRvqiRA8QsenbcooctK6d6Ts6aqZXBA+XbkKthiQg==} engines: {node: '>=4.0.0'} hasBin: true dev: true - /mime@3.0.0: + /mime/3.0.0: resolution: {integrity: sha512-jSCU7/VB1loIWBZe14aEYHU/+1UMEHoaO7qxCOVJOw9GgH72VAWppxNcjU+x9a2k3GSIBXNKxXQFqRvvZ7vr3A==} engines: {node: '>=10.0.0'} hasBin: true dev: true - /mimic-fn@2.1.0: + /mimic-fn/2.1.0: resolution: {integrity: sha512-OqbOk5oEQeAZ8WXWydlu9HJjz9WVdEIvamMCcXmuqUYjTknH/sqsWvhQ3vgwKFRR1HpjvNBKQ37nbJgYzGqGcg==} engines: {node: '>=6'} dev: true - /mimic-fn@4.0.0: + /mimic-fn/4.0.0: resolution: {integrity: sha512-vqiC06CuhBTUdZH+RYl8sFrL096vA45Ok5ISO6sE/Mr1jRbGH4Csnhi8f3wKVl7x8mO4Au7Ir9D3Oyv1VYMFJw==} engines: {node: '>=12'} dev: true - /mimic-response@3.1.0: + /mimic-response/3.1.0: resolution: {integrity: sha512-z0yWI+4FDrrweS8Zmt4Ej5HdJmky15+L2e6Wgn3+iK5fWzb6T3fhNFq2+MeTRb064c6Wr4N/wv0DzQTjNzHNGQ==} engines: {node: '>=10'} dev: true - /mimic-response@4.0.0: + /mimic-response/4.0.0: resolution: {integrity: sha512-e5ISH9xMYU0DzrT+jl8q2ze9D6eWBto+I8CNpe+VI+K2J/F/k3PdkdTdz4wvGVH4NTpo+NRYTVIuMQEMMcsLqg==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dev: true - /min-document@2.19.0: + /min-document/2.19.0: resolution: {integrity: sha512-9Wy1B3m3f66bPPmU5hdA4DR4PB2OfDU/+GS3yAB7IQozE3tqXaVv2zOjgla7MEGSRv95+ILmOuvhLkOK6wJtCQ==} dependencies: dom-walk: 0.1.2 dev: true - /min-indent@1.0.1: + /min-indent/1.0.1: resolution: {integrity: sha512-I9jwMn07Sy/IwOj3zVkVik2JTvgpaykDZEigL6Rx6N9LbMywwUSMtxET+7lVoDLLd3O3IXwJwvuuns8UB/HeAg==} engines: {node: '>=4'} dev: true - /minimalistic-assert@1.0.1: + /minimalistic-assert/1.0.1: resolution: {integrity: sha512-UtJcAD4yEaGtjPezWuO9wC4nwUnVH/8/Im3yEHQP4b67cXlD/Qr9hdITCU1xDbSEXg2XKNaP8jsReV7vQd00/A==} dev: true - /minimalistic-crypto-utils@1.0.1: + /minimalistic-crypto-utils/1.0.1: resolution: {integrity: sha512-JIYlbt6g8i5jKfJ3xz7rF0LXmv2TkDxBLUkiBeZ7bAx4GnnNMr8xFpGnOxn6GhTEHx3SjRrZEoU+j04prX1ktg==} dev: true - /minimatch@3.1.2: + /minimatch/3.1.2: resolution: {integrity: sha512-J7p63hRiAjw1NDEww1W7i37+ByIrOWO5XQQAzZ3VOcL0PNybwpfmV/N05zFAzwQ9USyEcX6t3UO+K5aqBQOIHw==} dependencies: brace-expansion: 1.1.11 - /minimatch@5.1.1: - resolution: {integrity: sha512-362NP+zlprccbEt/SkxKfRMHnNY85V74mVnpUpNyr3F35covl09Kec7/sEFLt3RA4oXmewtoaanoIf67SE5Y5g==} + /minimatch/5.1.6: + resolution: {integrity: sha512-lKwV/1brpG6mBUFHtb7NUmtABCb2WZZmm2wNiOA5hAb8VdCS4B3dtMWyvcoViccwAW/COERjXLt0zP1zXUN26g==} engines: {node: '>=10'} dependencies: brace-expansion: 2.0.1 dev: true - /minimatch@9.0.1: - resolution: {integrity: sha512-0jWhJpD/MdhPXwPuiRkCbfYfSKp2qnn2eOc279qI7f+osl/l+prKSrvhg157zSYvx/1nmgn2NqdT6k2Z7zSH9w==} + /minimatch/9.0.3: + resolution: {integrity: sha512-RHiac9mvaRw0x3AYRgDC1CxAP7HTcNrrECeA8YYJeWnpo+2Q5CegtZjaotWTWxDG3UeGA1coE05iH1mPjT/2mg==} engines: {node: '>=16 || 14 >=14.17'} dependencies: brace-expansion: 2.0.1 dev: true - /minimist@1.2.7: - resolution: {integrity: sha512-bzfL1YUZsP41gmu/qjrEk0Q6i2ix/cVeAhbCbqH9u3zYutS1cLg00qhrD0M2MVdCcx4Sc0UpP2eBWo9rotpq6g==} - dev: true - - /minimist@1.2.8: + /minimist/1.2.8: resolution: {integrity: sha512-2yyAR8qBkN3YuheJanUpWC5U3bb5osDywNB8RzDVlDwDHbocAJveqqj1u8+SVD7jkWT4yvsHCpWqqWqAxb0zCA==} dev: true - /minipass-collect@1.0.2: + /minipass-collect/1.0.2: resolution: {integrity: sha512-6T6lH0H8OG9kITm/Jm6tdooIbogG9e0tLgpY6mphXSm/A9u8Nq1ryBG+Qspiub9LjWlBPsPS3tWQ/Botq4FdxA==} engines: {node: '>= 8'} dependencies: - minipass: 3.3.4 + minipass: 3.3.6 dev: true - /minipass-flush@1.0.5: + /minipass-flush/1.0.5: resolution: {integrity: sha512-JmQSYYpPUqX5Jyn1mXaRwOda1uQ8HP5KAT/oDSLCzt1BYRhQU0/hDtsB1ufZfEEzMZ9aAVmsBw8+FWsIXlClWw==} engines: {node: '>= 8'} dependencies: - minipass: 3.3.4 + minipass: 3.3.6 dev: true - /minipass-pipeline@1.2.4: + /minipass-pipeline/1.2.4: resolution: {integrity: sha512-xuIq7cIOt09RPRJ19gdi4b+RiNvDFYe5JH+ggNvBqGqpQXcru3PcRmOZuHBKWK1Txf9+cQ+HMVN4d6z46LZP7A==} engines: {node: '>=8'} dependencies: - minipass: 3.3.4 + minipass: 3.3.6 dev: true - /minipass@3.3.4: - resolution: {integrity: sha512-I9WPbWHCGu8W+6k1ZiGpPu0GkoKBeorkfKNuAFBNS1HNFJvke82sxvI5bzcCNpWPorkOO5QQ+zomzzwRxejXiw==} + /minipass/3.3.6: + resolution: {integrity: sha512-DxiNidxSEK+tHG6zOIklvNOwm3hvCrbUrdtzY74U6HKTJxvIDfOUL5W5P2Ghd3DTkhhKPYGqeNUIh5qcM4YBfw==} engines: {node: '>=8'} dependencies: yallist: 4.0.0 dev: true - /minipass@4.2.5: - resolution: {integrity: sha512-+yQl7SX3bIT83Lhb4BVorMAHVuqsskxRdlmO9kTpyukp8vsm2Sn/fUOV9xlnG8/a5JsypJzap21lz/y3FBMJ8Q==} + /minipass/5.0.0: + resolution: {integrity: sha512-3FnjYuehv9k6ovOEbyOswadCDPX1piCfhV8ncmYtHOjuPwylVWsghTLo7rabjC3Rx5xD4HDx8Wm1xnMF7S5qFQ==} engines: {node: '>=8'} dev: true - /minipass@5.0.0: - resolution: {integrity: sha512-3FnjYuehv9k6ovOEbyOswadCDPX1piCfhV8ncmYtHOjuPwylVWsghTLo7rabjC3Rx5xD4HDx8Wm1xnMF7S5qFQ==} - engines: {node: '>=8'} + /minipass/7.0.2: + resolution: {integrity: sha512-eL79dXrE1q9dBbDCLg7xfn/vl7MS4F1gvJAgjJrQli/jbQWdUttuVawphqpffoIYfRdq78LHx6GP4bU/EQ2ATA==} + engines: {node: '>=16 || 14 >=14.17'} dev: true - /minisearch@6.1.0: + /minisearch/6.1.0: resolution: {integrity: sha512-PNxA/X8pWk+TiqPbsoIYH0GQ5Di7m6326/lwU/S4mlo4wGQddIcf/V//1f9TB0V4j59b57b+HZxt8h3iMROGvg==} dev: true - /minizlib@2.1.2: + /minizlib/2.1.2: resolution: {integrity: sha512-bAxsR8BVfj60DWXHE3u30oHzfl4G7khkSuPW+qvpd7jFRHm7dLxOjUk1EHACJ/hxLY8phGJ0YhYHZo7jil7Qdg==} engines: {node: '>= 8'} dependencies: - minipass: 3.3.4 + minipass: 3.3.6 yallist: 4.0.0 dev: true - /mississippi@3.0.0: + /mississippi/3.0.0: resolution: {integrity: sha512-x471SsVjUtBRtcvd4BzKE9kFC+/2TeWgKCgw0bZcw1b9l2X3QX5vCWgF+KaZaYm87Ss//rHnWryupDrgLvmSkA==} engines: {node: '>=4.0.0'} dependencies: @@ -19178,11 +16399,11 @@ packages: through2: 2.0.5 dev: true - /mitt@3.0.0: + /mitt/3.0.0: resolution: {integrity: sha512-7dX2/10ITVyqh4aOSVI9gdape+t9l2/8QxHrFmUXu4EEUpdlxl6RudZUPZoc+zuY2hk1j7XxVroIVIan/pD/SQ==} dev: true - /mixin-deep@1.3.2: + /mixin-deep/1.3.2: resolution: {integrity: sha512-WRoDn//mXBiJ1H40rqa3vH0toePwSsGb45iInWlTySa+Uu4k3tYUSxa2v1KqAiLtvlrSzaExqS1gtk96A9zvEA==} engines: {node: '>=0.10.0'} dependencies: @@ -19190,51 +16411,51 @@ packages: is-extendable: 1.0.1 dev: true - /mkdirp-classic@0.5.3: + /mkdirp-classic/0.5.3: resolution: {integrity: sha512-gKLcREMhtuZRwRAfqP3RFW+TK4JqApVBtOIftVgjuABpAtpxhPGaDcfvbhNvD0B8iD1oUr/txX35NjcaY6Ns/A==} dev: true - /mkdirp@0.5.6: + /mkdirp/0.5.6: resolution: {integrity: sha512-FP+p8RB8OWpF3YZBCrP5gtADmtXApB5AMLn+vdyA+PyxCjrCs00mjyUozssO33cwDeT3wNGdLxJ5M//YqtHAJw==} hasBin: true dependencies: - minimist: 1.2.7 + minimist: 1.2.8 dev: true - /mkdirp@1.0.4: + /mkdirp/1.0.4: resolution: {integrity: sha512-vVqVZQyf3WLx2Shd0qJ9xuvqgAyKPLAiqITEtqW0oIUjzo3PePDd6fW9iFz30ef7Ysp/oiWqbhszeGWW2T6Gzw==} engines: {node: '>=10'} hasBin: true dev: true - /mlly@1.4.0: + /mlly/1.4.0: resolution: {integrity: sha512-ua8PAThnTwpprIaU47EPeZ/bPUVp2QYBbWMphUQpVdBI3Lgqzm5KZQ45Agm3YJedHXaIHl6pBGabaLSUPPSptg==} dependencies: - acorn: 8.9.0 + acorn: 8.10.0 pathe: 1.1.1 pkg-types: 1.0.3 ufo: 1.1.2 - /modern-node-polyfills@0.1.3(rollup@3.26.0): + /modern-node-polyfills/0.1.3_rollup@3.26.2: resolution: {integrity: sha512-/4dB85Sdkt9MjWwtpKnsNTYhh0+fqjFC4ZEgDP4B0e6kyzbGUnX4NDxTUCaVwRLVF9gcEDcRQjol8pn05B3TUQ==} dependencies: '@jspm/core': 2.0.0-beta.24 - '@rollup/pluginutils': 3.1.0(rollup@3.26.0) + '@rollup/pluginutils': 3.1.0_rollup@3.26.2 esbuild: 0.14.54 local-pkg: 0.4.3 transitivePeerDependencies: - rollup dev: false - /moment@2.29.4: + /moment/2.29.4: resolution: {integrity: sha512-5LC9SOxjSc2HF6vO2CyuTDNivEdoz2IvyJJGj6X8DJ0eFyfszE0QiEd+iXmBvUP3WHxSjFH/vIsA0EN00cgr8w==} dev: true - /moo@0.5.1: - resolution: {integrity: sha512-I1mnb5xn4fO80BH9BLcF0yLypy2UKl+Cb01Fu0hJRkJjlCRtxZMWkTdAtDd5ZqCOxtCkhmRwyI57vWT+1iZ67w==} + /moo/0.5.2: + resolution: {integrity: sha512-iSAJLHYKnX41mKcJKjqvnAN9sf0LMDTXDEvFv+ffuRR9a1MIuXLjMNL6EsnDHSkKLTWNqQQ5uo61P4EbU4NU+Q==} dev: true - /move-concurrently@1.0.1: + /move-concurrently/1.0.1: resolution: {integrity: sha512-hdrFxZOycD/g6A6SoI2bB5NA/5NEqD0569+S47WZhPvm46sD50ZHdYaFmnua5lndde9rCHGjmfK7Z8BuCt/PcQ==} dependencies: aproba: 1.2.0 @@ -19245,45 +16466,41 @@ packages: run-queue: 1.0.3 dev: true - /mri@1.2.0: + /mri/1.2.0: resolution: {integrity: sha512-tzzskb3bG8LvYGFF/mDTpq3jpI6Q9wc3LEmBaghu+DdCssd1FakN7Bc0hVNmEyGq1bq3RgfkCb3cmQLpNPOroA==} engines: {node: '>=4'} dev: true - /mrmime@1.0.1: + /mrmime/1.0.1: resolution: {integrity: sha512-hzzEagAgDyoU1Q6yg5uI+AorQgdvMCur3FcKf7NhMKWsaYg+RnbTyHRa/9IlLF9rf455MOCtcqqrQQ83pPP7Uw==} engines: {node: '>=10'} - /ms@2.0.0: + /ms/2.0.0: resolution: {integrity: sha512-Tpp60P6IUJDTuOq/5Z8cdskzJujfwqfOTkrwIwj7IRISpnkJnT6SyJ4PCPnGMoFjC9ddhal5KVIYtAt97ix05A==} dev: true - /ms@2.1.1: + /ms/2.1.1: resolution: {integrity: sha512-tgp+dl5cGk28utYktBsrFqA7HKgrhgPsg6Z/EfhWI4gl1Hwq8B/GmY/0oXZ6nF8hDVesS/FpnYaD/kOWhYQvyg==} dev: true - /ms@2.1.2: + /ms/2.1.2: resolution: {integrity: sha512-sGkPx+VjMtmA6MX27oA4FBFELFCZZ4S4XqeGOXCv68tT+jb3vk/RyaKWP0PTKyWtmLSM0b+adUTEvbs1PEaH2w==} - /ms@2.1.3: + /ms/2.1.3: resolution: {integrity: sha512-6FlzubTLZG3J2a/NVCAleEhjzq5oxgHyaCU9yYXvcLsvoVaHJq/s5xXI6/XXP6tz7R9xAOtHnSO/tXtF3WRTlA==} dev: true - /msw-storybook-addon@1.6.3(msw@0.49.2)(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-Ps80WdRmXsmenoTwfrgKMNpQD8INUUFyUFyZOecx8QjuqSlL++UYrLaGyACXN2goOn+/VS6rb0ZapbjrasPClg==} + /msw-storybook-addon/1.8.0_msw@0.49.3: + resolution: {integrity: sha512-dw3vZwqjixmiur0vouRSOax7wPSu9Og2Hspy9JZFHf49bZRjwDiLF0Pfn2NXEkGviYJOJiGxS1ejoTiUwoSg4A==} peerDependencies: - msw: '>=0.35.0 <1.0.0' + msw: '>=0.35.0 <2.0.0' dependencies: - '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) - is-node-process: 1.0.1 - msw: 0.49.2(typescript@4.8.4) - transitivePeerDependencies: - - react - - react-dom + is-node-process: 1.2.0 + msw: 0.49.3_typescript@4.9.5 dev: true - /msw@0.49.2(typescript@4.8.4): - resolution: {integrity: sha512-70/E10f+POE2UmMw16v8PnKatpZplpkUwVRLBqiIdimpgaC3le7y2yOq9JmOrL15jpwWM5wAcPTOj0f550LI3g==} + /msw/0.49.3_typescript@4.9.5: + resolution: {integrity: sha512-kRCbDNbNnRq5LC1H/NUceZlrPAvSrMH6Or0mirIuH69NY84xwDruPn/hkXTovIK1KwDwbk+ZdoSyJlpiekLxEA==} engines: {node: '>=14'} hasBin: true requiresBuild: true @@ -19294,76 +16511,75 @@ packages: optional: true dependencies: '@mswjs/cookies': 0.2.2 - '@mswjs/interceptors': 0.17.6 + '@mswjs/interceptors': 0.17.9 '@open-draft/until': 1.0.3 '@types/cookie': 0.4.1 '@types/js-levenshtein': 1.1.1 chalk: 4.1.1 chokidar: 3.5.3 cookie: 0.4.2 - graphql: 16.6.0 + graphql: 16.7.1 headers-polyfill: 3.1.2 - inquirer: 8.2.4 - is-node-process: 1.0.1 + inquirer: 8.2.5 + is-node-process: 1.2.0 js-levenshtein: 1.1.6 - node-fetch: 2.6.7 - outvariant: 1.3.0 + node-fetch: 2.6.12 + outvariant: 1.4.0 path-to-regexp: 6.2.1 - strict-event-emitter: 0.2.8 + strict-event-emitter: 0.4.6 type-fest: 2.19.0 - typescript: 4.8.4 - yargs: 17.5.1 + typescript: 4.9.5 + yargs: 17.7.2 transitivePeerDependencies: - encoding - supports-color dev: true - /msw@1.2.1(typescript@5.1.6): - resolution: {integrity: sha512-bF7qWJQSmKn6bwGYVPXOxhexTCGD5oJSZg8yt8IBClxvo3Dx/1W0zqE1nX9BSWmzRsCKWfeGWcB/vpqV6aclpw==} + /msw/1.2.2: + resolution: {integrity: sha512-GsW3PE/Es/a1tYThXcM8YHOZ1S1MtivcS3He/LQbbTCx3rbWJYCtWD5XXyJ53KlNPT7O1VI9sCW3xMtgFe8XpQ==} engines: {node: '>=14'} hasBin: true requiresBuild: true peerDependencies: - typescript: '>= 4.4.x <= 5.0.x' + typescript: '>= 4.4.x <= 5.1.x' peerDependenciesMeta: typescript: optional: true dependencies: '@mswjs/cookies': 0.2.2 - '@mswjs/interceptors': 0.17.6 + '@mswjs/interceptors': 0.17.9 '@open-draft/until': 1.0.3 '@types/cookie': 0.4.1 '@types/js-levenshtein': 1.1.1 chalk: 4.1.1 chokidar: 3.5.3 cookie: 0.4.2 - graphql: 16.6.0 + graphql: 16.7.1 headers-polyfill: 3.1.2 - inquirer: 8.2.4 + inquirer: 8.2.5 is-node-process: 1.2.0 js-levenshtein: 1.1.6 - node-fetch: 2.6.7 + node-fetch: 2.6.12 outvariant: 1.4.0 path-to-regexp: 6.2.1 strict-event-emitter: 0.4.6 type-fest: 2.19.0 - typescript: 5.1.6 - yargs: 17.7.1 + yargs: 17.7.2 transitivePeerDependencies: - encoding - supports-color dev: true - /mute-stream@0.0.8: + /mute-stream/0.0.8: resolution: {integrity: sha512-nnbWWOkoWyUsTjKrhgD0dcz22mdkSnpYqbEjIm2nhwhuxlSkpywJmBo8h0ZqJdkp73mb90SssHkN4rsRaBAfAA==} dev: true - /mute-stream@1.0.0: + /mute-stream/1.0.0: resolution: {integrity: sha512-avsJQhyd+680gKXyG/sQc0nXaC6rBkPOfyHYcFb9+hdkqQkR9bdnkJ0AMZhke0oesPqIO+mFFJ+IdBc7mst4IA==} engines: {node: ^14.17.0 || ^16.13.0 || >=18.0.0} dev: true - /mz@2.7.0: + /mz/2.7.0: resolution: {integrity: sha512-z81GNO7nnYMEhrGh9LeymoE4+Yr0Wn5McHIZMK5cfQCl+NDX08sCZgUc9/6MHni9IWuFLm1Z3HTCXu2z9fN62Q==} dependencies: any-promise: 1.3.0 @@ -19371,24 +16587,23 @@ packages: thenify-all: 1.6.0 dev: true - /nan@2.16.0: - resolution: {integrity: sha512-UdAqHyFngu7TfQKsCBgAA6pWDkT8MAO7d0jyOecVhN5354xbLqdn8mV9Tat9gepAupm0bt2DbeaSC8vS52MuFA==} - requiresBuild: true + /nan/2.17.0: + resolution: {integrity: sha512-2ZTgtl0nJsO0KQCjEpxcIr5D+Yv90plTitZt9JBfQvVJDS5seMl3FOvsh3+9CoYWXf/1l5OaZzzF6nDm4cagaQ==} dev: true optional: true - /nano-time@1.0.0: - resolution: {integrity: sha1-sFVPaa2J4i0JB/ehKwmTpdlhN+8=} + /nano-time/1.0.0: + resolution: {integrity: sha512-flnngywOoQ0lLQOTRNexn2gGSNuM9bKj9RZAWSzhQ+UJYaAFG9bac4DW9VHjUAzrOaIcajHybCTHe/bkvozQqA==} dependencies: big-integer: 1.6.51 dev: false - /nanoid@3.3.6: + /nanoid/3.3.6: resolution: {integrity: sha512-BGcqMMJuToF7i1rt+2PWSNVnWIkGCU78jBG3RxO/bZlnZPK2Cmi2QaffxGO/2RvWi9sL+FAiRiXMgsyxQ1DIDA==} engines: {node: ^10 || ^12 || ^13.7 || ^14 || >=15.0.1} hasBin: true - /nanomatch@1.2.13: + /nanomatch/1.2.13: resolution: {integrity: sha512-fpoe2T0RbHwBTBUOftAfBPaDEi06ufaUai0mE6Yn1kacc3SnTErfb/h+X94VXzI64rKFHYImXSvdwGGCmwOqCA==} engines: {node: '>=0.10.0'} dependencies: @@ -19407,42 +16622,42 @@ packages: - supports-color dev: true - /napi-build-utils@1.0.2: + /napi-build-utils/1.0.2: resolution: {integrity: sha512-ONmRUqK7zj7DWX0D9ADe03wbwOBZxNAfF20PlGfCWQcD3+/MakShIHrMqx9YwPTfxDdF1zLeL+RGZiR9kGMLdg==} dev: true - /natural-compare-lite@1.4.0: + /natural-compare-lite/1.4.0: resolution: {integrity: sha512-Tj+HTDSJJKaZnfiuw+iaF9skdPpTo2GtEly5JHnWV/hfv2Qj/9RKsGISQtLh2ox3l5EAGw487hnBee0sIJ6v2g==} dev: true - /natural-compare@1.4.0: + /natural-compare/1.4.0: resolution: {integrity: sha512-OWND8ei3VtNC9h7V60qff3SVobHr996CTwgxubgyQYEpg290h9J0buyECNNJexkFm5sOajh5G116RYA1c8ZMSw==} dev: true - /nearley@2.20.1: + /nearley/2.20.1: resolution: {integrity: sha512-+Mc8UaAebFzgV+KpI5n7DasuuQCHA89dmwm7JXw3TV43ukfNQ9DnBH3Mdb2g/I4Fdxc26pwimBWvjIw0UAILSQ==} hasBin: true dependencies: commander: 2.20.3 - moo: 0.5.1 + moo: 0.5.2 railroad-diagrams: 1.0.0 randexp: 0.4.6 dev: true - /negotiator@0.6.3: + /negotiator/0.6.3: resolution: {integrity: sha512-+EUsqGPLsM+j/zdChZjsnX51g4XrHFOIXwfnCVPGlQk/k5giakcKsuxCObBRu6DSm9opw/O6slWbJdghQM4bBg==} engines: {node: '>= 0.6'} dev: true - /neo-async@2.6.2: + /neo-async/2.6.2: resolution: {integrity: sha512-Yd3UES5mWCSqR+qNT93S3UoYUkqAZ9lLg8a7g9rimsWmYGK8cVToA4/sF3RrshdyV3sAGMXVUmpMYOw+dLpOuw==} dev: true - /nested-error-stacks@2.1.1: + /nested-error-stacks/2.1.1: resolution: {integrity: sha512-9iN1ka/9zmX1ZvLV9ewJYEk9h7RyRRtqdK0woXcqohu8EWIerfPUjYJPg0ULy0UqP7cslmdGc8xKDJcojlKiaw==} dev: true - /next@12.1.5(@babel/core@7.22.5)(react-dom@18.0.0)(react@18.0.0): + /next/12.1.5_zpnidt7m3osuk7shl3s4oenomq: resolution: {integrity: sha512-YGHDpyfgCfnT5GZObsKepmRnne7Kzp7nGrac07dikhutWQug7hHg85/+sPJ4ZW5Q2pDkb+n0FnmLkmd44htIJQ==} engines: {node: '>=12.22.0'} hasBin: true @@ -19461,11 +16676,11 @@ packages: optional: true dependencies: '@next/env': 12.1.5 - caniuse-lite: 1.0.30001385 + caniuse-lite: 1.0.30001515 postcss: 8.4.5 react: 18.0.0 - react-dom: 18.0.0(react@18.0.0) - styled-jsx: 5.0.1(@babel/core@7.22.5)(react@18.0.0) + react-dom: 18.0.0_react@18.0.0 + styled-jsx: 5.0.1_react@18.0.0 optionalDependencies: '@next/swc-android-arm-eabi': 12.1.5 '@next/swc-android-arm64': 12.1.5 @@ -19484,45 +16699,45 @@ packages: - babel-plugin-macros dev: false - /nice-try@1.0.5: + /nice-try/1.0.5: resolution: {integrity: sha512-1nh45deeb5olNY7eX82BkPO7SSxR5SSYJiPTrTdFUVYwAl8CKMA5N9PjTYkHiRjisVcxcQ1HXdLhx2qxxJzLNQ==} dev: true - /no-case@3.0.4: + /no-case/3.0.4: resolution: {integrity: sha512-fgAN3jGAh+RoxUGZHTSOLJIqUc2wmoBwGR4tbpNAKmmovFoWq0OdRkb0VkldReO2a2iBT/OEulG9XSUc10r3zg==} dependencies: lower-case: 2.0.2 - tslib: 2.5.3 + tslib: 2.6.0 dev: true - /node-abi@3.45.0: + /node-abi/3.45.0: resolution: {integrity: sha512-iwXuFrMAcFVi/ZoZiqq8BzAdsLw9kxDfTC0HMyjXfSL/6CSDAGD5UmR7azrAgWV1zKYq7dUUMj4owusBWKLsiQ==} engines: {node: '>=10'} dependencies: semver: 7.5.4 dev: true - /node-addon-api@6.1.0: + /node-addon-api/6.1.0: resolution: {integrity: sha512-+eawOlIgy680F0kBzPUNFhMZGtJ1YmqM6l4+Crf4IkImjYrO/mqPwRMh352g23uIaQKFItcQ64I7KMaJxHgAVA==} dev: true - /node-dir@0.1.17: + /node-dir/0.1.17: resolution: {integrity: sha512-tmPX422rYgofd4epzrNoOXiE8XFZYOcCq1vD7MAXCDO+O+zndlA2ztdKKMa+EeuBG5tHETpr4ml4RGgpqDCCAg==} engines: {node: '>= 0.10.5'} dependencies: minimatch: 3.1.2 dev: true - /node-fetch-native@0.1.8: + /node-fetch-native/0.1.8: resolution: {integrity: sha512-ZNaury9r0NxaT2oL65GvdGDy+5PlSaHTovT6JV5tOW07k1TQmgC0olZETa4C9KZg0+6zBr99ctTYa3Utqj9P/Q==} dev: true - /node-fetch-native@1.2.0: + /node-fetch-native/1.2.0: resolution: {integrity: sha512-5IAMBTl9p6PaAjYCnMv5FmqIF6GcZnawAVnzaCG0rX2aYZJ4CxEkZNtVPuTRug7fL7wyM5BQYTlAzcyMPi6oTQ==} dev: true - /node-fetch@2.6.11: - resolution: {integrity: sha512-4I6pdBY1EthSqDmJkiNk3JIT8cswwR9nfeW/cPdUagJYEQG7R95WRH74wpz7ma8Gh/9dI9FP+OU+0E4FvtA55w==} + /node-fetch/2.6.12: + resolution: {integrity: sha512-C/fGU2E8ToujUivIO0H+tpQ6HWo4eEmchoPIoXtxCrVghxdKq+QOHqEZW7tuP3KlV3bC8FRMO5nMCC7Zm1VP6g==} engines: {node: 4.x || >=6.0.0} peerDependencies: encoding: ^0.1.0 @@ -19531,9 +16746,8 @@ packages: optional: true dependencies: whatwg-url: 5.0.0 - dev: true - /node-fetch@2.6.7: + /node-fetch/2.6.7: resolution: {integrity: sha512-ZjMPFEfVx5j+y2yF35Kzx5sF7kDzxuDj6ziH4FFbOp87zKDZNx8yExJIb05OGF4Nlt9IHFIMBkRl41VdvcNdbQ==} engines: {node: 4.x || >=6.0.0} peerDependencies: @@ -19543,12 +16757,13 @@ packages: optional: true dependencies: whatwg-url: 5.0.0 + dev: true - /node-int64@0.4.0: + /node-int64/0.4.0: resolution: {integrity: sha512-O5lz91xSOeoXP6DulyHfllpq+Eg00MWitZIbtPfoSEvqIHdl5gfcY6hYzDWnj0qD5tz52PI08u9qUvSVeUBeHw==} dev: true - /node-libs-browser@2.2.1: + /node-libs-browser/2.2.1: resolution: {integrity: sha512-h/zcD8H9kaDZ9ALUWwlBUDo6TKF8a7qBSCSEGfjTVIYeqsioSKaAX+BN7NgiMGp6iSIXZ3PxgCu8KS3b71YK5Q==} dependencies: assert: 1.5.0 @@ -19565,21 +16780,21 @@ packages: process: 0.11.10 punycode: 1.4.1 querystring-es3: 0.2.1 - readable-stream: 2.3.7 + readable-stream: 2.3.8 stream-browserify: 2.0.2 stream-http: 2.8.3 string_decoder: 1.3.0 timers-browserify: 2.0.12 tty-browserify: 0.0.0 - url: 0.11.0 + url: 0.11.1 util: 0.11.1 vm-browserify: 1.1.2 dev: true - /node-releases@2.0.6: - resolution: {integrity: sha512-PiVXnNuFm5+iYkLBNeq5211hvO38y63T0i2KKh2KnUs3RpzJ+JtODFjkD8yjLwnDkTYF1eKXheUwdssR+NRZdg==} + /node-releases/2.0.13: + resolution: {integrity: sha512-uYr7J37ae/ORWdZeQ1xxMJe3NtdmqMC/JZK+geofDrkLUApKRHPd18/TxtBOJ4A0/+uUIliorNrfYV6s1b02eQ==} - /nopt@6.0.0: + /nopt/6.0.0: resolution: {integrity: sha512-ZwLpbTgdhuZUnZzjd7nb1ZV+4DoiC6/sfiVKok72ym/4Tlf+DFdlHYmT2JPmcNNWV6Pi3SDf1kT+A4r9RTuT9g==} engines: {node: ^12.13.0 || ^14.15.0 || >=16.0.0} hasBin: true @@ -19587,16 +16802,16 @@ packages: abbrev: 1.1.1 dev: true - /normalize-package-data@2.5.0: + /normalize-package-data/2.5.0: resolution: {integrity: sha512-/5CMN3T0R4XTj4DcGaexo+roZSdSFW/0AOOTROrjxzCG1wrWXEsGbRKevjlIL+ZDE4sZlJr5ED4YW0yqmkK+eA==} dependencies: hosted-git-info: 2.8.9 resolve: 1.22.2 - semver: 5.7.1 + semver: 5.7.2 validate-npm-package-license: 3.0.4 dev: true - /normalize-package-data@3.0.3: + /normalize-package-data/3.0.3: resolution: {integrity: sha512-p2W1sgqij3zMMyRC067Dg16bfzVH+w7hyegmpIvZ4JNjqtGOVAIvLmjBx3yP7YTe9vKJgkoNOPjwQGogDoMXFA==} engines: {node: '>=10'} dependencies: @@ -19606,30 +16821,30 @@ packages: validate-npm-package-license: 3.0.4 dev: true - /normalize-path@2.1.1: + /normalize-path/2.1.1: resolution: {integrity: sha512-3pKJwH184Xo/lnH6oyP1q2pMd7HcypqqmRs91/6/i2CGtWwIKGCkOOMTm/zXbgTEWHw1uNpNi/igc3ePOYHb6w==} engines: {node: '>=0.10.0'} dependencies: remove-trailing-separator: 1.1.0 dev: true - /normalize-path@3.0.0: + /normalize-path/3.0.0: resolution: {integrity: sha512-6eZs5Ls3WtCisHWp9S2GUy8dqkpGi4BVSz3GaqiE6ezub0512ESztXUwUB6C6IKbQkY2Pnb/mD4WYojCRwcwLA==} engines: {node: '>=0.10.0'} dev: true - /normalize-range@0.1.2: + /normalize-range/0.1.2: resolution: {integrity: sha512-bdok/XvKII3nUpklnV6P2hxtMNrCboOjAcyBuQnWEhO665FwrSNRxU+AqpsyvO6LgGYPspN+lu5CLtw4jPRKNA==} engines: {node: '>=0.10.0'} dev: true - /normalize-url@8.0.0: + /normalize-url/8.0.0: resolution: {integrity: sha512-uVFpKhj5MheNBJRTiMZ9pE/7hD1QTeEvugSJW/OmLzAp78PB5O6adfMNTvmfKhXBkvCzC+rqifWcVYpGFwTjnw==} engines: {node: '>=14.16'} dev: true - /notistack@2.0.5(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(@mui/material@5.10.3)(react-dom@18.2.0)(react@18.2.0): - resolution: {integrity: sha512-Ig2T1Muqkc1PaSQcEDrK7diKv6cBxw02Iq6uv074ySfgq524TV5lK41diAb6OSsaiWfp3aRt+T3+0MF8m2EcJQ==} + /notistack/2.0.8_tr5jdv7ejqexso4qfp7vkl3yhi: + resolution: {integrity: sha512-/IY14wkFp5qjPgKNvAdfL5Jp6q90+MjgKTPh4c81r/lW70KeuX6b9pE/4f8L4FG31cNudbN9siiFS5ql1aSLRw==} peerDependencies: '@emotion/react': ^11.4.1 '@emotion/styled': ^11.3.0 @@ -19642,16 +16857,16 @@ packages: '@emotion/styled': optional: true dependencies: - '@emotion/react': 11.10.4(@babel/core@7.22.5)(react@18.2.0) - '@emotion/styled': 11.10.4(@babel/core@7.22.5)(@emotion/react@11.10.4)(react@18.2.0) - '@mui/material': 5.10.3(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(react-dom@18.2.0)(react@18.2.0) + '@emotion/react': 11.11.1_react@18.2.0 + '@emotion/styled': 11.11.0_xo5t6f4ryb2nvjgwj2cxjowrye + '@mui/material': 5.14.0_vizhjgize6w4e5tnsjmztd65da clsx: 1.2.1 hoist-non-react-statics: 3.3.2 react: 18.2.0 - react-dom: 18.2.0(react@18.2.0) + react-dom: 18.2.0_react@18.2.0 dev: false - /npm-run-all@4.1.5: + /npm-run-all/4.1.5: resolution: {integrity: sha512-Oo82gJDAVcaMdi3nuoKFavkIHBRVqQ1qvMb+9LHk/cF4P6B2m8aP04hGf7oL6wZ9BuGwX1onlLhpuoofSyoQDQ==} engines: {node: '>= 4'} hasBin: true @@ -19663,32 +16878,32 @@ packages: minimatch: 3.1.2 pidtree: 0.3.1 read-pkg: 3.0.0 - shell-quote: 1.7.4 - string.prototype.padend: 3.1.3 + shell-quote: 1.8.1 + string.prototype.padend: 3.1.4 dev: true - /npm-run-path@2.0.2: + /npm-run-path/2.0.2: resolution: {integrity: sha512-lJxZYlT4DW/bRUtFh1MQIWqmLwQfAxnqWG4HhEdjMlkrJYnJn0Jrr2u3mgxqaWsdiBc76TYkTG/mhrnYTuzfHw==} engines: {node: '>=4'} dependencies: path-key: 2.0.1 dev: true - /npm-run-path@4.0.1: + /npm-run-path/4.0.1: resolution: {integrity: sha512-S48WzZW777zhNIrn7gxOlISNAqi9ZC/uQFnRdbeIHhZhCA6UqpkOT8T1G7BvfdgP4Er8gF4sUbaS0i7QvIfCWw==} engines: {node: '>=8'} dependencies: path-key: 3.1.1 dev: true - /npm-run-path@5.1.0: + /npm-run-path/5.1.0: resolution: {integrity: sha512-sJOdmRGrY2sjNTRMbSvluQqg+8X7ZK61yvzBEIDhz4f8z1TZFYABsqjjCBd/0PUNE9M6QDgHJXQkGUEm7Q+l9Q==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dependencies: path-key: 4.0.0 dev: true - /npmlog@5.0.1: + /npmlog/5.0.1: resolution: {integrity: sha512-AqZtDUWOMKs1G/8lwylVjrdYgqA4d9nu8hc+0gzRxlDb1I10+FHBGMXs6aiQHFdCUUlqH99MUMuLfzWDNDtfxw==} dependencies: are-we-there-yet: 2.0.0 @@ -19697,33 +16912,25 @@ packages: set-blocking: 2.0.0 dev: true - /nth-check@2.1.1: + /nth-check/2.1.1: resolution: {integrity: sha512-lqjrjmaOoAnWfMmBPL+XNnynZh2+swxiX3WUE0s4yEHI6m+AwrK2UZOimIRl3X/4QctVqS8AiZjFqyOGrMXb/w==} dependencies: boolbase: 1.0.0 dev: true - /num2fraction@1.2.2: + /num2fraction/1.2.2: resolution: {integrity: sha512-Y1wZESM7VUThYY+4W+X4ySH2maqcA+p7UR+w8VWNWVAd6lwuXXWz/w/Cz43J/dI2I+PS6wD5N+bJUF+gjWvIqg==} dev: true - /nwsapi@2.2.1: - resolution: {integrity: sha512-JYOWTeFoS0Z93587vRJgASD5Ut11fYl5NyihP3KrYBvMe1FRRs6RN7m20SA/16GM4P6hTnZjT+UmDOt38UeXNg==} - dev: true - - /nwsapi@2.2.2: - resolution: {integrity: sha512-90yv+6538zuvUMnN+zCr8LuV6bPFdq50304114vJYJ8RDyK8D5O9Phpbd6SZWgI7PwzmmfN1upeOJlvybDSgCw==} - dev: true - - /nwsapi@2.2.4: - resolution: {integrity: sha512-NHj4rzRo0tQdijE9ZqAx6kYDcoRwYwSYzCA8MY3JzfxlrvEU0jhnhJT9BhqhJs7I/dKcrDm6TyulaRqZPIhN5g==} + /nwsapi/2.2.7: + resolution: {integrity: sha512-ub5E4+FBPKwAZx0UwIQOjYWGHTEq5sPqHQNRN8Z9e4A7u3Tj1weLJsL59yH9vmvqEtBHaOmT6cYQKIZOxp35FQ==} dev: true - /object-assign@4.1.1: + /object-assign/4.1.1: resolution: {integrity: sha512-rJgTQnkUnH1sFw8yT6VSU3zD3sWmu6sZhIseY8VX+GRu3P6F7Fu+JNDoXfklElbLJSnc3FUQHVe4cU5hj+BcUg==} engines: {node: '>=0.10.0'} - /object-copy@0.1.0: + /object-copy/0.1.0: resolution: {integrity: sha512-79LYn6VAb63zgtmAteVOWo9Vdj71ZVBy3Pbse+VqxDpEP83XuujMrGqHIwAXJ5I/aM0zU7dIyIAhifVTPrNItQ==} engines: {node: '>=0.10.0'} dependencies: @@ -19732,15 +16939,11 @@ packages: kind-of: 3.2.2 dev: true - /object-inspect@1.12.2: - resolution: {integrity: sha512-z+cPxW0QGUp0mcqcsgQyLVRDoXFQbXOwBaqyF7VIgI4TWNQsDHrBpUQslRmIfAoYWdYzs6UlKJtB2XJpTaNSpQ==} - dev: true - - /object-inspect@1.12.3: + /object-inspect/1.12.3: resolution: {integrity: sha512-geUvdk7c+eizMNUDkRpW1wJwgfOiOeHbxBR/hLXK1aT6zmVSO0jsQcs7fj6MGw89jC/cjGfLcNOrtMYtGqm81g==} dev: true - /object-is@1.1.5: + /object-is/1.1.5: resolution: {integrity: sha512-3cyDsyHgtmi7I7DfSSI2LDp6SK2lwvtbg0p0R1e0RvTqF5ceGx+K2dfSjm1bKDMVCFEDAQvy+o8c6a7VujOddw==} engines: {node: '>= 0.4'} dependencies: @@ -19748,19 +16951,19 @@ packages: define-properties: 1.2.0 dev: true - /object-keys@1.1.1: + /object-keys/1.1.1: resolution: {integrity: sha512-NuAESUOUMrlIXOfHKzD6bpPu3tYt3xvjNdRIQ+FeT0lNb4K8WR70CaDxhuNguS2XG+GjkyMwOzsN5ZktImfhLA==} engines: {node: '>= 0.4'} dev: true - /object-visit@1.0.1: + /object-visit/1.0.1: resolution: {integrity: sha512-GBaMwwAVK9qbQN3Scdo0OyvgPW7l3lnaVMj84uTOZlswkX0KpF6fyDBJhtTthf7pymztoN36/KEr1DyhF96zEA==} engines: {node: '>=0.10.0'} dependencies: isobject: 3.0.1 dev: true - /object.assign@4.1.4: + /object.assign/4.1.4: resolution: {integrity: sha512-1mxKf0e58bvyjSCtKYY4sRe9itRk3PJpquJOjeIkz885CczcI4IvJJDLPS72oowuSh+pBxUFROpX+TU++hxhZQ==} engines: {node: '>= 0.4'} dependencies: @@ -19770,72 +16973,64 @@ packages: object-keys: 1.1.1 dev: true - /object.entries@1.1.5: - resolution: {integrity: sha512-TyxmjUoZggd4OrrU1W66FMDG6CuqJxsFvymeyXI51+vQLN67zYfZseptRge703kKQdo4uccgAKebXFcRCzk4+g==} + /object.entries/1.1.6: + resolution: {integrity: sha512-leTPzo4Zvg3pmbQ3rDK69Rl8GQvIqMWubrkxONG9/ojtFE2rD9fjMKfSI5BxW3osRH1m6VdzmqK8oAY9aT4x5w==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.20.4 + es-abstract: 1.21.2 dev: true - /object.fromentries@2.0.5: - resolution: {integrity: sha512-CAyG5mWQRRiBU57Re4FKoTBjXfDoNwdFVH2Y1tS9PqCsfUTymAohOkEMSG3aRNKmv4lV3O7p1et7c187q6bynw==} + /object.fromentries/2.0.6: + resolution: {integrity: sha512-VciD13dswC4j1Xt5394WR4MzmAQmlgN72phd/riNp9vtD7tp4QQWJ0R4wvclXcafgcYK8veHRed2W6XeGBvcfg==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.20.4 + es-abstract: 1.21.2 dev: true - /object.getownpropertydescriptors@2.1.4: - resolution: {integrity: sha512-sccv3L/pMModT6dJAYF3fzGMVcb38ysQ0tEE6ixv2yXJDtEIPph268OlAdJj5/qZMZDq2g/jqvwppt36uS/uQQ==} + /object.getownpropertydescriptors/2.1.6: + resolution: {integrity: sha512-lq+61g26E/BgHv0ZTFgRvi7NMEPuAxLkFU7rukXjc/AlwH4Am5xXVnIXy3un1bg/JPbXHrixRkK1itUzzPiIjQ==} engines: {node: '>= 0.8'} dependencies: - array.prototype.reduce: 1.0.4 + array.prototype.reduce: 1.0.5 call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.20.4 + es-abstract: 1.21.2 + safe-array-concat: 1.0.0 dev: true - /object.pick@1.3.0: + /object.pick/1.3.0: resolution: {integrity: sha512-tqa/UMy/CCoYmj+H5qc07qvSL9dqcs/WZENZ1JbtWBlATP+iVOe778gE6MSijnyCnORzDuX6hU+LA4SZ09YjFQ==} engines: {node: '>=0.10.0'} dependencies: isobject: 3.0.1 dev: true - /object.values@1.1.5: - resolution: {integrity: sha512-QUZRW0ilQ3PnPpbNtgdNV1PDbEqLIiSFB3l+EnGtBQ/8SUTLj1PZwtQHABZtLgwpJZTSZhuGLOGk57Drx2IvYg==} - engines: {node: '>= 0.4'} - dependencies: - call-bind: 1.0.2 - define-properties: 1.2.0 - es-abstract: 1.20.4 - dev: true - - /object.values@1.1.6: + /object.values/1.1.6: resolution: {integrity: sha512-FVVTkD1vENCsAcwNs9k6jea2uHC/X0+JcjG8YA60FN5CMaJmG95wT9jek/xX9nornqGRrBkKtzuAu2wuHpKqvw==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.20.4 + es-abstract: 1.21.2 dev: true - /objectorarray@1.0.5: + /objectorarray/1.0.5: resolution: {integrity: sha512-eJJDYkhJFFbBBAxeh8xW+weHlkI28n2ZdQV/J/DNfWfSKlGEf2xcfAbZTv3riEXHAhL9SVOTs2pRmXiSTf78xg==} dev: true - /oblivious-set@1.0.0: + /oblivious-set/1.0.0: resolution: {integrity: sha512-z+pI07qxo4c2CulUHCDf9lcqDlMSo72N/4rLUpRXf6fu+q8vjt8y0xS+Tlf8NTJDdTXHbdeO1n3MlbctwEoXZw==} dev: false - /obuf@1.1.2: + /obuf/1.1.2: resolution: {integrity: sha512-PX1wu0AmAdPqOL1mWhqmlOd8kOIZQwGZw6rh7uby9fTc5lhaOWFLX3I6R1hrF9k3zUY40e6igsLGkDXK92LJNg==} dev: true - /ofetch@1.1.1: + /ofetch/1.1.1: resolution: {integrity: sha512-SSMoktrp9SNLi20BWfB/BnnKcL0RDigXThD/mZBeQxkIRv1xrd9183MtLdsqRYLYSqW0eTr5t8w8MqjNhvoOQQ==} dependencies: destr: 2.0.0 @@ -19843,55 +17038,55 @@ packages: ufo: 1.1.2 dev: true - /ohash@1.1.2: + /ohash/1.1.2: resolution: {integrity: sha512-9CIOSq5945rI045GFtcO3uudyOkYVY1nyfFxVQp+9BRgslr8jPNiSSrsFGg/BNTUFOLqx0P5tng6G32brIPw0w==} dev: true - /ohmyfetch@0.4.21: + /ohmyfetch/0.4.21: resolution: {integrity: sha512-VG7f/JRvqvBOYvL0tHyEIEG7XHWm7OqIfAs6/HqwWwDfjiJ1g0huIpe5sFEmyb+7hpFa1EGNH2aERWR72tlClw==} dependencies: - destr: 1.2.0 + destr: 1.2.2 node-fetch-native: 0.1.8 ufo: 0.8.6 - undici: 5.12.0 + undici: 5.22.1 dev: true - /on-exit-leak-free@2.1.0: + /on-exit-leak-free/2.1.0: resolution: {integrity: sha512-VuCaZZAjReZ3vUwgOB8LxAosIurDiAW0s13rI1YwmaP++jvcxP77AWoQvenZebpCA2m8WC1/EosPYPMjnRAp/w==} dev: true - /on-finished@2.4.1: + /on-finished/2.4.1: resolution: {integrity: sha512-oVlzkg3ENAhCk2zdv7IJwd/QUD4z2RxRwpkcGY8psCVcCYZNq4wYnVWALHM+brtuJjePWiYF/ClmuDr8Ch5+kg==} engines: {node: '>= 0.8'} dependencies: ee-first: 1.1.1 dev: true - /on-headers@1.0.2: + /on-headers/1.0.2: resolution: {integrity: sha512-pZAE+FJLoyITytdqK0U5s+FIpjN0JP3OzFi/u8Rx+EV5/W+JTWGXG8xFzevE7AjBfDqHv/8vL8qQsIhHnqRkrA==} engines: {node: '>= 0.8'} dev: true - /once@1.4.0: + /once/1.4.0: resolution: {integrity: sha512-lNaJgI+2Q5URQBkccEKHTQOPaXdUxnZZElQTZY0MFUAuaEqe1E+Nyvgdz/aIyNi6Z9MzO5dv1H8n58/GELp3+w==} dependencies: wrappy: 1.0.2 - /onetime@5.1.2: + /onetime/5.1.2: resolution: {integrity: sha512-kbpaSSGJTWdAY5KPVeMOKXSrPtr8C8C7wodJbcsd51jRnmD+GZu8Y0VoU6Dm5Z4vWr0Ig/1NKuWRKf7j5aaYSg==} engines: {node: '>=6'} dependencies: mimic-fn: 2.1.0 dev: true - /onetime@6.0.0: + /onetime/6.0.0: resolution: {integrity: sha512-1FlR+gjXK7X+AsAHso35MnyN5KqGwJRi/31ft6x0M194ht7S+rWAvd7PHss9xSKMzE0asv1pyIHaJYq+BbacAQ==} engines: {node: '>=12'} dependencies: mimic-fn: 4.0.0 dev: true - /open@7.4.2: + /open/7.4.2: resolution: {integrity: sha512-MVHddDVweXZF3awtlAS+6pgKLlm/JgxZ90+/NBurBoQctVOOB/zDdVjcyPzQ+0laDGbsWgrRkflI65sQeOgT9Q==} engines: {node: '>=8'} dependencies: @@ -19899,8 +17094,8 @@ packages: is-wsl: 2.2.0 dev: true - /open@8.4.0: - resolution: {integrity: sha512-XgFPPM+B28FtCCgSb9I+s9szOC1vZRSwgWsRUA5ylIxRTgKozqjOCrVOqGsYABPYK5qnfqClxZTFBa8PKt2v6Q==} + /open/8.4.2: + resolution: {integrity: sha512-7x81NCL719oNbsq/3mh+hVrAWmFuEYUqrq/Iw3kUzH8ReypT9QQ0BLoJS7/G9k6N81XjW4qHWtjWwe/9eLy1EQ==} engines: {node: '>=12'} dependencies: define-lazy-prop: 2.0.0 @@ -19908,38 +17103,14 @@ packages: is-wsl: 2.2.0 dev: true - /optimism@0.16.1: - resolution: {integrity: sha512-64i+Uw3otrndfq5kaoGNoY7pvOhSsjFEN4bdEFh80MWVk/dbgJfMv7VFDeCT8LxNAlEVhQmdVEbfE7X2nWNIIg==} + /optimism/0.16.2: + resolution: {integrity: sha512-zWNbgWj+3vLEjZNIh/okkY2EUfX+vB9TJopzIZwT1xxaMqC5hRLLraePod4c5n4He08xuXNH+zhKFFCu390wiQ==} dependencies: - '@wry/context': 0.6.1 + '@wry/context': 0.7.3 '@wry/trie': 0.3.2 dev: false - /optionator@0.8.3: - resolution: {integrity: sha512-+IW9pACdk3XWmmTXG8m3upGUJst5XRGzxMRjXzAuJ1XnIFNvfhjjIuYkDvysnPQ7qzqVzLt78BCruntqRhWQbA==} - engines: {node: '>= 0.8.0'} - dependencies: - deep-is: 0.1.4 - fast-levenshtein: 2.0.6 - levn: 0.3.0 - prelude-ls: 1.1.2 - type-check: 0.3.2 - word-wrap: 1.2.3 - dev: true - - /optionator@0.9.1: - resolution: {integrity: sha512-74RlY5FCnhq4jRxVUPKDaRwrVNXMqsGsiW6AJw4XK8hmtm10wC0ypZBLw5IIp85NZMr91+qd1RvvENwg7jjRFw==} - engines: {node: '>= 0.8.0'} - dependencies: - deep-is: 0.1.4 - fast-levenshtein: 2.0.6 - levn: 0.4.1 - prelude-ls: 1.2.1 - type-check: 0.4.0 - word-wrap: 1.2.3 - dev: true - - /optionator@0.9.3: + /optionator/0.9.3: resolution: {integrity: sha512-JjCoypp+jKn1ttEFExxhetCKeJt9zhAgAve5FXHixTvFDW/5aEktX9bufBKLRRMdU7bNtpLfcGu94B3cdEJgjg==} engines: {node: '>= 0.8.0'} dependencies: @@ -19951,14 +17122,14 @@ packages: type-check: 0.4.0 dev: true - /ora@5.4.1: + /ora/5.4.1: resolution: {integrity: sha512-5b6Y85tPxZZ7QytO+BQzysW31HJku27cRIlkbAXaNx+BdcVi+LlRFmVXzeF6a7JCwJpyw5c4b+YSVImQIrBpuQ==} engines: {node: '>=10'} dependencies: bl: 4.1.0 chalk: 4.1.2 cli-cursor: 3.1.0 - cli-spinners: 2.7.0 + cli-spinners: 2.9.0 is-interactive: 1.0.0 is-unicode-supported: 0.1.0 log-symbols: 4.1.0 @@ -19966,179 +17137,175 @@ packages: wcwidth: 1.0.1 dev: true - /os-browserify@0.3.0: + /os-browserify/0.3.0: resolution: {integrity: sha512-gjcpUc3clBf9+210TRaDWbf+rZZZEshZ+DlXMRCeAjp0xhTrnQsKHypIy1J3d5hKdUzj69t708EHtU8P6bUn0A==} dev: true - /os-homedir@1.0.2: + /os-homedir/1.0.2: resolution: {integrity: sha512-B5JU3cabzk8c67mRRd3ECmROafjYMXbuzlwtqdM8IbS8ktlTix8aFGb2bAGKrSRIlnfKwovGUUr72JUPyOb6kQ==} engines: {node: '>=0.10.0'} dev: true optional: true - /os-tmpdir@1.0.2: + /os-tmpdir/1.0.2: resolution: {integrity: sha512-D2FR03Vir7FIu45XBY20mTb+/ZSWB00sjU9jdQXt83gDrI4Ztz5Fs7/yy74g2N5SVQY4xY1qDr4rNddwYRVX0g==} engines: {node: '>=0.10.0'} dev: true - /ospath@1.2.2: + /ospath/1.2.2: resolution: {integrity: sha512-o6E5qJV5zkAbIDNhGSIlyOhScKXgQrSRMilfph0clDfM0nEnBOlKlH4sWDmG95BW/CvwNz0vmm7dJVtU2KlMiA==} dev: true - /outvariant@1.3.0: - resolution: {integrity: sha512-yeWM9k6UPfG/nzxdaPlJkB2p08hCg4xP6Lx99F+vP8YF7xyZVfTmJjrrNalkmzudD4WFvNLVudQikqUmF8zhVQ==} - dev: true - - /outvariant@1.4.0: + /outvariant/1.4.0: resolution: {integrity: sha512-AlWY719RF02ujitly7Kk/0QlV+pXGFDHrHf9O2OKqyqgBieaPOIeuSkL8sRK6j2WK+/ZAURq2kZsY0d8JapUiw==} dev: true - /p-all@2.1.0: + /p-all/2.1.0: resolution: {integrity: sha512-HbZxz5FONzz/z2gJfk6bFca0BCiSRF8jU3yCsWOen/vR6lZjfPOu/e7L3uFzTW1i0H8TlC3vqQstEJPQL4/uLA==} engines: {node: '>=6'} dependencies: p-map: 2.1.0 dev: true - /p-cancelable@3.0.0: + /p-cancelable/3.0.0: resolution: {integrity: sha512-mlVgR3PGuzlo0MmTdk4cXqXWlwQDLnONTAg6sm62XkMJEiRxN3GL3SffkYvqwonbkJBcrI7Uvv5Zh9yjvn2iUw==} engines: {node: '>=12.20'} dev: true - /p-event@4.2.0: + /p-event/4.2.0: resolution: {integrity: sha512-KXatOjCRXXkSePPb1Nbi0p0m+gQAwdlbhi4wQKJPI1HsMQS9g+Sqp2o+QHziPr7eYJyOZet836KoHEVM1mwOrQ==} engines: {node: '>=8'} dependencies: p-timeout: 3.2.0 dev: true - /p-filter@2.1.0: + /p-filter/2.1.0: resolution: {integrity: sha512-ZBxxZ5sL2HghephhpGAQdoskxplTwr7ICaehZwLIlfL6acuVgZPm8yBNuRAFBGEqtD/hmUeq9eqLg2ys9Xr/yw==} engines: {node: '>=8'} dependencies: p-map: 2.1.0 dev: true - /p-finally@1.0.0: + /p-finally/1.0.0: resolution: {integrity: sha512-LICb2p9CB7FS+0eR1oqWnHhp0FljGLZCWBE9aix0Uye9W8LTQPwMTYVGWQWIw9RdQiDg4+epXQODwIYJtSJaow==} engines: {node: '>=4'} dev: true - /p-iteration@1.1.8: + /p-iteration/1.1.8: resolution: {integrity: sha512-IMFBSDIYcPNnW7uWYGrBqmvTiq7W0uB0fJn6shQZs7dlF3OvrHOre+JT9ikSZ7gZS3vWqclVgoQSvToJrns7uQ==} engines: {node: '>=8.0.0'} dev: true - /p-limit@2.3.0: + /p-limit/2.3.0: resolution: {integrity: sha512-//88mFWSJx8lxCzwdAABTJL2MyWB12+eIY7MDL2SqLmAkeKU9qxRvWuSyTjm3FUmpBEMuFfckAIqEaVGUDxb6w==} engines: {node: '>=6'} dependencies: p-try: 2.2.0 dev: true - /p-limit@3.1.0: + /p-limit/3.1.0: resolution: {integrity: sha512-TYOanM3wGwNGsZN2cVTYPArw454xnXj5qmWF1bEoAc4+cU/ol7GVh7odevjp1FNHduHc3KZMcFduxU5Xc6uJRQ==} engines: {node: '>=10'} dependencies: yocto-queue: 0.1.0 dev: true - /p-limit@4.0.0: + /p-limit/4.0.0: resolution: {integrity: sha512-5b0R4txpzjPWVw/cXXUResoD4hb6U/x9BH08L7nw+GN1sezDzPdxeRvpc9c433fZhBan/wusjbCsqwqm4EIBIQ==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dependencies: yocto-queue: 1.0.0 - /p-locate@3.0.0: + /p-locate/3.0.0: resolution: {integrity: sha512-x+12w/To+4GFfgJhBEpiDcLozRJGegY+Ei7/z0tSLkMmxGZNybVMSfWj9aJn8Z5Fc7dBUNJOOVgPv2H7IwulSQ==} engines: {node: '>=6'} dependencies: p-limit: 2.3.0 dev: true - /p-locate@4.1.0: + /p-locate/4.1.0: resolution: {integrity: sha512-R79ZZ/0wAxKGu3oYMlz8jy/kbhsNrS7SKZ7PxEHBgJ5+F2mtFW2fK2cOtBh1cHYkQsbzFV7I+EoRKe6Yt0oK7A==} engines: {node: '>=8'} dependencies: p-limit: 2.3.0 dev: true - /p-locate@5.0.0: + /p-locate/5.0.0: resolution: {integrity: sha512-LaNjtRWUBY++zB5nE/NwcaoMylSPk+S+ZHNB1TzdbMJMny6dynpAGt7X/tl/QYq3TIeE6nxHppbo2LGymrG5Pw==} engines: {node: '>=10'} dependencies: p-limit: 3.1.0 dev: true - /p-locate@6.0.0: + /p-locate/6.0.0: resolution: {integrity: sha512-wPrq66Llhl7/4AGC6I+cqxT07LhXvWL08LNXz1fENOw0Ap4sRZZ/gZpTTJ5jpurzzzfS2W/Ge9BY3LgLjCShcw==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dependencies: p-limit: 4.0.0 dev: true - /p-map@2.1.0: + /p-map/2.1.0: resolution: {integrity: sha512-y3b8Kpd8OAN444hxfBbFfj1FY/RjtTd8tzYwhUqNYXx0fXx2iX4maP4Qr6qhIKbQXI02wTLAda4fYUbDagTUFw==} engines: {node: '>=6'} dev: true - /p-map@3.0.0: + /p-map/3.0.0: resolution: {integrity: sha512-d3qXVTF/s+W+CdJ5A29wywV2n8CQQYahlgz2bFiA+4eVNJbHJodPZ+/gXwPGh0bOqA+j8S+6+ckmvLGPk1QpxQ==} engines: {node: '>=8'} dependencies: aggregate-error: 3.1.0 dev: true - /p-map@4.0.0: + /p-map/4.0.0: resolution: {integrity: sha512-/bjOqmgETBYB5BoEeGVea8dmvHb2m9GLy1E9W43yeyfP6QQCZGFNa+XRceJEuDB6zqr+gKpIAmlLebMpykw/MQ==} engines: {node: '>=10'} dependencies: aggregate-error: 3.1.0 dev: true - /p-timeout@3.2.0: + /p-timeout/3.2.0: resolution: {integrity: sha512-rhIwUycgwwKcP9yTOOFK/AKsAopjjCakVqLHePO3CC6Mir1Z99xT+R63jZxAT5lFZLa2inS5h+ZS2GvR99/FBg==} engines: {node: '>=8'} dependencies: p-finally: 1.0.0 dev: true - /p-try@2.2.0: + /p-try/2.2.0: resolution: {integrity: sha512-R4nPAVTAU0B9D35/Gk3uJf/7XYbQcyohSKdvAxIRSNghFl4e71hVoGnBNQz9cWaXxO2I10KTC+3jMdvvoKw6dQ==} engines: {node: '>=6'} dev: true - /package-name-regex@2.0.6: + /package-name-regex/2.0.6: resolution: {integrity: sha512-gFL35q7kbE/zBaPA3UKhp2vSzcPYx2ecbYuwv1ucE9Il6IIgBDweBlH8D68UFGZic2MkllKa2KHCfC1IQBQUYA==} engines: {node: '>=12'} dev: true - /pako@1.0.11: + /pako/1.0.11: resolution: {integrity: sha512-4hLB8Py4zZce5s4yd9XzopqwVv/yGNhV1Bl8NTmCq1763HeK2+EwVTv+leGeL13Dnh2wfbqowVPXCIO0z4taYw==} dev: true - /parallel-transform@1.2.0: + /parallel-transform/1.2.0: resolution: {integrity: sha512-P2vSmIu38uIlvdcU7fDkyrxj33gTUy/ABO5ZUbGowxNCopBq/OoD42bP4UmMrJoPyk4Uqf0mu3mtWBhHCZD8yg==} dependencies: - cyclist: 1.0.1 + cyclist: 1.0.2 inherits: 2.0.4 - readable-stream: 2.3.7 + readable-stream: 2.3.8 dev: true - /param-case@3.0.4: + /param-case/3.0.4: resolution: {integrity: sha512-RXlj7zCYokReqWpOPH9oYivUzLYZ5vAPIfEmCTNViosC78F8F0H9y7T7gG2M39ymgutxF5gcFEsyZQSph9Bp3A==} dependencies: dot-case: 3.0.4 - tslib: 2.5.3 + tslib: 2.6.0 dev: true - /parent-module@1.0.1: + /parent-module/1.0.1: resolution: {integrity: sha512-GQ2EWRpQV8/o+Aw8YqtfZZPfNRWZYkbidE9k5rpl/hC3vtHHBfGm2Ifi6qWV+coDGkrUKZAxE3Lot5kcsRlh+g==} engines: {node: '>=6'} dependencies: callsites: 3.1.0 - /parse-asn1@5.1.6: + /parse-asn1/5.1.6: resolution: {integrity: sha512-RnZRo1EPU6JBnra2vGHj0yhp6ebyjBZpmUCLHWiFhxlzvBCCpAuZ7elsBp1PVAbQN0/04VD/19rfzlBSwLstMw==} dependencies: asn1.js: 5.4.1 @@ -20148,12 +17315,12 @@ packages: safe-buffer: 5.2.1 dev: true - /parse-code-context@1.0.0: + /parse-code-context/1.0.0: resolution: {integrity: sha512-OZQaqKaQnR21iqhlnPfVisFjBWjhnMl5J9MgbP8xC+EwoVqbXrq78lp+9Zb3ahmLzrIX5Us/qbvBnaS3hkH6OA==} engines: {node: '>=6'} dev: true - /parse-entities@2.0.0: + /parse-entities/2.0.0: resolution: {integrity: sha512-kkywGpCcRYhqQIchaWqZ875wzpS/bMKhz5HnN3p7wveJTkTtyAB/AlnS0f8DFSqYW1T82t6yEAkEcB+A1I3MbQ==} dependencies: character-entities: 1.2.4 @@ -20164,7 +17331,7 @@ packages: is-hexadecimal: 1.0.4 dev: true - /parse-json@2.2.0: + /parse-json/2.2.0: resolution: {integrity: sha512-QR/GGaKCkhwk1ePQNYDRKYZ3mwU9ypsKhB0XyFnLQdomyEqk3e8wpW3V5Jp88zbxK4n5ST1nqo+g9juTpownhQ==} engines: {node: '>=0.10.0'} dependencies: @@ -20172,7 +17339,7 @@ packages: dev: true optional: true - /parse-json@4.0.0: + /parse-json/4.0.0: resolution: {integrity: sha512-aOIos8bujGN93/8Ox/jPLh7RwVnPEysynVFE+fQZyg6jKELEHwzgKdLRFHUgXJL6kylijVSBC4BvN9OmsB48Rw==} engines: {node: '>=4'} dependencies: @@ -20180,7 +17347,7 @@ packages: json-parse-better-errors: 1.0.2 dev: true - /parse-json@5.2.0: + /parse-json/5.2.0: resolution: {integrity: sha512-ayCKvm/phCGxOkYRSCM82iDwct8/EonSEgCSxWxD7ve6jHggsFl4fZVQBPRNgQoKiuV/odhFrGzQXZwbifC8Rg==} engines: {node: '>=8'} dependencies: @@ -20189,61 +17356,49 @@ packages: json-parse-even-better-errors: 2.3.1 lines-and-columns: 1.2.4 - /parse5-htmlparser2-tree-adapter@7.0.0: + /parse5-htmlparser2-tree-adapter/7.0.0: resolution: {integrity: sha512-B77tOZrqqfUfnVcOrUvfdLbz4pu4RopLD/4vmu3HUPswwTA8OH0EMW9BlWR2B0RCoiZRAHEUu7IxeP1Pd1UU+g==} dependencies: domhandler: 5.0.3 parse5: 7.1.2 dev: true - /parse5@6.0.1: + /parse5/6.0.1: resolution: {integrity: sha512-Ofn/CTFzRGTTxwpNEs9PP93gXShHcTq255nzRYSKe8AkVpZY7e1fpmTfOyoIvjP5HG7Z2ZM7VS9PPhQGW2pOpw==} dev: true - /parse5@7.0.0: - resolution: {integrity: sha512-y/t8IXSPWTuRZqXc0ajH/UwDj4mnqLEbSttNbThcFhGrZuOyoyvNBO85PBp2jQa55wY9d07PBNjsK8ZP3K5U6g==} - dependencies: - entities: 4.5.0 - dev: true - - /parse5@7.1.1: - resolution: {integrity: sha512-kwpuwzB+px5WUg9pyK0IcK/shltJN5/OVhQagxhCQNtT9Y9QRZqNY2e1cmbu/paRh5LMnz/oVTVLBpjFmMZhSg==} - dependencies: - entities: 4.5.0 - dev: true - - /parse5@7.1.2: + /parse5/7.1.2: resolution: {integrity: sha512-Czj1WaSVpaoj0wbhMzLmWD69anp2WH7FXMB9n1Sy8/ZFF9jolSQVMu1Ij5WIyGmcBmhk7EOndpO4mIpihVqAXw==} dependencies: entities: 4.5.0 dev: true - /parseurl@1.3.3: + /parseurl/1.3.3: resolution: {integrity: sha512-CiyeOxFT/JZyN5m0z9PfXw4SCBJ6Sygz1Dpl0wqjlhDEGGBP1GnsUVEL0p63hoG1fcj3fHynXi9NYO4nWOL+qQ==} engines: {node: '>= 0.8'} dev: true - /pascal-case@3.1.2: + /pascal-case/3.1.2: resolution: {integrity: sha512-uWlGT3YSnK9x3BQJaOdcZwrnV6hPpd8jFH1/ucpiLRPh/2zCVJKS19E4GvYHvaCcACn3foXZ0cLB9Wrx1KGe5g==} dependencies: no-case: 3.0.4 - tslib: 2.5.3 + tslib: 2.6.0 dev: true - /pascalcase@0.1.1: + /pascalcase/0.1.1: resolution: {integrity: sha512-XHXfu/yOQRy9vYOtUDVMN60OEJjW013GoObG1o+xwQTpB9eYJX/BjXMsdW13ZDPruFhYYn0AG22w0xgQMwl3Nw==} engines: {node: '>=0.10.0'} dev: true - /path-browserify@0.0.1: + /path-browserify/0.0.1: resolution: {integrity: sha512-BapA40NHICOS+USX9SN4tyhq+A2RrN/Ws5F0Z5aMHDp98Fl86lX8Oti8B7uN93L4Ifv4fHOEA+pQw87gmMO/lQ==} dev: true - /path-dirname@1.0.2: + /path-dirname/1.0.2: resolution: {integrity: sha512-ALzNPpyNq9AqXMBjeymIjFDAkAFH06mHJH/cSBHAgU0s4vfpBn6b2nf8tiRLvagKD8RbTpq2FKTBg7cl9l3c7Q==} dev: true - /path-exists@2.1.0: + /path-exists/2.1.0: resolution: {integrity: sha512-yTltuKuhtNeFJKa1PiRzfLAU5182q1y4Eb4XCJ3PBqyzEDkAZRzBrKKBct682ls9reBVHf9udYLN5Nd+K1B9BQ==} engines: {node: '>=0.10.0'} dependencies: @@ -20251,96 +17406,92 @@ packages: dev: true optional: true - /path-exists@3.0.0: + /path-exists/3.0.0: resolution: {integrity: sha512-bpC7GYwiDYQ4wYLe+FA8lhRjhQCMcQGuSgGGqDkg/QerRWw9CmGRT0iSOVRSZJ29NMLZgIzqaljJ63oaL4NIJQ==} engines: {node: '>=4'} dev: true - /path-exists@4.0.0: + /path-exists/4.0.0: resolution: {integrity: sha512-ak9Qy5Q7jYb2Wwcey5Fpvg2KoAc/ZIhLSLOSBmRmygPsGwkVVt0fZa0qrtMz+m6tJTAHfZQ8FnmB4MG4LWy7/w==} engines: {node: '>=8'} dev: true - /path-exists@5.0.0: + /path-exists/5.0.0: resolution: {integrity: sha512-RjhtfwJOxzcFmNOi6ltcbcu4Iu+FL3zEj83dk4kAS+fVpTxXLO1b38RvJgT/0QwvV/L3aY9TAnyv0EOqW4GoMQ==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dev: true - /path-is-absolute@1.0.1: + /path-is-absolute/1.0.1: resolution: {integrity: sha512-AVbw3UJ2e9bq64vSaS9Am0fje1Pa8pbGqTTsmXfaIiMpnr5DlDhfJOuLj9Sf95ZPVDAUerDfEk88MPmPe7UCQg==} engines: {node: '>=0.10.0'} - /path-key@2.0.1: + /path-key/2.0.1: resolution: {integrity: sha512-fEHGKCSmUSDPv4uoj8AlD+joPlq3peND+HRYyxFz4KPw4z926S/b8rIuFs2FYJg3BwsxJf6A9/3eIdLaYC+9Dw==} engines: {node: '>=4'} dev: true - /path-key@3.1.1: + /path-key/3.1.1: resolution: {integrity: sha512-ojmeN0qd+y0jszEtoY48r0Peq5dwMEkIlCOu6Q5f41lfkswXuKtYrhgoTpLnyIcHm24Uhqx+5Tqm2InSwLhE6Q==} engines: {node: '>=8'} dev: true - /path-key@4.0.0: + /path-key/4.0.0: resolution: {integrity: sha512-haREypq7xkM7ErfgIyA0z+Bj4AGKlMSdlQE2jvJo6huWD1EdkKYV+G/T4nq0YEF2vgTT8kqMFKo1uHn950r4SQ==} engines: {node: '>=12'} dev: true - /path-parse@1.0.7: + /path-parse/1.0.7: resolution: {integrity: sha512-LDJzPVEEEPR+y48z93A0Ed0yXb8pAByGWo/k5YYdYgpY2/2EsOsksJrq7lOHxryrVOn1ejG6oAp8ahvOIQD8sw==} - /path-scurry@1.7.0: - resolution: {integrity: sha512-UkZUeDjczjYRE495+9thsgcVgsaCPkaw80slmfVFgllxY+IO8ubTsOpFVjDPROBqJdHfVPUFRHPBV/WciOVfWg==} + /path-scurry/1.10.1: + resolution: {integrity: sha512-MkhCqzzBEpPvxxQ71Md0b1Kk51W01lrYvlMzSUaIzNsODdd7mqhiimSZlr+VegAz5Z6Vzt9Xg2ttE//XBhH3EQ==} engines: {node: '>=16 || 14 >=14.17'} dependencies: - lru-cache: 9.1.1 - minipass: 5.0.0 + lru-cache: 10.0.0 + minipass: 7.0.2 dev: true - /path-to-regexp@0.1.7: + /path-to-regexp/0.1.7: resolution: {integrity: sha512-5DFkuoqlv1uYQKxy8omFBeJPQcdoE07Kv2sferDCrAq1ohOU+MSDswDIbnx3YAM60qIOnYa53wBhXW0EbMonrQ==} dev: true - /path-to-regexp@6.2.1: + /path-to-regexp/6.2.1: resolution: {integrity: sha512-JLyh7xT1kizaEvcaXOQwOc2/Yhw6KZOvPf1S8401UyLk86CU79LN3vl7ztXGm/pZ+YjoyAJ4rxmHwbkBXJX+yw==} dev: true - /path-type@1.1.0: + /path-type/1.1.0: resolution: {integrity: sha512-S4eENJz1pkiQn9Znv33Q+deTOKmbl+jj1Fl+qiP/vYezj+S8x+J3Uo0ISrx/QoEvIlOaDWJhPaRd1flJ9HXZqg==} engines: {node: '>=0.10.0'} dependencies: - graceful-fs: 4.2.10 + graceful-fs: 4.2.11 pify: 2.3.0 pinkie-promise: 2.0.1 dev: true optional: true - /path-type@3.0.0: + /path-type/3.0.0: resolution: {integrity: sha512-T2ZUsdZFHgA3u4e5PfPbjd7HDDpxPnQb5jN0SrDsjNSuVXHJqtwTnWqG0B1jZrgmJ/7lj1EmVIByWt1gxGkWvg==} engines: {node: '>=4'} dependencies: pify: 3.0.0 dev: true - /path-type@4.0.0: + /path-type/4.0.0: resolution: {integrity: sha512-gDKb8aZMDeD/tZWs9P6+q0J9Mwkdl6xMV8TjnGP3qJVJ06bdMgkbBlLU8IdfOsIsFz2BW1rNVT3XuNEl8zPAvw==} engines: {node: '>=8'} - /pathe@0.3.9: + /pathe/0.3.9: resolution: {integrity: sha512-6Y6s0vT112P3jD8dGfuS6r+lpa0qqNrLyHPOwvXMnyNTQaYiwgau2DP3aNDsR13xqtGj7rrPo+jFUATpU6/s+g==} dev: true - /pathe@1.1.0: - resolution: {integrity: sha512-ODbEPR0KKHqECXW1GoxdDb+AZvULmXjVPy4rt+pGo2+TnjJTIPJQSVS6N63n8T2Ip+syHhbn52OewKicV0373w==} - dev: true - - /pathe@1.1.1: + /pathe/1.1.1: resolution: {integrity: sha512-d+RQGp0MAYTIaDBIMmOfMwz3E+LOZnxx1HZd5R18mmCZY0QBlK0LDZfPc8FW8Ed2DlvsuE6PRjroDY+wg4+j/Q==} - /pathval@1.1.1: + /pathval/1.1.1: resolution: {integrity: sha512-Dp6zGqpTdETdR63lehJYPeIOqpiNBNtc7BpWSLrOje7UaIsE5aY92r/AunQA7rsXvet3lrJ3JnZX29UPTKXyKQ==} dev: false - /pbkdf2@3.1.2: + /pbkdf2/3.1.2: resolution: {integrity: sha512-iuh7L6jA7JEGu2WxDwtQP1ddOpaJNC4KlDEFfdQajSGgGPNi4OyDc2R7QnbY2bR9QjBVGwgvTdNJZoE7RaxUMA==} engines: {node: '>=0.12'} dependencies: @@ -20351,23 +17502,19 @@ packages: sha.js: 2.4.11 dev: true - /pend@1.2.0: + /pend/1.2.0: resolution: {integrity: sha512-F3asv42UuXchdzt+xXqfW1OGlVBe+mxa2mqI0pg5yAHZPvFmY3Y6drSf/GQ1A86WgWEN9Kzh/WrgKa6iGcHXLg==} dev: true - /perfect-debounce@0.1.3: - resolution: {integrity: sha512-NOT9AcKiDGpnV/HBhI22Str++XWcErO/bALvHCuhv33owZW/CjH8KAFLZDCmu3727sihe0wTxpDhyGc6M8qacQ==} - dev: true - - /perfect-debounce@1.0.0: + /perfect-debounce/1.0.0: resolution: {integrity: sha512-xCy9V055GLEqoFaHoC1SoLIaLmWctgCUaBaWxDZ7/Zx4CTyX7cJQLJOok/orfjZAh9kEYpjJa4d0KcJmCbctZA==} dev: true - /performance-now@2.1.0: + /performance-now/2.1.0: resolution: {integrity: sha512-7EAHlyLHI56VEIdK57uwHdHKIaAGbnXPiw0yWbarQZOKaKpvUIgW0jWRVLiatnM+XXlSwsanIBH/hzGMJulMow==} dev: true - /periscopic@3.1.0: + /periscopic/3.1.0: resolution: {integrity: sha512-vKiQ8RRtkl9P+r/+oefh25C3fhybptkHKCZSPlcXiJux2tJF55GnEj3BVn4A5gKfq9NWWXXrxkHBwVPUfH0opw==} dependencies: '@types/estree': 1.0.1 @@ -20375,45 +17522,45 @@ packages: is-reference: 3.0.1 dev: true - /picocolors@0.2.1: + /picocolors/0.2.1: resolution: {integrity: sha512-cMlDqaLEqfSaW8Z7N5Jw+lyIW869EzT73/F5lhtY9cLGoVxSXznfgfXMO0Z5K0o0Q2TkTXq+0KFsdnSe3jDViA==} dev: true - /picocolors@1.0.0: + /picocolors/1.0.0: resolution: {integrity: sha512-1fygroTLlHu66zi26VoTDv8yRgm0Fccecssto+MhsZ0D/DGW2sm8E8AjW7NU5VVTRt5GxbeZ5qBuJr+HyLYkjQ==} - /picomatch@2.3.1: + /picomatch/2.3.1: resolution: {integrity: sha512-JU3teHTNjmE2VCGFzuY8EXzCDVwEqB2a8fsIvwaStHhAWJEeVd1o1QD80CU6+ZdEXXSLbSsuLwJjkCBWqRQUVA==} engines: {node: '>=8.6'} - /pidtree@0.3.1: + /pidtree/0.3.1: resolution: {integrity: sha512-qQbW94hLHEqCg7nhby4yRC7G2+jYHY4Rguc2bjw7Uug4GIJuu1tvf2uHaZv5Q8zdt+WKJ6qK1FOI6amaWUo5FA==} engines: {node: '>=0.10'} hasBin: true dev: true - /pidtree@0.6.0: + /pidtree/0.6.0: resolution: {integrity: sha512-eG2dWTVw5bzqGRztnHExczNxt5VGsE6OwTeCG3fdUf9KBsZzO3R5OIIIzWR+iZA0NtZ+RDVdaoE2dK1cn6jH4g==} engines: {node: '>=0.10'} hasBin: true dev: true - /pify@2.3.0: + /pify/2.3.0: resolution: {integrity: sha512-udgsAY+fTnvv7kI7aaxbqwWNb0AHiB0qBO89PZKPkoTmGOgdbrHDKD+0B2X4uTfJ/FT1R09r9gTsjUjNJotuog==} engines: {node: '>=0.10.0'} dev: true - /pify@3.0.0: + /pify/3.0.0: resolution: {integrity: sha512-C3FsVNH1udSEX48gGX1xfvwTWfsYWj5U+8/uK15BGzIGrKoUpghX8hWZwa/OFnakBiiVNmBvemTJR5mcy7iPcg==} engines: {node: '>=4'} dev: true - /pify@4.0.1: + /pify/4.0.1: resolution: {integrity: sha512-uB80kBFb/tfd68bVleG9T5GGsGPjJrLAUpR5PZIrhBnIaRTQRjqdJSsIKkOP6OAIFbj7GOrcudc5pNjZ+geV2g==} engines: {node: '>=6'} dev: true - /pinkie-promise@2.0.1: + /pinkie-promise/2.0.1: resolution: {integrity: sha512-0Gni6D4UcLTbv9c57DfxDGdr41XfgUjqWZu492f0cIGr16zDU06BWP/RAEvOuo7CQ0CNjHaLlM59YJJFm3NWlw==} engines: {node: '>=0.10.0'} dependencies: @@ -20421,174 +17568,153 @@ packages: dev: true optional: true - /pinkie@2.0.4: + /pinkie/2.0.4: resolution: {integrity: sha512-MnUuEycAemtSaeFSjXKW/aroV7akBbY+Sv+RkyqFjgAe73F+MR0TBWKBRDkmfWq/HiFmdavfZ1G7h4SPZXaCSg==} engines: {node: '>=0.10.0'} dev: true optional: true - /pino-abstract-transport@1.0.0: + /pino-abstract-transport/1.0.0: resolution: {integrity: sha512-c7vo5OpW4wIS42hUVcT5REsL8ZljsUfBjqV/e2sFxmFEFZiq1XLUp5EYLtuDH6PEHq9W1egWqRbnLUP5FuZmOA==} dependencies: - readable-stream: 4.1.0 - split2: 4.1.0 + readable-stream: 4.4.2 + split2: 4.2.0 dev: true - /pino-std-serializers@6.0.0: - resolution: {integrity: sha512-mMMOwSKrmyl+Y12Ri2xhH1lbzQxwwpuru9VjyJpgFIH4asSj88F2csdMwN6+M5g1Ll4rmsYghHLQJw81tgZ7LQ==} + /pino-std-serializers/6.2.2: + resolution: {integrity: sha512-cHjPPsE+vhj/tnhCy/wiMh3M3z3h/j15zHQX+S9GkTBgqJuTuJzYJ4gUyACLhDaJ7kk9ba9iRDmbH2tJU03OiA==} dev: true - /pino@8.5.0: - resolution: {integrity: sha512-PuD6sOti8Y+p9zRoNB5dibmfjfM/OU2tEtJFICxw5ulXi1d0qnq/Rt3CsR6aBEAOeyCXP+ZUfiNWW+tt55pNzg==} + /pino/8.14.1: + resolution: {integrity: sha512-8LYNv7BKWXSfS+k6oEc6occy5La+q2sPwU3q2ljTX5AZk7v+5kND2o5W794FyRaqha6DJajmkNRsWtPpFyMUdw==} hasBin: true dependencies: atomic-sleep: 1.0.0 - fast-redact: 3.1.2 + fast-redact: 3.2.0 on-exit-leak-free: 2.1.0 pino-abstract-transport: 1.0.0 - pino-std-serializers: 6.0.0 - process-warning: 2.0.0 + pino-std-serializers: 6.2.2 + process-warning: 2.2.0 quick-format-unescaped: 4.0.4 real-require: 0.2.0 - safe-stable-stringify: 2.3.1 - sonic-boom: 3.2.0 - thread-stream: 2.1.0 + safe-stable-stringify: 2.4.3 + sonic-boom: 3.3.0 + thread-stream: 2.3.0 dev: true - /pirates@4.0.5: - resolution: {integrity: sha512-8V9+HQPupnaXMA23c5hvl69zXvTwTzyAYasnkb0Tts4XvO4CliqONMOnvlq26rkhLC3nWDFBJf73LU1e1VZLaQ==} + /pirates/4.0.6: + resolution: {integrity: sha512-saLsH7WeYYPiD25LDuLRRY/i+6HaPYr6G1OUlN39otzkSTxKnubR9RTxS3/Kk50s1g2JTgFwWQDQyplC5/SHZg==} engines: {node: '>= 6'} dev: true - /pixelmatch@5.3.0: + /pixelmatch/5.3.0: resolution: {integrity: sha512-o8mkY4E/+LNUf6LzX96ht6k6CEDi65k9G2rjMtBe9Oo+VPKSvl+0GKHuH/AlG+GA5LPG/i5hrekkxUc3s2HU+Q==} hasBin: true dependencies: pngjs: 6.0.0 dev: true - /pkg-dir@3.0.0: + /pkg-dir/3.0.0: resolution: {integrity: sha512-/E57AYkoeQ25qkxMj5PBOVgF8Kiu/h7cYS30Z5+R7WaiCCBfLq58ZI/dSeaEKb9WVJV5n/03QwrN3IeWIFllvw==} engines: {node: '>=6'} dependencies: find-up: 3.0.0 dev: true - /pkg-dir@4.2.0: + /pkg-dir/4.2.0: resolution: {integrity: sha512-HRDzbaKjC+AOWVXxAU/x54COGeIv9eb+6CkDSQoNTt4XyWoIJvuPsXizxu/Fr23EiekbtZwmh1IcIG/l/a10GQ==} engines: {node: '>=8'} dependencies: find-up: 4.1.0 dev: true - /pkg-dir@5.0.0: + /pkg-dir/5.0.0: resolution: {integrity: sha512-NPE8TDbzl/3YQYY7CSS228s3g2ollTFnc+Qi3tqmqJp9Vg2ovUpixcJEo2HJScN2Ez+kEaal6y70c0ehqJBJeA==} engines: {node: '>=10'} dependencies: find-up: 5.0.0 dev: true - /pkg-types@1.0.3: + /pkg-types/1.0.3: resolution: {integrity: sha512-nN7pYi0AQqJnoLPC9eHFQ8AcyaixBUOwvqc5TDnIKCMEE6I0y8P7OKA7fPexsXGCGxQDl/cmrLAp26LhcwxZ4A==} dependencies: jsonc-parser: 3.2.0 mlly: 1.4.0 pathe: 1.1.1 - /playwright-chromium@1.30.0: - resolution: {integrity: sha512-ZfqjYdFuxnZxK02mDZtHFK/Mi0+cjCVn51RmwLwLLHA8PkCExk0odmZH2REx+LjqX8tDLGnmf6vDnPAirdSY0g==} - engines: {node: '>=14'} + /playwright-chromium/1.36.0: + resolution: {integrity: sha512-AU4/euzKqiIeK7JMsxMlgVx3jRFOnXF0vkptF9mfqeNSETVYCbovZ9EpwJ3Kzm/vVAmIlpHp+VoXdX2bi+05Zg==} + engines: {node: '>=16'} hasBin: true requiresBuild: true dependencies: - playwright-core: 1.30.0 - dev: true - - /playwright-core@1.28.0: - resolution: {integrity: sha512-nJLknd28kPBiCNTbqpu6Wmkrh63OEqJSFw9xOfL9qxfNwody7h6/L3O2dZoWQ6Oxcm0VOHjWmGiCUGkc0X3VZA==} - engines: {node: '>=14'} - hasBin: true - dev: true - - /playwright-core@1.30.0: - resolution: {integrity: sha512-7AnRmTCf+GVYhHbLJsGUtskWTE33SwMZkybJ0v6rqR1boxq2x36U7p1vDRV7HO2IwTZgmycracLxPEJI49wu4g==} - engines: {node: '>=14'} - hasBin: true + playwright-core: 1.36.0 dev: true - /playwright-core@1.35.1: - resolution: {integrity: sha512-pNXb6CQ7OqmGDRspEjlxE49w+4YtR6a3X6mT1hZXeJHWmsEz7SunmvZeiG/+y1yyMZdHnnn73WKYdtV1er0Xyg==} + /playwright-core/1.36.0: + resolution: {integrity: sha512-7RTr8P6YJPAqB+8j5ATGHqD6LvLLM39sYVNsslh78g8QeLcBs5750c6+msjrHUwwGt+kEbczBj1XB22WMwn+WA==} engines: {node: '>=16'} hasBin: true dev: true - /playwright@1.28.0: - resolution: {integrity: sha512-kyOXGc5y1mgi+hgEcCIyE1P1+JumLrxS09nFHo5sdJNzrucxPRAGwM4A2X3u3SDOfdgJqx61yIoR6Av+5plJPg==} - engines: {node: '>=14'} - hasBin: true - requiresBuild: true - dependencies: - playwright-core: 1.28.0 - dev: true - - /playwright@1.35.1: - resolution: {integrity: sha512-NbwBeGJLu5m7VGM0+xtlmLAH9VUfWwYOhUi/lSEDyGg46r1CA9RWlvoc5yywxR9AzQb0mOCm7bWtOXV7/w43ZA==} + /playwright/1.36.0: + resolution: {integrity: sha512-ODVOTp5WoRMxDJY3liMmC+wVNicc0cQB17gASvQ+zLBggVK9a2x3gdT5mbl7av+zomvtdirWOqqfD+O6qIrFgw==} engines: {node: '>=16'} hasBin: true requiresBuild: true dependencies: - playwright-core: 1.35.1 + playwright-core: 1.36.0 dev: true - /pluralize@8.0.0: + /pluralize/8.0.0: resolution: {integrity: sha512-Nc3IT5yHzflTfbjgqWcCPpo7DaKy4FnpB0l/zCAW0Tc7jxAiuqSxHasntB3D7887LSrA93kDJ9IXovxJYxyLCA==} engines: {node: '>=4'} dev: true - /pngjs@3.4.0: + /pngjs/3.4.0: resolution: {integrity: sha512-NCrCHhWmnQklfH4MtJMRjZ2a8c80qXeMlQMv2uVp9ISJMTt562SbGd6n2oq0PaPgKm7Z6pL9E2UlLIhC+SHL3w==} engines: {node: '>=4.0.0'} dev: true - /pngjs@6.0.0: + /pngjs/6.0.0: resolution: {integrity: sha512-TRzzuFRRmEoSW/p1KVAmiOgPco2Irlah+bGFCeNfJXxxYGwSw7YwAOAcd7X28K/m5bjBWKsC29KyoMfHbypayg==} engines: {node: '>=12.13.0'} dev: true - /pnp-webpack-plugin@1.6.4(typescript@4.8.4): + /pnp-webpack-plugin/1.6.4_typescript@4.9.5: resolution: {integrity: sha512-7Wjy+9E3WwLOEL30D+m8TSTF7qJJUJLONBnwQp0518siuMxUQUbgZwssaFX+QKlZkjHZcw/IpZCt/H0srrntSg==} engines: {node: '>=6'} dependencies: - ts-pnp: 1.2.0(typescript@4.8.4) + ts-pnp: 1.2.0_typescript@4.9.5 transitivePeerDependencies: - typescript dev: true - /pnpm@8.6.6: + /pnpm/8.6.6: resolution: {integrity: sha512-a51bIJyCmvstgCvsWf6SgZnsXfWmwAW1pHWEaH2gN3vqQGC58yLFL/oKBwcZWH0mjpMzBWRXdS9dLdN6GAK2Rw==} engines: {node: '>=16.14'} hasBin: true dev: true - /polished@4.2.2: + /polished/4.2.2: resolution: {integrity: sha512-Sz2Lkdxz6F2Pgnpi9U5Ng/WdWAUZxmHrNPoVlm3aAemxoy2Qy7LGjQg4uf8qKelDAUW94F4np3iH2YPf2qefcQ==} engines: {node: '>=10'} dependencies: - '@babel/runtime': 7.18.9 + '@babel/runtime': 7.22.6 dev: true - /posix-character-classes@0.1.1: + /posix-character-classes/0.1.1: resolution: {integrity: sha512-xTgYBc3fuo7Yt7JbiuFxSYGToMoz8fLoE6TC9Wx1P/u+LfeThMOAqmuyECnlBaaJb+u1m9hHiXUEtwW4OzfUJg==} engines: {node: '>=0.10.0'} dev: true - /postcss-flexbugs-fixes@4.2.1: + /postcss-flexbugs-fixes/4.2.1: resolution: {integrity: sha512-9SiofaZ9CWpQWxOwRh1b/r85KD5y7GgvsNt1056k6OYLvWUun0czCvogfJgylC22uJTwW1KzY3Gz65NZRlvoiQ==} dependencies: postcss: 7.0.39 dev: true - /postcss-load-config@3.1.4(ts-node@10.9.1): + /postcss-load-config/3.1.4_ts-node@10.9.1: resolution: {integrity: sha512-6DiM4E7v4coTE4uzA8U//WhtPwyhiim3eyjEMFCnUpzbrkK9wJHgKDT2mR+HbtSrd/NubVaYTOpSpjUl8NQeRg==} engines: {node: '>= 10'} peerDependencies: @@ -20601,75 +17727,75 @@ packages: optional: true dependencies: lilconfig: 2.1.0 - ts-node: 10.9.1(@types/node@18.16.19)(typescript@5.1.6) + ts-node: 10.9.1_pqdfkuhuhnwv2d7uogwywwxtqq yaml: 1.10.2 dev: true - /postcss-loader@4.3.0(postcss@7.0.39)(webpack@4.46.0): + /postcss-loader/4.3.0_gzaxsinx64nntyd3vmdqwl7coe: resolution: {integrity: sha512-M/dSoIiNDOo8Rk0mUqoj4kpGq91gcxCfb9PoyZVdZ76/AuhxylHDYZblNE8o+EQ9AMSASeMFEKxZf5aU6wlx1Q==} engines: {node: '>= 10.13.0'} peerDependencies: postcss: ^7.0.0 || ^8.0.1 webpack: ^4.0.0 || ^5.0.0 dependencies: - cosmiconfig: 7.0.1 - klona: 2.0.5 - loader-utils: 2.0.2 + cosmiconfig: 7.1.0 + klona: 2.0.6 + loader-utils: 2.0.4 postcss: 7.0.39 - schema-utils: 3.1.1 + schema-utils: 3.3.0 semver: 7.5.4 webpack: 4.46.0 dev: true - /postcss-modules-extract-imports@2.0.0: + /postcss-modules-extract-imports/2.0.0: resolution: {integrity: sha512-LaYLDNS4SG8Q5WAWqIJgdHPJrDDr/Lv775rMBFUbgjTz6j34lUznACHcdRWroPvXANP2Vj7yNK57vp9eFqzLWQ==} engines: {node: '>= 6'} dependencies: postcss: 7.0.39 dev: true - /postcss-modules-local-by-default@3.0.3: + /postcss-modules-local-by-default/3.0.3: resolution: {integrity: sha512-e3xDq+LotiGesympRlKNgaJ0PCzoUIdpH0dj47iWAui/kyTgh3CiAr1qP54uodmJhl6p9rN6BoNcdEDVJx9RDw==} engines: {node: '>= 6'} dependencies: icss-utils: 4.1.1 postcss: 7.0.39 - postcss-selector-parser: 6.0.10 + postcss-selector-parser: 6.0.13 postcss-value-parser: 4.2.0 dev: true - /postcss-modules-scope@2.2.0: + /postcss-modules-scope/2.2.0: resolution: {integrity: sha512-YyEgsTMRpNd+HmyC7H/mh3y+MeFWevy7V1evVhJWewmMbjDHIbZbOXICC2y+m1xI1UVfIT1HMW/O04Hxyu9oXQ==} engines: {node: '>= 6'} dependencies: postcss: 7.0.39 - postcss-selector-parser: 6.0.10 + postcss-selector-parser: 6.0.13 dev: true - /postcss-modules-values@3.0.0: + /postcss-modules-values/3.0.0: resolution: {integrity: sha512-1//E5jCBrZ9DmRX+zCtmQtRSV6PV42Ix7Bzj9GbwJceduuf7IqP8MgeTXuRDHOWj2m0VzZD5+roFWDuU8RQjcg==} dependencies: icss-utils: 4.1.1 postcss: 7.0.39 dev: true - /postcss-selector-parser@6.0.10: - resolution: {integrity: sha512-IQ7TZdoaqbT+LCpShg46jnZVlhWD2w6iQYAcYXfHARZ7X1t/UGhhceQDs5X0cGqKvYlHNOuv7Oa1xmb0oQuA3w==} + /postcss-selector-parser/6.0.13: + resolution: {integrity: sha512-EaV1Gl4mUEV4ddhDnv/xtj7sxwrwxdetHdWUGnT4VJQf+4d05v6lHYZr8N573k5Z0BViss7BDhfWtKS3+sfAqQ==} engines: {node: '>=4'} dependencies: cssesc: 3.0.0 util-deprecate: 1.0.2 dev: true - /postcss-value-parser@3.3.1: + /postcss-value-parser/3.3.1: resolution: {integrity: sha512-pISE66AbVkp4fDQ7VHBwRNXzAAKJjw4Vw7nWI/+Q3vuly7SNfgYXvm6i5IgFylHGK5sP/xHAbB7N49OS4gWNyQ==} dev: false - /postcss-value-parser@4.2.0: + /postcss-value-parser/4.2.0: resolution: {integrity: sha512-1NNCs6uurfkVbeXG4S8JFT9t19m45ICnif8zWLd5oPSZ50QnwMfK+H3jv408d4jw/7Bttv5axS5IiHoLaVNHeQ==} dev: true - /postcss@7.0.39: + /postcss/7.0.39: resolution: {integrity: sha512-yioayjNbHn6z1/Bywyb2Y4s3yvDAeXGOyxqD+LnVOinq6Mdmd++SW2wUNVzavyyHxd6+DxzWGIuosg6P1Rj8uA==} engines: {node: '>=6.0.0'} dependencies: @@ -20677,15 +17803,15 @@ packages: source-map: 0.6.1 dev: true - /postcss@8.4.24: - resolution: {integrity: sha512-M0RzbcI0sO/XJNucsGjvWU9ERWxb/ytp1w6dKtxTKgixdtQDq4rmx/g8W1hnaheq9jgwL/oyEdH5Bc4WwJKMqg==} + /postcss/8.4.25: + resolution: {integrity: sha512-7taJ/8t2av0Z+sQEvNzCkpDynl0tX3uJMCODi6nT3PfASC7dYCWV9aQ+uiCf+KBD4SEFcu+GvJdGdwzQ6OSjCw==} engines: {node: ^10 || ^12 || >=14} dependencies: nanoid: 3.3.6 picocolors: 1.0.0 source-map-js: 1.0.2 - /postcss@8.4.5: + /postcss/8.4.5: resolution: {integrity: sha512-jBDboWM8qpaqwkMwItqTQTiFikhs/67OYVvblFFTM7MrZjt6yMKd6r2kgXizEbTTljacm4NldIlZnhbjr84QYg==} engines: {node: ^10 || ^12 || >=14} dependencies: @@ -20694,11 +17820,11 @@ packages: source-map-js: 1.0.2 dev: false - /preact@10.10.6: - resolution: {integrity: sha512-w0mCL5vICUAZrh1DuHEdOWBjxdO62lvcO++jbzr8UhhYcTbFkpegLH9XX+7MadjTl/y0feoqwQ/zAnzkc/EGog==} + /preact/10.16.0: + resolution: {integrity: sha512-XTSj3dJ4roKIC93pald6rWuB2qQJO9gO2iLLyTe87MrjQN+HklueLsmskbywEWqCHlclgz3/M4YLL2iBr9UmMA==} dev: true - /prebuild-install@7.1.1: + /prebuild-install/7.1.1: resolution: {integrity: sha512-jAXscXWMcCK8GgCoHOfIr0ODh5ai8mj63L2nWrjuAgXE6tDyYGnx4/8o/rCgU+B4JSyZBKbeZqzhtwtC3ovxjw==} engines: {node: '>=10'} hasBin: true @@ -20717,62 +17843,51 @@ packages: tunnel-agent: 0.6.0 dev: true - /prelude-ls@1.1.2: - resolution: {integrity: sha512-ESF23V4SKG6lVSGZgYNpbsiaAkdab6ZgOxe52p7+Kid3W3u3bxR4Vfd/o21dmN7jSt0IwgZ4v5MUd26FEtXE9w==} - engines: {node: '>= 0.8.0'} - dev: true - - /prelude-ls@1.2.1: + /prelude-ls/1.2.1: resolution: {integrity: sha512-vkcDPrRZo1QZLbn5RLGPpg/WmIQ65qoWWhcGKf/b5eplkkarX0m9z8ppCat4mlOqUsWpyNuYgO3VRyrYHSzX5g==} engines: {node: '>= 0.8.0'} dev: true - /prettier-plugin-svelte@2.10.1(prettier@2.8.8)(svelte@3.59.1): + /prettier-plugin-svelte/2.10.1_jlgs5vq3kify7hyf3gm4oz2klm: resolution: {integrity: sha512-Wlq7Z5v2ueCubWo0TZzKc9XHcm7TDxqcuzRuGd0gcENfzfT4JZ9yDlCbEgxWgiPmLHkBjfOtpAWkcT28MCDpUQ==} peerDependencies: prettier: ^1.16.4 || ^2.0.0 svelte: ^3.2.0 || ^4.0.0-next.0 dependencies: prettier: 2.8.8 - svelte: 3.59.1 + svelte: 3.59.2 dev: true - /prettier@2.3.0: + /prettier/2.3.0: resolution: {integrity: sha512-kXtO4s0Lz/DW/IJ9QdWhAf7/NmPWQXkFr/r/WkR3vyI+0v8amTDxiaQSLzs8NBlytfLWX/7uQUMIW677yLKl4w==} engines: {node: '>=10.13.0'} hasBin: true dev: true - /prettier@2.7.1: - resolution: {integrity: sha512-ujppO+MkdPqoVINuDFDRLClm7D78qbDt0/NR+wp5FqEZOoTNAjPHWj17QRhu7geIHJfcNhRk1XVQmF8Bp3ye+g==} - engines: {node: '>=10.13.0'} - hasBin: true - dev: true - - /prettier@2.8.8: + /prettier/2.8.8: resolution: {integrity: sha512-tdN8qQGvNjw4CHbY+XXk0JgCXn9QiF21a55rBe5LJAU+kDyC4WQn4+awm2Xfk2lQMk5fKup9XgzTZtGkjBdP9Q==} engines: {node: '>=10.13.0'} hasBin: true dev: true - /pretty-bytes@5.6.0: + /pretty-bytes/5.6.0: resolution: {integrity: sha512-FFw039TmrBqFK8ma/7OL3sDz/VytdtJr044/QUJtH0wK9lb9jLq9tJyIxUwtQJHwar2BqtiA4iCWSwo9JLkzFg==} engines: {node: '>=6'} dev: true - /pretty-bytes@6.0.0: - resolution: {integrity: sha512-6UqkYefdogmzqAZWzJ7laYeJnaXDy2/J+ZqiiMtS7t7OfpXWTlaeGMwX8U6EFvPV/YWWEKRkS8hKS4k60WHTOg==} + /pretty-bytes/6.1.0: + resolution: {integrity: sha512-Rk753HI8f4uivXi4ZCIYdhmG1V+WKzvRMg/X+M42a6t7D07RcmopXJMDNk6N++7Bl75URRGsb40ruvg7Hcp2wQ==} engines: {node: ^14.13.1 || >=16.0.0} dev: true - /pretty-error@2.1.2: + /pretty-error/2.1.2: resolution: {integrity: sha512-EY5oDzmsX5wvuynAByrmY0P0hcp+QpnAKbJng2A2MPjVKXCxrDSUkzghVJ4ZGPIv+JC4gX8fPUWscC0RtjsWGw==} dependencies: lodash: 4.17.21 renderkid: 2.0.7 dev: true - /pretty-format@27.5.1: + /pretty-format/27.5.1: resolution: {integrity: sha512-Qb1gy5OrP5+zDf2Bvnzdl3jsTf1qXVMazbvCoKhtKqVs4/YK4ozX4gKQJJVyNe+cajNPn0KoC0MC3FUmaHWEmQ==} engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: @@ -20781,47 +17896,56 @@ packages: react-is: 17.0.2 dev: true - /pretty-format@29.5.0: - resolution: {integrity: sha512-V2mGkI31qdttvTFX7Mt4efOqHXqJWMu4/r66Xh3Z3BwZaPfPJgp6/gbwoujRpPUtfEF6AUUWx3Jim3GCw5g/Qw==} + /pretty-format/29.6.1: + resolution: {integrity: sha512-7jRj+yXO0W7e4/tSJKoR7HRIHLPPjtNaUGG2xxKQnGvPNRkgWcQ0AZX6P4KBRJN4FcTBWb3sa7DVUJmocYuoog==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: - '@jest/schemas': 29.4.3 + '@jest/schemas': 29.6.0 ansi-styles: 5.2.0 react-is: 18.2.0 - /pretty-hrtime@1.0.3: + /pretty-hrtime/1.0.3: resolution: {integrity: sha512-66hKPCr+72mlfiSjlEB1+45IjXSqvVAIy6mocupoww4tBFE9R9IhwwUGoI4G++Tc9Aq+2rxOt0RFU6gPcrte0A==} engines: {node: '>= 0.8'} dev: true - /pretty@2.0.0: + /pretty/2.0.0: resolution: {integrity: sha512-G9xUchgTEiNpormdYBl+Pha50gOUovT18IvAe7EYMZ1/f9W/WWMPRn+xI68yXNMUk3QXHDwo/1wV/4NejVNe1w==} engines: {node: '>=0.10.0'} dependencies: condense-newlines: 0.2.1 extend-shallow: 2.0.1 - js-beautify: 1.14.6 + js-beautify: 1.14.8 dev: true - /process-nextick-args@2.0.1: + /process-nextick-args/2.0.1: resolution: {integrity: sha512-3ouUOpQhtgrbOa17J7+uxOTpITYWaGP7/AhoR3+A+/1e9skrzelGi/dXzEYyvbxubEF6Wn2ypscTKiKJFFn1ag==} dev: true - /process-warning@2.0.0: - resolution: {integrity: sha512-+MmoAXoUX+VTHAlwns0h+kFUWFs/3FZy+ZuchkgjyOu3oioLAo2LB5aCfKPh2+P9O18i3m43tUEv3YqttSy0Ww==} + /process-warning/2.2.0: + resolution: {integrity: sha512-/1WZ8+VQjR6avWOgHeEPd7SDQmFQ1B5mC1eRXsCm5TarlNmx/wCsa5GEaxGm05BORRtyG/Ex/3xq3TuRvq57qg==} dev: true - /process@0.11.10: + /process/0.11.10: resolution: {integrity: sha512-cdGef/drWFoydD1JsMzuFf8100nZl+GT+yacc2bEced5f9Rjk4z+WtFUTBu9PhOi9j/jfmBPu0mMEY4wIdAF8A==} engines: {node: '>= 0.6.0'} dev: true - /progress@2.0.3: + /progress/2.0.3: resolution: {integrity: sha512-7PiHtLll5LdnKIMw100I+8xJXR5gW2QwWYkT6iJva0bXitZKa/XMrSbdmg3r2Xnaidz9Qumd0VPaMrZlF9V9sA==} engines: {node: '>=0.4.0'} dev: true - /promise-inflight@1.0.1(bluebird@3.7.2): + /promise-inflight/1.0.1: + resolution: {integrity: sha512-6zWPyEOFaQBJYcGMHBKTKJ3u6TBsnMFOIZSa6ce1e/ZrrsOlnHRHbabMjLiBYKp+n44X9eUI6VUPaukCXHuG4g==} + peerDependencies: + bluebird: '*' + peerDependenciesMeta: + bluebird: + optional: true + dev: true + + /promise-inflight/1.0.1_bluebird@3.7.2: resolution: {integrity: sha512-6zWPyEOFaQBJYcGMHBKTKJ3u6TBsnMFOIZSa6ce1e/ZrrsOlnHRHbabMjLiBYKp+n44X9eUI6VUPaukCXHuG4g==} peerDependencies: bluebird: '*' @@ -20832,28 +17956,28 @@ packages: bluebird: 3.7.2 dev: true - /promise.allsettled@1.0.5: - resolution: {integrity: sha512-tVDqeZPoBC0SlzJHzWGZ2NKAguVq2oiYj7gbggbiTvH2itHohijTp7njOUA0aQ/nl+0lr/r6egmhoYu63UZ/pQ==} + /promise.allsettled/1.0.6: + resolution: {integrity: sha512-22wJUOD3zswWFqgwjNHa1965LvqTX87WPu/lreY2KSd7SVcERfuZ4GfUaOnJNnvtoIv2yXT/W00YIGMetXtFXg==} engines: {node: '>= 0.4'} dependencies: - array.prototype.map: 1.0.4 + array.prototype.map: 1.0.5 call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.20.4 - get-intrinsic: 1.2.0 + es-abstract: 1.21.2 + get-intrinsic: 1.2.1 iterate-value: 1.0.2 dev: true - /promise.prototype.finally@3.1.3: - resolution: {integrity: sha512-EXRF3fC9/0gz4qkt/f5EP5iW4kj9oFpBICNpCNOb/52+8nlHIX07FPLbi/q4qYBQ1xZqivMzTpNQSnArVASolQ==} + /promise.prototype.finally/3.1.4: + resolution: {integrity: sha512-nNc3YbgMfLzqtqvO/q5DP6RR0SiHI9pUPGzyDf1q+usTwCN2kjvAnJkBb7bHe3o+fFSBPpsGMoYtaSi+LTNqng==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.20.4 + es-abstract: 1.21.2 dev: true - /prompts@2.4.2: + /prompts/2.4.2: resolution: {integrity: sha512-NxNv/kLguCA7p3jE8oL2aEBsrJWgAakBpgmgK6lpPWV+WuOmY6r2/zbAVnP+T8bQlA0nzHXSJSJW0Hq7ylaD2Q==} engines: {node: '>= 6'} dependencies: @@ -20861,24 +17985,24 @@ packages: sisteransi: 1.0.5 dev: true - /prop-types@15.8.1: + /prop-types/15.8.1: resolution: {integrity: sha512-oj87CgZICdulUohogVAR7AjlC0327U4el4L6eAvOqCeudMDVU0NThNaV+b9Df4dXgSP1gXMTnPdhfe/2qDH5cg==} dependencies: loose-envify: 1.4.0 object-assign: 4.1.1 react-is: 16.13.1 - /property-information@5.6.0: + /property-information/5.6.0: resolution: {integrity: sha512-YUHSPk+A30YPv+0Qf8i9Mbfe/C0hdPXk1s1jPVToV8pk8BQtpw10ct89Eo7OWkutrwqvT0eicAxlOg3dOAu8JA==} dependencies: xtend: 4.0.2 dev: true - /proto-list@1.2.4: + /proto-list/1.2.4: resolution: {integrity: sha512-vtK/94akxsTMhe0/cbfpR+syPuszcuwhqVjJq26CuNDgFGj682oRBXOP5MJpv2r7JtE8MsiepGIqvvOTBwn2vA==} dev: true - /proxy-addr@2.0.7: + /proxy-addr/2.0.7: resolution: {integrity: sha512-llQsMLSUDUPT44jdrU/O37qlnifitDP+ZwrmmZcoSKyLKvtZxpyV0n2/bD/N4tBAAZ/gJEdZU7KMraoK1+XYAg==} engines: {node: '>= 0.10'} dependencies: @@ -20886,27 +18010,27 @@ packages: ipaddr.js: 1.9.1 dev: true - /proxy-from-env@1.0.0: + /proxy-from-env/1.0.0: resolution: {integrity: sha512-F2JHgJQ1iqwnHDcQjVBsq3n/uoaFL+iPW/eAeL7kVxy/2RrWaN4WroKjjvbsoRtv0ftelNyC01bjRhn/bhcf4A==} dev: true - /proxy-from-env@1.1.0: + /proxy-from-env/1.1.0: resolution: {integrity: sha512-D+zkORCbA9f1tdWRK0RaCR3GPv50cMxcrz4X8k5LTSUD1Dkw47mKJEZQNunItRTkWwgtaUSo1RVFRIG9ZXiFYg==} dev: true - /prr@1.0.1: + /prr/1.0.1: resolution: {integrity: sha512-yPw4Sng1gWghHQWj0B3ZggWUm4qVbPwPFcRG8KyxiU7J2OHFSoEHKS+EZ3fv5l1t9CyCiop6l/ZYeWbrgoQejw==} dev: true - /pseudomap@1.0.2: + /pseudomap/1.0.2: resolution: {integrity: sha512-b/YwNhb8lk1Zz2+bXXpS/LK9OisiZZ1SNsSLxN1x2OXVEhW2Ckr/7mWE5vrC1ZTiJlD9g19jWszTmJsB+oEpFQ==} dev: true - /psl@1.9.0: + /psl/1.9.0: resolution: {integrity: sha512-E/ZsdU4HLs/68gYzgGTkMicWTLPdAftJLfJFlLUAAKZGkStNU72sZjT66SnMDVOfOWY/YAoiD7Jxa9iHvngcag==} dev: true - /public-encrypt@4.0.3: + /public-encrypt/4.0.3: resolution: {integrity: sha512-zVpa8oKZSz5bTMTFClc1fQOnyyEzpl5ozpi1B5YcvBrdohMjH2rfsBtyXcuNuwjsDIXmBYlF2N5FlJYhR29t8Q==} dependencies: bn.js: 4.12.0 @@ -20917,21 +18041,21 @@ packages: safe-buffer: 5.2.1 dev: true - /pump@2.0.1: + /pump/2.0.1: resolution: {integrity: sha512-ruPMNRkN3MHP1cWJc9OWr+T/xDP0jhXYCLfJcBuX54hhfIBnaQmAUMfDcG4DM5UMWByBbJY69QSphm3jtDKIkA==} dependencies: end-of-stream: 1.4.4 once: 1.4.0 dev: true - /pump@3.0.0: + /pump/3.0.0: resolution: {integrity: sha512-LwZy+p3SFs1Pytd/jYct4wpv49HiYCqd9Rlc5ZVdk0V+8Yzv6jR5Blk3TRmPL1ft69TxP0IMZGJ+WPFU2BFhww==} dependencies: end-of-stream: 1.4.4 once: 1.4.0 dev: true - /pumpify@1.5.1: + /pumpify/1.5.1: resolution: {integrity: sha512-oClZI37HvuUJJxSKKrC17bZ9Cu0ZYhEAGPsPUy9KlMUmv9dKX2o77RUmq7f3XjIxbwyGwYzbzQ1L2Ks8sIradQ==} dependencies: duplexify: 3.7.1 @@ -20939,20 +18063,16 @@ packages: pump: 2.0.1 dev: true - /punycode@1.3.2: - resolution: {integrity: sha512-RofWgt/7fL5wP1Y7fxE7/EmTLzQVnB0ycyibJ0OOHIlJqTNzglYFxVwETOcIoJqJmpDXJ9xImDv+Fq34F/d4Dw==} - dev: true - - /punycode@1.4.1: + /punycode/1.4.1: resolution: {integrity: sha512-jmYNElW7yvO7TV33CjSmvSiE2yco3bV2czu/OzDKdMNVZQWfxCblURLhf+47syQRBntjfLdd/H0egrzIG+oaFQ==} dev: true - /punycode@2.3.0: + /punycode/2.3.0: resolution: {integrity: sha512-rRV+zQD8tVFys26lAGR9WUuS4iUAngJScM+ZRSKtvl5tKeZ2t5bvdNFdNHBW9FWR4guGHlgmsZ1G7BSm2wTbuA==} engines: {node: '>=6'} dev: true - /puppeteer-core@20.3.0(typescript@5.1.6): + /puppeteer-core/20.3.0: resolution: {integrity: sha512-264pBrIui5bO6NJeOcbJrLa0OCwmA4+WK00JMrLIKTfRiqe2gx8KWTzLsjyw/bizErp3TKS7vt/I0i5fTC+mAw==} engines: {node: '>=16.0.0'} peerDependencies: @@ -20961,12 +18081,11 @@ packages: typescript: optional: true dependencies: - '@puppeteer/browsers': 1.3.0(typescript@5.1.6) - chromium-bidi: 0.4.9(devtools-protocol@0.0.1120988) + '@puppeteer/browsers': 1.3.0 + chromium-bidi: 0.4.9_5222unh4tkeylqma7dhccidrk4 cross-fetch: 3.1.6 - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 devtools-protocol: 0.0.1120988 - typescript: 5.1.6 ws: 8.13.0 transitivePeerDependencies: - bufferutil @@ -20975,15 +18094,16 @@ packages: - utf-8-validate dev: true - /puppeteer@13.7.0: + /puppeteer/13.7.0: resolution: {integrity: sha512-U1uufzBjz3+PkpCxFrWzh4OrMIdIb2ztzCu0YEPfRHjHswcSwHZswnK+WdsOQJsRV8WeTg3jLhJR4D867+fjsA==} engines: {node: '>=10.18.1'} + deprecated: < 19.4.0 is no longer supported requiresBuild: true dependencies: cross-fetch: 3.1.5 - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 devtools-protocol: 0.0.981744 - extract-zip: 2.0.1(supports-color@8.1.1) + extract-zip: 2.0.1 https-proxy-agent: 5.0.1 pkg-dir: 4.2.0 progress: 2.0.3 @@ -20999,76 +18119,75 @@ packages: - utf-8-validate dev: true - /qs@6.10.3: - resolution: {integrity: sha512-wr7M2E0OFRfIfJZjKGieI8lBKb7fRCH4Fv5KNPEs7gJ8jadvotdsS08PzOKR7opXhZ/Xkjtt3WF9g38drmyRqQ==} + /qs/6.10.4: + resolution: {integrity: sha512-OQiU+C+Ds5qiH91qh/mg0w+8nwQuLjM4F4M/PbmhDOoYehPh+Fb0bDjtR1sOvy7YKxvj28Y/M0PhP5uVX0kB+g==} engines: {node: '>=0.6'} dependencies: side-channel: 1.0.4 dev: true - /qs@6.11.0: + /qs/6.11.0: resolution: {integrity: sha512-MvjoMCJwEarSbUYk5O+nmoSzSutSsTwF85zcHPQ9OrlFoZOYIjaqBAJIqIXjptyD5vThxGq52Xu/MaJzRkIk4Q==} engines: {node: '>=0.6'} dependencies: side-channel: 1.0.4 dev: true - /qs@6.5.3: - resolution: {integrity: sha512-qxXIEh4pCGfHICj1mAJQ2/2XVZkjCDTcEgfoSQxc/fYivUZxTkk7L3bDBJSoNrEzXI17oUO5Dp07ktqE5KzczA==} - engines: {node: '>=0.6'} - dev: true - - /qs@6.9.3: - resolution: {integrity: sha512-EbZYNarm6138UKKq46tdx08Yo/q9ZhFoAXAI1meAFd2GtbRDhbZY2WQSICskT0c5q99aFzLG1D4nvTk9tqfXIw==} + /qs/6.11.2: + resolution: {integrity: sha512-tDNIz22aBzCDxLtVH++VnTfzxlfeK5CbqohpSqpJgj1Wg/cQbStNAz3NuqCs5vV+pjBsK4x4pN9HlVh7rcYRiA==} engines: {node: '>=0.6'} + dependencies: + side-channel: 1.0.4 dev: true - /query-selector-shadow-dom@1.0.1: + /query-selector-shadow-dom/1.0.1: resolution: {integrity: sha512-lT5yCqEBgfoMYpf3F2xQRK7zEr1rhIIZuceDK6+xRkJQ4NMbHTwXqk4NkwDwQMNqXgG9r9fyHnzwNVs6zV5KRw==} dev: true - /querystring-es3@0.2.1: + /querystring-es3/0.2.1: resolution: {integrity: sha512-773xhDQnZBMFobEiztv8LIl70ch5MSF/jUQVlhwFyBILqq96anmoctVIYz+ZRp0qbCKATTn6ev02M3r7Ga5vqA==} engines: {node: '>=0.4.x'} dev: true - /querystring@0.2.0: - resolution: {integrity: sha512-X/xY82scca2tau62i9mDyU9K+I+djTMUsvwf7xnUX5GLvVzgJybOJf4Y6o9Zx3oJK/LSXg5tTZBjwzqVPaPO2g==} - engines: {node: '>=0.4.x'} - deprecated: The querystring API is considered Legacy. new code should use the URLSearchParams API instead. - dev: true - - /querystringify@2.2.0: + /querystringify/2.2.0: resolution: {integrity: sha512-FIqgj2EUvTa7R50u0rGsyTftzjYmv/a3hO345bZNrqabNqjtgiDMgmo4mkUjd+nzU5oF3dClKqFIPUKybUyqoQ==} dev: true - /queue-microtask@1.2.3: + /queue-microtask/1.2.3: resolution: {integrity: sha512-NuaNSa6flKT5JaSYQzJok04JzTL1CA6aGhv5rfLW3PgqA+M2ChpZQnAC8h8i4ZFkBS8X5RqkDBHA7r4hej3K9A==} - /quick-format-unescaped@4.0.4: + /queue-tick/1.0.1: + resolution: {integrity: sha512-kJt5qhMxoszgU/62PLP1CJytzd2NKetjSRnyuj31fDd3Rlcz3fzlFdFLD1SItunPwyqEOkca6GbV612BWfaBag==} + dev: true + + /quick-format-unescaped/4.0.4: resolution: {integrity: sha512-tYC1Q1hgyRuHgloV/YXs2w15unPVh8qfu/qCTfhTYamaw7fyhumKa2yGpdSo87vY32rIclj+4fWYQXUMs9EHvg==} dev: true - /quick-lru@5.1.1: + /quick-lru/5.1.1: resolution: {integrity: sha512-WuyALRjWPDGtt/wzJiadO5AXY+8hZ80hVpe6MyivgraREW751X3SbhRvG3eLKOYN+8VEvqLcf3wdnt44Z4S4SA==} engines: {node: '>=10'} dev: true - /raf@3.4.1: + /raf/3.4.1: resolution: {integrity: sha512-Sq4CW4QhwOHE8ucn6J34MqtZCeWFP2aQSmrlroYgqAV1PjStIhJXxYuTgUIfkEk7zTLjmIjLmU5q+fbD1NnOJA==} dependencies: performance-now: 2.1.0 dev: true - /railroad-diagrams@1.0.0: + /railroad-diagrams/1.0.0: resolution: {integrity: sha512-cz93DjNeLY0idrCNOH6PviZGRN9GJhsdm9hpn1YCS879fj4W+x5IFJhhkRZcwVgMmFF7R82UA/7Oh+R8lLZg6A==} dev: true - /ramda@0.28.0: + /ramda/0.28.0: resolution: {integrity: sha512-9QnLuG/kPVgWvMQ4aODhsBUFKOUmnbUnsSXACv+NCQZcHbeb+v8Lodp8OVxtRULN1/xOyYLLaL6npE6dMq5QTA==} dev: true - /randexp@0.4.6: + /ramda/0.29.0: + resolution: {integrity: sha512-BBea6L67bYLtdbOqfp8f58fPMqEwx0doL+pAi8TZyp2YWz8R9G8z9x75CZI8W+ftqhFHCpEX2cRnUUXK130iKA==} + dev: true + + /randexp/0.4.6: resolution: {integrity: sha512-80WNmd9DA0tmZrw9qQa62GPPWfuXJknrmVmLcxvq4uZBdYqb1wYoKTmnlGUchvVWe0XiLupYkBoXVOxz3C8DYQ==} engines: {node: '>=0.12'} dependencies: @@ -21076,25 +18195,25 @@ packages: ret: 0.1.15 dev: true - /randombytes@2.1.0: + /randombytes/2.1.0: resolution: {integrity: sha512-vYl3iOX+4CKUWuxGi9Ukhie6fsqXqS9FE2Zaic4tNFD2N2QQaXOMFbuKK4QmDHC0JO6B1Zp41J0LpT0oR68amQ==} dependencies: safe-buffer: 5.2.1 dev: true - /randomfill@1.0.4: + /randomfill/1.0.4: resolution: {integrity: sha512-87lcbR8+MhcWcUiQ+9e+Rwx8MyR2P7qnt15ynUlbm3TU/fjbgz4GsvfSUDTemtCCtVCqb4ZcEFlyPNTh9bBTLw==} dependencies: randombytes: 2.1.0 safe-buffer: 5.2.1 dev: true - /range-parser@1.2.1: + /range-parser/1.2.1: resolution: {integrity: sha512-Hrgsx+orqoygnmhFbKaHE6c296J+HTAQXoxEF6gNupROmmGJRoyzfG3ccAveqCBrwr/2yxQ5BVd/GTl5agOwSg==} engines: {node: '>= 0.6'} dev: true - /raw-body@2.5.1: + /raw-body/2.5.1: resolution: {integrity: sha512-qqJBtEyVgS0ZmPGdCFPWJ3FreoqvG4MVQln/kCgF7Olq95IbOp0/BWyMwbdtn4VTvkM8Y7khCQ2Xgk/tcrCXig==} engines: {node: '>= 0.8'} dependencies: @@ -21104,26 +18223,18 @@ packages: unpipe: 1.0.0 dev: true - /raw-loader@4.0.2(webpack@4.46.0): + /raw-loader/4.0.2_webpack@4.46.0: resolution: {integrity: sha512-ZnScIV3ag9A4wPX/ZayxL/jZH+euYb6FcUinPcgiQW0+UBtEv0O6Q3lGd3cqJ+GHH+rksEv3Pj99oxJ3u3VIKA==} engines: {node: '>= 10.13.0'} peerDependencies: webpack: ^4.0.0 || ^5.0.0 dependencies: - loader-utils: 2.0.2 - schema-utils: 3.1.1 + loader-utils: 2.0.4 + schema-utils: 3.3.0 webpack: 4.46.0 dev: true - /rc9@2.1.0: - resolution: {integrity: sha512-ROO9bv8PPqngWKoiUZU3JDQ4sugpdRs9DfwHnzDSxK25XtQn6BEHL6EOd/OtKuDT2qodrtNR+0WkPT6l0jxH5Q==} - dependencies: - defu: 6.1.2 - destr: 1.2.2 - flat: 5.0.2 - dev: true - - /rc@1.2.8: + /rc/1.2.8: resolution: {integrity: sha512-y3bGgqKj3QBdxLbLkomlohkvsA8gdAiUQlSBJnBhfn+BPxg4bc62d8TcBW15wavDfgexCgccckhcZvywyQYPOw==} hasBin: true dependencies: @@ -21133,22 +18244,30 @@ packages: strip-json-comments: 2.0.1 dev: true - /react-docgen-typescript@2.2.2(typescript@4.8.4): + /rc9/2.1.1: + resolution: {integrity: sha512-lNeOl38Ws0eNxpO3+wD1I9rkHGQyj1NU1jlzv4go2CtEnEQEUfqnIvZG7W+bC/aXdJ27n5x/yUjb6RoT9tko+Q==} + dependencies: + defu: 6.1.2 + destr: 2.0.0 + flat: 5.0.2 + dev: true + + /react-docgen-typescript/2.2.2_typescript@4.9.5: resolution: {integrity: sha512-tvg2ZtOpOi6QDwsb3GZhOjDkkX0h8Z2gipvTg6OVMUyoYoURhEiRNePT8NZItTVCDh39JJHnLdfCOkzoLbFnTg==} peerDependencies: typescript: '>= 4.3.x' dependencies: - typescript: 4.8.4 + typescript: 4.9.5 dev: true - /react-docgen@5.4.3: + /react-docgen/5.4.3: resolution: {integrity: sha512-xlLJyOlnfr8lLEEeaDZ+X2J/KJoe6Nr9AzxnkdQWush5hz2ZSu66w6iLMOScMmxoSHWpWMn+k3v5ZiyCfcWsOA==} engines: {node: '>=8.10.0'} hasBin: true dependencies: - '@babel/core': 7.22.5 - '@babel/generator': 7.22.5 - '@babel/runtime': 7.18.9 + '@babel/core': 7.22.8 + '@babel/generator': 7.22.7 + '@babel/runtime': 7.22.6 ast-types: 0.14.2 commander: 2.20.3 doctrine: 3.0.0 @@ -21160,26 +18279,25 @@ packages: - supports-color dev: true - /react-docgen@6.0.0-alpha.3: - resolution: {integrity: sha512-DDLvB5EV9As1/zoUsct6Iz2Cupw9FObEGD3DMcIs3EDFIoSKyz8FZtoWj3Wj+oodrU4/NfidN0BL5yrapIcTSA==} - engines: {node: '>=12.0.0'} - hasBin: true + /react-docgen/6.0.1: + resolution: {integrity: sha512-K+EHJrADKJYpmojACrebABRb5e6RvW8cSeJ/0950Km5YnrSglebHeMm/uGSv/DpBvsZOsMGVQoYb8XjCA3r0NQ==} + engines: {node: '>=14.18.0'} dependencies: - '@babel/core': 7.22.5 - '@babel/generator': 7.22.5 - ast-types: 0.14.2 - commander: 2.20.3 + '@babel/core': 7.22.8 + '@babel/traverse': 7.22.8 + '@babel/types': 7.22.5 + '@types/babel__core': 7.20.1 + '@types/babel__traverse': 7.20.1 + '@types/doctrine': 0.0.5 + '@types/resolve': 1.20.2 doctrine: 3.0.0 - estree-to-babel: 3.2.1 - neo-async: 2.6.2 - node-dir: 0.1.17 resolve: 1.22.2 - strip-indent: 3.0.0 + strip-indent: 4.0.0 transitivePeerDependencies: - supports-color dev: true - /react-dom@17.0.2(react@17.0.2): + /react-dom/17.0.2_react@17.0.2: resolution: {integrity: sha512-s4h96KtLDUQlsENhMn1ar8t2bEa+q/YAtj8pPPdIjPDGBDIVNsrD9aXNWqspUe6AzKCIG0C1HZZLqLV7qpOBGA==} peerDependencies: react: 17.0.2 @@ -21189,7 +18307,7 @@ packages: react: 17.0.2 scheduler: 0.20.2 - /react-dom@18.0.0(react@18.0.0): + /react-dom/18.0.0_react@18.0.0: resolution: {integrity: sha512-XqX7uzmFo0pUceWFCt7Gff6IyIMzFUn7QMZrbrQfGxtaxXZIcGQzoNpRLE3fQLnS4XzLLPMZX2T9TRcSrasicw==} peerDependencies: react: ^18.0.0 @@ -21198,7 +18316,7 @@ packages: react: 18.0.0 scheduler: 0.21.0 - /react-dom@18.2.0(react@18.2.0): + /react-dom/18.2.0_react@18.2.0: resolution: {integrity: sha512-6IMTriUmvsjHUjNtEDudZfuDQUoWXVxKHhlEGSk81n4YFS+r/Kl99wXiwlVXtPBtJenozv2P+hxDsw9eA7Xo6g==} peerDependencies: react: ^18.2.0 @@ -21207,7 +18325,7 @@ packages: react: 18.2.0 scheduler: 0.23.0 - /react-element-to-jsx-string@14.3.4(react-dom@17.0.2)(react@17.0.2): + /react-element-to-jsx-string/14.3.4_sfoxds7t5ydpegc3knd667wn6m: resolution: {integrity: sha512-t4ZwvV6vwNxzujDQ+37bspnLwA4JlgUPWhLjBJWsNIDceAf6ZKUTCjdm08cN6WeZ5pTMKiCJkmAYnpmR4Bm+dg==} peerDependencies: react: ^0.14.8 || ^15.0.1 || ^16.0.0 || ^17.0.1 @@ -21216,37 +18334,37 @@ packages: '@base2/pretty-print-object': 1.0.1 is-plain-object: 5.0.0 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 react-is: 17.0.2 dev: true - /react-inspector@5.1.1(react@17.0.2): + /react-inspector/5.1.1_react@17.0.2: resolution: {integrity: sha512-GURDaYzoLbW8pMGXwYPDBIv6nqei4kK7LPRZ9q9HCZF54wqXz/dnylBp/kfE9XmekBhHvLDdcYeyIwSrvtOiWg==} peerDependencies: react: ^16.8.4 || ^17.0.0 dependencies: - '@babel/runtime': 7.18.9 + '@babel/runtime': 7.22.6 is-dom: 1.1.0 prop-types: 15.8.1 react: 17.0.2 dev: true - /react-is@16.13.1: + /react-is/16.13.1: resolution: {integrity: sha512-24e6ynE2H+OKt4kqsOvNd8kBpV65zoxbA4BVsEOB3ARVWQki/DHzaUoC5KuON/BiccDaCCTZBuOcfZs70kR8bQ==} - /react-is@17.0.2: + /react-is/17.0.2: resolution: {integrity: sha512-w2GsyukL62IJnlaff/nRegPQR94C/XXamvMWmSHRJ4y7Ts/4ocGRmTHvOs8PSE6pB3dWOrD/nueuU5sduBsQ4w==} dev: true - /react-is@18.2.0: + /react-is/18.2.0: resolution: {integrity: sha512-xWGDIW6x921xtzPkhiULtthJHoJvBbF3q26fzloPCK0hsvxtPVelvftw3zjbHWSkR2km9Z+4uxbDDK/6Zw9B8w==} - /react-lifecycles-compat@3.0.4: + /react-lifecycles-compat/3.0.4: resolution: {integrity: sha512-fBASbA6LnOU9dOU2eW7aQ8xmYBSXUIWr+UmF9b1efZBazGNO+rcXT/icdKnYm2pTwcRylVUYwW7H1PHfLekVzA==} dev: false - /react-query@3.39.2(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-F6hYDKyNgDQfQOuR1Rsp3VRzJnWHx6aRnnIZHMNGGgbL3SBgpZTDg8MQwmxOgpCAoqZJA+JSNCydF1xGJqKOCA==} + /react-query/3.39.3_sfoxds7t5ydpegc3knd667wn6m: + resolution: {integrity: sha512-nLfLz7GiohKTJDuT4us4X3h/8unOh+00MLb2yJoGTPjxKs2bc1iDhkNx2bd5MKklXnOD3NrVZ+J2UXujA5In4g==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: '*' @@ -21257,85 +18375,86 @@ packages: react-native: optional: true dependencies: - '@babel/runtime': 7.18.9 + '@babel/runtime': 7.22.6 broadcast-channel: 3.7.0 match-sorter: 6.3.1 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) + react-dom: 17.0.2_react@17.0.2 dev: false - /react-refresh@0.11.0: + /react-refresh/0.11.0: resolution: {integrity: sha512-F27qZr8uUqwhWZboondsPx8tnC3Ct3SxZA3V5WyEvujRyyNv0VYPhoBg1gZ8/MV5tubQp76Trw8lTv9hzRBa+A==} engines: {node: '>=0.10.0'} dev: true - /react-refresh@0.13.0: + /react-refresh/0.13.0: resolution: {integrity: sha512-XP8A9BT0CpRBD+NYLLeIhld/RqG9+gktUjW1FkE+Vm7OCinbG1SshcK5tb9ls4kzvjZr9mOQc7HYgBngEyPAXg==} engines: {node: '>=0.10.0'} dev: true - /react-refresh@0.14.0: + /react-refresh/0.14.0: resolution: {integrity: sha512-wViHqhAd8OHeLS/IRMJjTSDHF3U9eWi62F/MledQGPdJGDhodXJ9PBLNGr6WWL7qlH12Mt3TyTpbS+hGXMjCzQ==} engines: {node: '>=0.10.0'} dev: true - /react-resize-detector@7.1.2(react-dom@18.2.0)(react@18.2.0): - resolution: {integrity: sha512-zXnPJ2m8+6oq9Nn8zsep/orts9vQv3elrpA+R8XTcW7DVVUJ9vwDwMXaBtykAYjMnkCIaOoK9vObyR7ZgFNlOw==} + /react-resize-detector/8.1.0_biqbaboplfbrettd7655fr4n2y: + resolution: {integrity: sha512-S7szxlaIuiy5UqLhLL1KY3aoyGHbZzsTpYal9eYMwCyKqoqoVLCmIgAgNyIM1FhnP2KyBygASJxdhejrzjMb+w==} peerDependencies: react: ^16.0.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.0.0 || ^17.0.0 || ^18.0.0 dependencies: lodash: 4.17.21 react: 18.2.0 - react-dom: 18.2.0(react@18.2.0) + react-dom: 18.2.0_react@18.2.0 dev: false - /react-router-dom@6.3.0(react-dom@18.2.0)(react@18.2.0): - resolution: {integrity: sha512-uaJj7LKytRxZNQV8+RbzJWnJ8K2nPsOOEuX7aQstlMZKQT0164C+X2w6bnkqU3sjtLvpd5ojrezAyfZ1+0sStw==} + /react-router-dom/6.14.1_biqbaboplfbrettd7655fr4n2y: + resolution: {integrity: sha512-ssF6M5UkQjHK70fgukCJyjlda0Dgono2QGwqGvuk7D+EDGHdacEN3Yke2LTMjkrpHuFwBfDFsEjGVXBDmL+bWw==} + engines: {node: '>=14'} peerDependencies: react: '>=16.8' react-dom: '>=16.8' dependencies: - history: 5.3.0 + '@remix-run/router': 1.7.1 react: 18.2.0 - react-dom: 18.2.0(react@18.2.0) - react-router: 6.3.0(react@18.2.0) + react-dom: 18.2.0_react@18.2.0 + react-router: 6.14.1_react@18.2.0 dev: false - /react-router@6.3.0(react@18.2.0): - resolution: {integrity: sha512-7Wh1DzVQ+tlFjkeo+ujvjSqSJmkt1+8JO+T5xklPlgrh70y7ogx75ODRW0ThWhY7S+6yEDks8TYrtQe/aoboBQ==} + /react-router/6.14.1_react@18.2.0: + resolution: {integrity: sha512-U4PfgvG55LdvbQjg5Y9QRWyVxIdO1LlpYT7x+tMAxd9/vmiPuJhIwdxZuIQLN/9e3O4KFDHYfR9gzGeYMasW8g==} + engines: {node: '>=14'} peerDependencies: react: '>=16.8' dependencies: - history: 5.3.0 + '@remix-run/router': 1.7.1 react: 18.2.0 dev: false - /react-shallow-renderer@16.15.0(react@17.0.2): + /react-shallow-renderer/16.15.0_react@17.0.2: resolution: {integrity: sha512-oScf2FqQ9LFVQgA73vr86xl2NaOIX73rh+YFqcOp68CWj56tSfgtGKrEbyhCj0rSijyG9M1CYprTh39fBi5hzA==} peerDependencies: react: ^16.0.0 || ^17.0.0 || ^18.0.0 dependencies: object-assign: 4.1.1 react: 17.0.2 - react-is: 18.2.0 + react-is: 17.0.2 dev: true - /react-smooth@2.0.1(prop-types@15.8.1)(react-dom@18.2.0)(react@18.2.0): - resolution: {integrity: sha512-Own9TA0GPPf3as4vSwFhDouVfXP15ie/wIHklhyKBH5AN6NFtdk0UpHBnonV11BtqDkAWlt40MOUc+5srmW7NA==} + /react-smooth/2.0.3_biqbaboplfbrettd7655fr4n2y: + resolution: {integrity: sha512-yl4y3XiMorss7ayF5QnBiSprig0+qFHui8uh7Hgg46QX5O+aRMRKlfGGNGLHno35JkQSvSYY8eCWkBfHfrSHfg==} peerDependencies: prop-types: ^15.6.0 react: ^15.0.0 || ^16.0.0 || ^17.0.0 || ^18.0.0 react-dom: ^15.0.0 || ^16.0.0 || ^17.0.0 || ^18.0.0 dependencies: - fast-equals: 2.0.4 - prop-types: 15.8.1 + fast-equals: 5.0.1 react: 18.2.0 - react-dom: 18.2.0(react@18.2.0) - react-transition-group: 2.9.0(react-dom@18.2.0)(react@18.2.0) + react-dom: 18.2.0_react@18.2.0 + react-transition-group: 2.9.0_biqbaboplfbrettd7655fr4n2y dev: false - /react-test-renderer@17.0.2(react@17.0.2): + /react-test-renderer/17.0.2_react@17.0.2: resolution: {integrity: sha512-yaQ9cB89c17PUb0x6UfWRs7kQCorVdHlutU1boVPEsB8IDZH6n9tHxMacc3y0JoXOJUsZb/t/Mb8FUWMKaM7iQ==} peerDependencies: react: 17.0.2 @@ -21343,11 +18462,11 @@ packages: object-assign: 4.1.1 react: 17.0.2 react-is: 17.0.2 - react-shallow-renderer: 16.15.0(react@17.0.2) + react-shallow-renderer: 16.15.0_react@17.0.2 scheduler: 0.20.2 dev: true - /react-transition-group@2.9.0(react-dom@18.2.0)(react@18.2.0): + /react-transition-group/2.9.0_biqbaboplfbrettd7655fr4n2y: resolution: {integrity: sha512-+HzNTCHpeQyl4MJ/bdE0u6XRMe9+XG/+aL4mCxVN4DnPBQ0/5bfHWPDuOZUzYdMj94daZaZdCCc1Dzt9R/xSSg==} peerDependencies: react: '>=15.0.0' @@ -21357,44 +18476,44 @@ packages: loose-envify: 1.4.0 prop-types: 15.8.1 react: 18.2.0 - react-dom: 18.2.0(react@18.2.0) + react-dom: 18.2.0_react@18.2.0 react-lifecycles-compat: 3.0.4 dev: false - /react-transition-group@4.4.5(react-dom@18.2.0)(react@18.2.0): + /react-transition-group/4.4.5_biqbaboplfbrettd7655fr4n2y: resolution: {integrity: sha512-pZcd1MCJoiKiBR2NRxeCRg13uCXbydPnmB4EOeRrY7480qNWO8IIgQG6zlDkm6uRMsURXPuKq0GWtiM59a5Q6g==} peerDependencies: react: '>=16.6.0' react-dom: '>=16.6.0' dependencies: - '@babel/runtime': 7.18.9 + '@babel/runtime': 7.22.6 dom-helpers: 5.2.1 loose-envify: 1.4.0 prop-types: 15.8.1 react: 18.2.0 - react-dom: 18.2.0(react@18.2.0) + react-dom: 18.2.0_react@18.2.0 dev: false - /react@17.0.2: + /react/17.0.2: resolution: {integrity: sha512-gnhPt75i/dq/z3/6q/0asP78D0u592D5L1pd7M8P+dck6Fu/jJeL6iVVK23fptSUZj8Vjf++7wXA8UNclGQcbA==} engines: {node: '>=0.10.0'} dependencies: loose-envify: 1.4.0 object-assign: 4.1.1 - /react@18.0.0: + /react/18.0.0: resolution: {integrity: sha512-x+VL6wbT4JRVPm7EGxXhZ8w8LTROaxPXOqhlGyVSrv0sB1jkyFGgXxJ8LVoPRLvPR6/CIZGFmfzqUa2NYeMr2A==} engines: {node: '>=0.10.0'} dependencies: loose-envify: 1.4.0 - /react@18.2.0: + /react/18.2.0: resolution: {integrity: sha512-/3IjMdb2L9QbBdWiW5e3P2/npwMBaU9mHCSCUzNln0ZCYbcfTsGbTJrU/kGemdH2IWmB2ioZ+zkxtmq6g09fGQ==} engines: {node: '>=0.10.0'} dependencies: loose-envify: 1.4.0 - /read-pkg-up@1.0.1: + /read-pkg-up/1.0.1: resolution: {integrity: sha512-WD9MTlNtI55IwYUS27iHh9tK3YoIVhxis8yKhLpTqWtml739uXc9NWTpxoHkfZf3+DkCCsXox94/VWZniuZm6A==} engines: {node: '>=0.10.0'} dependencies: @@ -21403,7 +18522,7 @@ packages: dev: true optional: true - /read-pkg-up@7.0.1: + /read-pkg-up/7.0.1: resolution: {integrity: sha512-zK0TB7Xd6JpCLmlLmufqykGE+/TlOePD6qKClNW7hHDKFh/J7/7gCWGR7joEQEW1bKq3a3yUZSObOoWLFQ4ohg==} engines: {node: '>=8'} dependencies: @@ -21412,7 +18531,7 @@ packages: type-fest: 0.8.1 dev: true - /read-pkg-up@9.1.0: + /read-pkg-up/9.1.0: resolution: {integrity: sha512-vaMRR1AC1nrd5CQM0PhlRsO5oc2AAigqr7cCrZ/MW/Rsaflz4RlgzkpL4qoU/z1F6wrbd85iFv1OQj/y5RdGvg==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dependencies: @@ -21421,7 +18540,7 @@ packages: type-fest: 2.19.0 dev: true - /read-pkg@1.1.0: + /read-pkg/1.1.0: resolution: {integrity: sha512-7BGwRHqt4s/uVbuyoeejRn4YmFnYZiFl4AuaeXHlgZf3sONF0SOGlxs2Pw8g6hCKupo08RafIO5YXFNOKTfwsQ==} engines: {node: '>=0.10.0'} dependencies: @@ -21431,7 +18550,7 @@ packages: dev: true optional: true - /read-pkg@3.0.0: + /read-pkg/3.0.0: resolution: {integrity: sha512-BLq/cCO9two+lBgiTYNqD6GdtK8s4NpaWrl6/rCO9w0TUS8oJl7cmToOZfRYllKTISY6nt1U7jQ53brmKqY6BA==} engines: {node: '>=4'} dependencies: @@ -21440,7 +18559,7 @@ packages: path-type: 3.0.0 dev: true - /read-pkg@5.2.0: + /read-pkg/5.2.0: resolution: {integrity: sha512-Ug69mNOpfvKDAc2Q8DRpMjjzdtrnv9HcSMX+4VsZxD1aZ6ZzrIE7rlzXBtWTyhULSMKg076AW6WR5iZpD0JiOg==} engines: {node: '>=8'} dependencies: @@ -21450,7 +18569,7 @@ packages: type-fest: 0.6.0 dev: true - /read-pkg@7.1.0: + /read-pkg/7.1.0: resolution: {integrity: sha512-5iOehe+WF75IccPc30bWTbpdDQLOCc3Uu8bi3Dte3Eueij81yx1Mrufk8qBx/YAbR4uL1FdUr+7BKXDwEtisXg==} engines: {node: '>=12.20'} dependencies: @@ -21460,8 +18579,8 @@ packages: type-fest: 2.19.0 dev: true - /readable-stream@2.3.7: - resolution: {integrity: sha512-Ebho8K4jIbHAxnuxi7o42OrZgF/ZTNcsZj6nRKyUmkhLFq8CHItp/fy6hQZuZmP/n3yZ9VBUbp4zz/mX8hmYPw==} + /readable-stream/2.3.8: + resolution: {integrity: sha512-8p0AUk4XODgIewSi0l8Epjs+EVnWiK7NoDIEGU0HhE7+ZyY8D1IMY7odu5lRrFXGg71L15KG8QrPmum45RTtdA==} dependencies: core-util-is: 1.0.3 inherits: 2.0.4 @@ -21472,8 +18591,8 @@ packages: util-deprecate: 1.0.2 dev: true - /readable-stream@3.6.0: - resolution: {integrity: sha512-BViHy7LKeTz4oNnkcLJ+lVSL6vpiFeX6/d3oSH8zCW7UxP2onchk+vTGB143xuFjHS3deTgkKoXXymXqymiIdA==} + /readable-stream/3.6.2: + resolution: {integrity: sha512-9u/sniCrY3D5WdsERHzHE4G2YCXqoG5FTHUiCC4SIbr6XcLZBY05ya9EKjYek9O5xOAwjGq+1JdGBAS7Q9ScoA==} engines: {node: '>= 6'} dependencies: inherits: 2.0.4 @@ -21481,74 +18600,75 @@ packages: util-deprecate: 1.0.2 dev: true - /readable-stream@4.1.0: - resolution: {integrity: sha512-sVisi3+P2lJ2t0BPbpK629j8wRW06yKGJUcaLAGXPAUhyUxVJm7VsCTit1PFgT4JHUDMrGNR+ZjSKpzGaRF3zw==} + /readable-stream/4.4.2: + resolution: {integrity: sha512-Lk/fICSyIhodxy1IDK2HazkeGjSmezAWX2egdtJnYhtzKEsBPJowlI6F6LPb5tqIQILrMbx22S5o3GuJavPusA==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dependencies: abort-controller: 3.0.0 + buffer: 6.0.3 + events: 3.3.0 + process: 0.11.10 + string_decoder: 1.3.0 dev: true - /readdir-glob@1.1.2: - resolution: {integrity: sha512-6RLVvwJtVwEDfPdn6X6Ille4/lxGl0ATOY4FN/B9nxQcgOazvvI0nodiD19ScKq0PvA/29VpaOQML36o5IzZWA==} + /readdir-glob/1.1.3: + resolution: {integrity: sha512-v05I2k7xN8zXvPD9N+z/uhXPaj0sUFCe2rcWZIpBsqxfP7xXFQ0tipAd/wjj1YxWyWtUS5IDJpOG82JKt2EAVA==} dependencies: - minimatch: 5.1.1 + minimatch: 5.1.6 dev: true - /readdirp@2.2.1: + /readdirp/2.2.1: resolution: {integrity: sha512-1JU/8q+VgFZyxwrJ+SVIOsh+KywWGpds3NTqikiKpDMZWScmAYyKIgqkO+ARvNWJfXeXR1zxz7aHF4u4CyH6vQ==} engines: {node: '>=0.10'} dependencies: - graceful-fs: 4.2.10 + graceful-fs: 4.2.11 micromatch: 3.1.10 - readable-stream: 2.3.7 + readable-stream: 2.3.8 transitivePeerDependencies: - supports-color dev: true optional: true - /readdirp@3.6.0: + /readdirp/3.6.0: resolution: {integrity: sha512-hOS089on8RduqdbhvQ5Z37A0ESjsqz6qnRcffsMU3495FuTdqSm+7bhJ29JvIOsBDEEnan5DPu9t3To9VRlMzA==} engines: {node: '>=8.10.0'} dependencies: picomatch: 2.3.1 dev: true - /real-require@0.2.0: + /real-require/0.2.0: resolution: {integrity: sha512-57frrGM/OCTLqLOAh0mhVA9VBMHd+9U7Zb2THMGdBUoZVOtGbJzjxsYGDJ3A9AYYCP4hn6y1TVbaOfzWtm5GFg==} engines: {node: '>= 12.13.0'} dev: true - /recharts-scale@0.4.5: + /recharts-scale/0.4.5: resolution: {integrity: sha512-kivNFO+0OcUNu7jQquLXAxz1FIwZj8nrj+YkOKc5694NbjCvcT6aSZiIzNzd2Kul4o4rTto8QVR9lMNtxD4G1w==} dependencies: decimal.js-light: 2.5.1 dev: false - /recharts@2.1.13(prop-types@15.8.1)(react-dom@18.2.0)(react@18.2.0): - resolution: {integrity: sha512-9VWu2nzExmfiMFDHKqRFhYlJVmjzQGVKH5rBetXR4EuyEXuu3Y6cVxQuNEdusHhbm4SoPPrVDCwlBdREL3sQPA==} + /recharts/2.7.2_biqbaboplfbrettd7655fr4n2y: + resolution: {integrity: sha512-HMKRBkGoOXHW+7JcRa6+MukPSifNtJlqbc+JreGVNA407VLE/vOP+8n3YYjprDVVIF9E2ZgwWnL3D7K/LUFzBg==} engines: {node: '>=12'} peerDependencies: prop-types: ^15.6.0 react: ^16.0.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.0.0 || ^17.0.0 || ^18.0.0 dependencies: - classnames: 2.3.1 - d3-interpolate: 3.0.1 - d3-scale: 4.0.2 - d3-shape: 3.1.0 + classnames: 2.3.2 eventemitter3: 4.0.7 lodash: 4.17.21 - prop-types: 15.8.1 react: 18.2.0 - react-dom: 18.2.0(react@18.2.0) + react-dom: 18.2.0_react@18.2.0 react-is: 16.13.1 - react-resize-detector: 7.1.2(react-dom@18.2.0)(react@18.2.0) - react-smooth: 2.0.1(prop-types@15.8.1)(react-dom@18.2.0)(react@18.2.0) + react-resize-detector: 8.1.0_biqbaboplfbrettd7655fr4n2y + react-smooth: 2.0.3_biqbaboplfbrettd7655fr4n2y recharts-scale: 0.4.5 reduce-css-calc: 2.1.8 + victory-vendor: 36.6.11 dev: false - /redent@1.0.0: + /redent/1.0.0: resolution: {integrity: sha512-qtW5hKzGQZqKoh6JNSD+4lfitfPKGz42e6QwiRmPM5mmKtR0N41AbJRYu0xJi7nhOJ4WDgRkKvAk6tw4WIwR4g==} engines: {node: '>=0.10.0'} dependencies: @@ -21557,7 +18677,7 @@ packages: dev: true optional: true - /redent@3.0.0: + /redent/3.0.0: resolution: {integrity: sha512-6tDA8g98We0zd0GvVeMT9arEOnTw9qM03L9cJXaCjrip1OO764RDBLBfrB4cwzNGDj5OA5ioymC9GkizgWJDUg==} engines: {node: '>=8'} dependencies: @@ -21565,38 +18685,34 @@ packages: strip-indent: 3.0.0 dev: true - /reduce-css-calc@2.1.8: + /reduce-css-calc/2.1.8: resolution: {integrity: sha512-8liAVezDmUcH+tdzoEGrhfbGcP7nOV4NkGE3a74+qqvE7nt9i4sKLGBuZNOnpI4WiGksiNPklZxva80061QiPg==} dependencies: css-unit-converter: 1.1.2 postcss-value-parser: 3.3.1 dev: false - /regenerate-unicode-properties@10.0.1: - resolution: {integrity: sha512-vn5DU6yg6h8hP/2OkQo3K7uVILvY4iu0oI4t3HFa81UPkhGJwkRwM10JEc3upjdhHjs/k8GJY1sRBhk5sr69Bw==} + /regenerate-unicode-properties/10.1.0: + resolution: {integrity: sha512-d1VudCLoIGitcU/hEg2QqvyGZQmdC0Lf8BqdOMXGFSvJP4bNV1+XqbPQeHHLD51Jh4QJJ225dlIFvY4Ly6MXmQ==} engines: {node: '>=4'} dependencies: regenerate: 1.4.2 dev: true - /regenerate@1.4.2: + /regenerate/1.4.2: resolution: {integrity: sha512-zrceR/XhGYU/d/opr2EKO7aRHUeiBI8qjtfHqADTwZd6Szfy16la6kqD0MIUs5z5hx6AaKa+PixpPrR289+I0A==} dev: true - /regenerator-runtime@0.13.11: + /regenerator-runtime/0.13.11: resolution: {integrity: sha512-kY1AZVr2Ra+t+piVaJ4gxaFaReZVH40AKNo7UCX6W+dEwBo/2oZJzqfuN1qLq1oL45o56cPaTXELwrTh8Fpggg==} - /regenerator-runtime@0.13.9: - resolution: {integrity: sha512-p3VT+cOEgxFsRRA9X4lkI1E+k2/CtnKtU4gcxyaCUreilL/vqI6CdZ3wxVUx3UOUg+gnUOQQcRI7BmSI656MYA==} - dev: true - - /regenerator-transform@0.15.0: - resolution: {integrity: sha512-LsrGtPmbYg19bcPHwdtmXwbW+TqNvtY4riE3P83foeHRroMbH6/2ddFBfab3t7kbzc7v7p4wbkIecHImqt0QNg==} + /regenerator-transform/0.15.1: + resolution: {integrity: sha512-knzmNAcuyxV+gQCufkYcvOqX/qIIfHLv0u5x79kRxuGojfYVky1f15TzZEu2Avte8QGepvUNTnLskf8E6X6Vyg==} dependencies: - '@babel/runtime': 7.18.9 + '@babel/runtime': 7.22.6 dev: true - /regex-not@1.0.2: + /regex-not/1.0.2: resolution: {integrity: sha512-J6SDjUgDxQj5NusnOtdFxDwN/+HWykR8GELwctJ7mdqhcyy1xEc4SRFHUXvxTp661YaVKAjfRLZ9cCqS6tn32A==} engines: {node: '>=0.10.0'} dependencies: @@ -21604,12 +18720,12 @@ packages: safe-regex: 1.1.0 dev: true - /regexp-tree@0.1.24: - resolution: {integrity: sha512-s2aEVuLhvnVJW6s/iPgEGK6R+/xngd2jNQ+xy4bXNDKxZKJH6jpPHY6kVeVv1IeLCHgswRj+Kl3ELaDjG6V1iw==} + /regexp-tree/0.1.27: + resolution: {integrity: sha512-iETxpjK6YoRWJG5o6hXLwvjYAoW+FEZn9os0PD/b6AP6xQwsa/Y7lCVgIixBbUPMfhu+i2LtdeAqVTgGlQarfA==} hasBin: true dev: true - /regexp.prototype.flags@1.5.0: + /regexp.prototype.flags/1.5.0: resolution: {integrity: sha512-0SutC3pNudRKgquxGoRGIz946MZVHqbNfPjBdxeOhBrdgDKlRoXmYLQN9xRbrR09ZXWeGAdPuif7egofn6v5LA==} engines: {node: '>= 0.4'} dependencies: @@ -21618,47 +18734,43 @@ packages: functions-have-names: 1.2.3 dev: true - /regexpp@3.2.0: + /regexpp/3.2.0: resolution: {integrity: sha512-pq2bWo9mVD43nbts2wGv17XLiNLya+GklZ8kaDLV2Z08gDCsGpnKn9BFMepvWuHCbyVvY7J5o5+BVvoQbmlJLg==} engines: {node: '>=8'} dev: true - /regexpu-core@5.1.0: - resolution: {integrity: sha512-bb6hk+xWd2PEOkj5It46A16zFMs2mv86Iwpdu94la4S3sJ7C973h2dHpYKwIBGaWSO7cIRJ+UX0IeMaWcO4qwA==} + /regexpu-core/5.3.2: + resolution: {integrity: sha512-RAM5FlZz+Lhmo7db9L298p2vHP5ZywrVXmVXpmAD9GuL5MPH6t9ROw1iA/wfHkQ76Qe7AaPF0nGuim96/IrQMQ==} engines: {node: '>=4'} dependencies: + '@babel/regjsgen': 0.8.0 regenerate: 1.4.2 - regenerate-unicode-properties: 10.0.1 - regjsgen: 0.6.0 - regjsparser: 0.8.4 + regenerate-unicode-properties: 10.1.0 + regjsparser: 0.9.1 unicode-match-property-ecmascript: 2.0.0 - unicode-match-property-value-ecmascript: 2.0.0 - dev: true - - /regjsgen@0.6.0: - resolution: {integrity: sha512-ozE883Uigtqj3bx7OhL1KNbCzGyW2NQZPl6Hs09WTvCuZD5sTI4JY58bkbQWa/Y9hxIsvJ3M8Nbf7j54IqeZbA==} + unicode-match-property-value-ecmascript: 2.1.0 dev: true - /regjsparser@0.10.0: + /regjsparser/0.10.0: resolution: {integrity: sha512-qx+xQGZVsy55CH0a1hiVwHmqjLryfh7wQyF5HO07XJ9f7dQMY/gPQHhlyDkIzJKC+x2fUCpCcUODUUUFrm7SHA==} hasBin: true dependencies: jsesc: 0.5.0 dev: true - /regjsparser@0.8.4: - resolution: {integrity: sha512-J3LABycON/VNEu3abOviqGHuB/LOtOQj8SKmfP9anY5GfAVw/SPjwzSjxGjbZXIxbGfqTHtJw58C2Li/WkStmA==} + /regjsparser/0.9.1: + resolution: {integrity: sha512-dQUtn90WanSNl+7mQKcXAgZxvUe7Z0SqXlgzv0za4LwiUhyzBC58yQO3liFoUgu8GiJVInAhJjkj1N0EtQ5nkQ==} hasBin: true dependencies: jsesc: 0.5.0 dev: true - /relateurl@0.2.7: + /relateurl/0.2.7: resolution: {integrity: sha512-G08Dxvm4iDN3MLM0EsP62EDV9IuhXPR6blNz6Utcp7zyV3tr4HVNINt6MpaRWbxoOHT3Q7YN2P+jaHX8vUbgog==} engines: {node: '>= 0.10'} dev: true - /remark-external-links@8.0.0: + /remark-external-links/8.0.0: resolution: {integrity: sha512-5vPSX0kHoSsqtdftSHhIYofVINC8qmp0nctkeU9YoJwV3YfiBRiI6cbFRJ0oI/1F9xS+bopXG0m2KS8VFscuKA==} dependencies: extend: 3.0.2 @@ -21668,17 +18780,17 @@ packages: unist-util-visit: 2.0.3 dev: true - /remark-footnotes@2.0.0: + /remark-footnotes/2.0.0: resolution: {integrity: sha512-3Clt8ZMH75Ayjp9q4CorNeyjwIxHFcTkaektplKGl2A1jNGEUey8cKL0ZC5vJwfcD5GFGsNLImLG/NGzWIzoMQ==} dev: true - /remark-mdx@1.6.22: + /remark-mdx/1.6.22: resolution: {integrity: sha512-phMHBJgeV76uyFkH4rvzCftLfKCr2RZuF+/gmVcaKrpsihyzmhXjA0BEMDaPTXG5y8qZOKPVo83NAOX01LPnOQ==} dependencies: '@babel/core': 7.12.9 '@babel/helper-plugin-utils': 7.10.4 - '@babel/plugin-proposal-object-rest-spread': 7.12.1(@babel/core@7.12.9) - '@babel/plugin-syntax-jsx': 7.12.1(@babel/core@7.12.9) + '@babel/plugin-proposal-object-rest-spread': 7.12.1_@babel+core@7.12.9 + '@babel/plugin-syntax-jsx': 7.12.1_@babel+core@7.12.9 '@mdx-js/util': 1.6.22 is-alphabetical: 1.0.4 remark-parse: 8.0.3 @@ -21687,7 +18799,7 @@ packages: - supports-color dev: true - /remark-parse@8.0.3: + /remark-parse/8.0.3: resolution: {integrity: sha512-E1K9+QLGgggHxCQtLt++uXltxEprmWzNfg+MxpfHsZlrddKzZ/hZyWHDbK3/Ap8HJQqYJRXP+jHczdL6q6i85Q==} dependencies: ccount: 1.1.0 @@ -21708,29 +18820,29 @@ packages: xtend: 4.0.2 dev: true - /remark-slug@6.1.0: + /remark-slug/6.1.0: resolution: {integrity: sha512-oGCxDF9deA8phWvxFuyr3oSJsdyUAxMFbA0mZ7Y1Sas+emILtO+e5WutF9564gDsEN4IXaQXm5pFo6MLH+YmwQ==} dependencies: - github-slugger: 1.4.0 + github-slugger: 1.5.0 mdast-util-to-string: 1.1.0 unist-util-visit: 2.0.3 dev: true - /remark-squeeze-paragraphs@4.0.0: + /remark-squeeze-paragraphs/4.0.0: resolution: {integrity: sha512-8qRqmL9F4nuLPIgl92XUuxI3pFxize+F1H0e/W3llTk0UsjJaj01+RrirkMw7P21RKe4X6goQhYRSvNWX+70Rw==} dependencies: mdast-squeeze-paragraphs: 4.0.0 dev: true - /remove-accents@0.4.2: - resolution: {integrity: sha1-CkPTqq4egNuRngeuJUsoXZ4ce7U=} + /remove-accents/0.4.2: + resolution: {integrity: sha512-7pXIJqJOq5tFgG1A2Zxti3Ht8jJF337m4sowbuHsW30ZnkQFnDzy9qBNhgzX8ZLW4+UBcXiiR7SwR6pokHsxiA==} dev: false - /remove-trailing-separator@1.1.0: + /remove-trailing-separator/1.1.0: resolution: {integrity: sha512-/hS+Y0u3aOfIETiaiirUFwDBDzmXPvO+jAfKTitUngIPzdKc6Z0LoFjM/CK5PL4C+eKwHohlHAb6H0VFfmmUsw==} dev: true - /renderkid@2.0.7: + /renderkid/2.0.7: resolution: {integrity: sha512-oCcFyxaMrKsKcTY59qnCAtmDVSLfPbrv6A3tVbPdFMMrv5jaK10V6m40cKsoPNhAqN6rmHW9sswW4o3ruSrwUQ==} dependencies: css-select: 4.3.0 @@ -21740,17 +18852,17 @@ packages: strip-ansi: 3.0.1 dev: true - /repeat-element@1.1.4: + /repeat-element/1.1.4: resolution: {integrity: sha512-LFiNfRcSu7KK3evMyYOuCzv3L10TW7yC1G2/+StMjK8Y6Vqd2MG7r/Qjw4ghtuCOjFvlnms/iMmLqpvW/ES/WQ==} engines: {node: '>=0.10.0'} dev: true - /repeat-string@1.6.1: + /repeat-string/1.6.1: resolution: {integrity: sha512-PV0dzCYDNfRi1jCDbJzpW7jNNDRuCOG/jI5ctQcGKt/clZD+YcPS3yIlWuTJMmESC8aevCFmWJy5wjAFgNqN6w==} engines: {node: '>=0.10'} dev: true - /repeating@2.0.1: + /repeating/2.0.1: resolution: {integrity: sha512-ZqtSMuVybkISo2OWvqvm7iHSWngvdaW3IpsT9/uP8v4gMi591LY6h35wdOfvQdWCKFWZWm2Y1Opp4kV7vQKT6A==} engines: {node: '>=0.10.0'} dependencies: @@ -21758,61 +18870,49 @@ packages: dev: true optional: true - /request-progress@3.0.0: + /request-progress/3.0.0: resolution: {integrity: sha512-MnWzEHHaxHO2iWiQuHrUPBi/1WeBf5PkxQqNyNvLl9VAYSdXkP8tQ3pBSeCPD+yw0v0Aq1zosWLz0BdeXpWwZg==} dependencies: throttleit: 1.0.0 dev: true - /require-directory@2.1.1: + /require-directory/2.1.1: resolution: {integrity: sha512-fGxEI7+wsG9xrvdjsrlmL22OMTTiHRwAMroiEeMgq8gzoLC/PQr7RsRDSTLUg/bZAZtF+TVIkHc6/4RIKrui+Q==} engines: {node: '>=0.10.0'} dev: true - /require-from-string@2.0.2: + /require-from-string/2.0.2: resolution: {integrity: sha512-Xf0nWe6RseziFMu+Ap9biiUbmplq6S9/p+7w7YXP/JBHhrUDDUhwa+vANyubuqfZWTveU//DYVGsDG7RKL/vEw==} engines: {node: '>=0.10.0'} dev: true - /requires-port@1.0.0: + /requires-port/1.0.0: resolution: {integrity: sha512-KigOCHcocU3XODJxsu8i/j8T9tzT4adHiecwORRQ0ZZFcp7ahwXuRU1m+yuO90C5ZUyGeGfocHDI14M3L3yDAQ==} dev: true - /resolve-alpn@1.2.1: + /resolve-alpn/1.2.1: resolution: {integrity: sha512-0a1F4l73/ZFZOakJnQ3FvkJ2+gSTQWz/r2KE5OdDY0TxPm5h4GkqkWWfM47T7HsbnOtcJVEF4epCVy6u7Q3K+g==} dev: true - /resolve-cwd@3.0.0: - resolution: {integrity: sha512-OrZaX2Mb+rJCpH/6CpSqt9xFVpN++x01XnN2ie9g6P5/3xelLAkXWVADpdz1IHD/KFfEXyE6V0U01OQ3UO2rEg==} - engines: {node: '>=8'} - dependencies: - resolve-from: 5.0.0 - dev: true - - /resolve-from@4.0.0: + /resolve-from/4.0.0: resolution: {integrity: sha512-pb/MYmXstAkysRFx8piNI1tGFNQIFA3vkE3Gq4EuA1dF6gHp/+vgZqsCGJapvy8N3Q+4o7FwvquPJcnZ7RYy4g==} engines: {node: '>=4'} - /resolve-from@5.0.0: + /resolve-from/5.0.0: resolution: {integrity: sha512-qYg9KP24dD5qka9J47d0aVky0N+b4fTU89LN9iDnjB5waksiC49rvMB0PrUJQGoTmH50XPiqOvAjDfaijGxYZw==} engines: {node: '>=8'} dev: true - /resolve-pkg-maps@1.0.0: + /resolve-pkg-maps/1.0.0: resolution: {integrity: sha512-seS2Tj26TBVOC2NIc2rOe2y2ZO7efxITtLZcGSOnHHNOQ7CkiUBfw0Iw2ck6xkIhPwLhKNLS8BO+hEpngQlqzw==} dev: true - /resolve-url@0.2.1: + /resolve-url/0.2.1: resolution: {integrity: sha512-ZuF55hVUQaaczgOIwqWzkEcEidmlD/xl44x1UZnhOXcYuFN2S6+rcxpG+C1N3So0wvNI3DmJICUFfu2SxhBmvg==} deprecated: https://github.com/lydell/resolve-url#deprecated dev: true - /resolve.exports@1.1.1: - resolution: {integrity: sha512-/NtpHNDN7jWhAaQ9BvBUYZ6YTXsRBgfqWFWP7BZBaoMJO/I3G5OFzvTuWNlZC3aPjins1F+TNrLKsGbH4rfsRQ==} - engines: {node: '>=10'} - dev: true - - /resolve@1.22.2: + /resolve/1.22.2: resolution: {integrity: sha512-Sb+mjNHOULsBv818T40qSPeRiuWLyaGMa5ewydRLFimneixmVy2zdivRl+AF6jaYPC8ERxGDmFSiqui6SfPd+g==} hasBin: true dependencies: @@ -21820,7 +18920,7 @@ packages: path-parse: 1.0.7 supports-preserve-symlinks-flag: 1.0.0 - /resolve@1.22.3: + /resolve/1.22.3: resolution: {integrity: sha512-P8ur/gp/AmbEzjr729bZnLjXK5Z+4P0zhIJgBgzqRih7hL7BOukHGtSTA3ACMY467GRFz3duQsi0bDZdR7DKdw==} hasBin: true dependencies: @@ -21829,20 +18929,25 @@ packages: supports-preserve-symlinks-flag: 1.0.0 dev: true - /responselike@3.0.0: + /response-iterator/0.2.6: + resolution: {integrity: sha512-pVzEEzrsg23Sh053rmDUvLSkGXluZio0qu8VT6ukrYuvtjVfCbDZH9d6PGXb8HZfzdNZt8feXv/jvUzlhRgLnw==} + engines: {node: '>=0.8'} + dev: false + + /responselike/3.0.0: resolution: {integrity: sha512-40yHxbNcl2+rzXvZuVkrYohathsSJlMTXKryG5y8uciHv1+xDLHQpgjG64JUO9nrEq2jGLH6IZ8BcZyw3wrweg==} engines: {node: '>=14.16'} dependencies: lowercase-keys: 3.0.0 dev: true - /resq@1.11.0: + /resq/1.11.0: resolution: {integrity: sha512-G10EBz+zAAy3zUd/CDoBbXRL6ia9kOo3xRHrMDsHljI0GDkhYlyjwoCx5+3eCC4swi1uCoZQhskuJkj7Gp57Bw==} dependencies: fast-deep-equal: 2.0.1 dev: true - /restore-cursor@3.1.0: + /restore-cursor/3.1.0: resolution: {integrity: sha512-l+sSefzHpj5qimhFSE5a8nufZYAM3sBSVMAPtYkmC+4EH2anSGaEMXSD0izRQbu9nfyQ9y5JrVmp7E8oZrUjvA==} engines: {node: '>=8'} dependencies: @@ -21850,7 +18955,7 @@ packages: signal-exit: 3.0.7 dev: true - /restore-cursor@4.0.0: + /restore-cursor/4.0.0: resolution: {integrity: sha512-I9fPXU9geO9bHOt9pHHOhOkYerIMsmVaWB0rA2AI9ERh/+x/i7MV5HKBNrg+ljO5eoPVgCcnFuRjJ9uH6I/3eg==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dependencies: @@ -21858,29 +18963,29 @@ packages: signal-exit: 3.0.7 dev: true - /ret@0.1.15: + /ret/0.1.15: resolution: {integrity: sha512-TTlYpa+OL+vMMNG24xSlQGEJ3B/RzEfUlLct7b5G/ytav+wPrplCpVMFuwzXbkecJrb6IYo1iFb0S9v37754mg==} engines: {node: '>=0.12'} dev: true - /ret@0.2.2: + /ret/0.2.2: resolution: {integrity: sha512-M0b3YWQs7R3Z917WRQy1HHA7Ba7D8hvZg6UE5mLykJxQVE2ju0IXbGlaHPPlkY+WN7wFP+wUMXmBFA0aV6vYGQ==} engines: {node: '>=4'} dev: true - /reusify@1.0.4: + /reusify/1.0.4: resolution: {integrity: sha512-U9nH88a3fc/ekCF1l0/UP1IosiuIjyTh7hBvXVMHYgVcfGvt897Xguj2UOLDeI5BG2m7/uwyaLVT6fbtCwTyzw==} engines: {iojs: '>=1.0.0', node: '>=0.10.0'} - /rfdc@1.3.0: + /rfdc/1.3.0: resolution: {integrity: sha512-V2hovdzFbOi77/WajaSMXk2OLm+xNIeQdMMuB7icj7bk6zi2F8GGAxigcnDFpJHbNyNcgyJDiP+8nOrY5cZGrA==} dev: true - /rgb2hex@0.2.5: + /rgb2hex/0.2.5: resolution: {integrity: sha512-22MOP1Rh7sAo1BZpDG6R5RFYzR2lYEgwq7HEmyW2qcsOqR2lQKmn+O//xV3YG/0rrhMC6KVX2hU+ZXuaw9a5bw==} dev: true - /rifm@0.12.1(react@18.2.0): + /rifm/0.12.1_react@18.2.0: resolution: {integrity: sha512-OGA1Bitg/dSJtI/c4dh90svzaUPt228kzFsUkJbtA2c964IqEAwWXeL9ZJi86xWv3j5SMqRvGULl7bA6cK0Bvg==} peerDependencies: react: '>=16.8' @@ -21888,35 +18993,35 @@ packages: react: 18.2.0 dev: false - /rimraf@2.7.1: + /rimraf/2.7.1: resolution: {integrity: sha512-uWjbaKIK3T1OSVptzX7Nl6PvQ3qAGtKEtVRjRuazjfL3Bx5eI409VZSqgND+4UNnmzLVdPj9FqFJNPqBZFve4w==} hasBin: true dependencies: glob: 7.2.3 dev: true - /rimraf@3.0.2: + /rimraf/3.0.2: resolution: {integrity: sha512-JZkJMZkAGFFPP2YqXZXPbMlMBgsxzE8ILs4lMIX/2o0L9UBw9O/Y3o6wFw/i9YLapcUJWwqbi3kdxIPdC62TIA==} hasBin: true dependencies: glob: 7.2.3 - /rimraf@5.0.1: + /rimraf/5.0.1: resolution: {integrity: sha512-OfFZdwtd3lZ+XZzYP/6gTACubwFcHdLRqS9UX3UwpU2dnGQYkPFISRwvM3w9IiB2w7bW5qGo/uAwE4SmXXSKvg==} engines: {node: '>=14'} hasBin: true dependencies: - glob: 10.2.7 + glob: 10.3.3 dev: true - /ripemd160@2.0.2: + /ripemd160/2.0.2: resolution: {integrity: sha512-ii4iagi25WusVoiC4B4lq7pbXfAp3D9v5CwfkY33vffw2+pkDjY1D8GaN7spsxvCSx8dkPqOZCEZyfxcmJG2IA==} dependencies: hash-base: 3.1.0 inherits: 2.0.4 dev: true - /rollup-plugin-dts@5.3.0(rollup@3.26.0)(typescript@5.1.6): + /rollup-plugin-dts/5.3.0_btijhbnqj3bkl7p6fnurpsgzhq: resolution: {integrity: sha512-8FXp0ZkyZj1iU5klkIJYLjIq/YZSwBoERu33QBDxm/1yw5UU4txrEtcmMkrq+ZiKu3Q4qvPCNqc3ovX6rjqzbQ==} engines: {node: '>=v14'} peerDependencies: @@ -21924,31 +19029,31 @@ packages: typescript: ^4.1 || ^5.0 dependencies: magic-string: 0.30.1 - rollup: 3.26.0 + rollup: 3.26.2 typescript: 5.1.6 optionalDependencies: '@babel/code-frame': 7.22.5 dev: true - /rollup-plugin-esbuild@5.0.0(esbuild@0.18.11)(rollup@3.26.0): + /rollup-plugin-esbuild/5.0.0_b5okt2kat7kf37a3hh6exlw3ju: resolution: {integrity: sha512-1cRIOHAPh8WQgdQQyyvFdeOdxuiyk+zB5zJ5+YOwrZP4cJ0MT3Fs48pQxrZeyZHcn+klFherytILVfE4aYrneg==} engines: {node: '>=14.18.0', npm: '>=8.0.0'} peerDependencies: esbuild: '>=0.10.1' rollup: ^1.20.0 || ^2.0.0 || ^3.0.0 dependencies: - '@rollup/pluginutils': 5.0.2(rollup@3.26.0) - debug: 4.3.4(supports-color@8.1.1) - es-module-lexer: 1.1.0 + '@rollup/pluginutils': 5.0.2_rollup@3.26.2 + debug: 4.3.4 + es-module-lexer: 1.3.0 esbuild: 0.18.11 joycon: 3.1.1 jsonc-parser: 3.2.0 - rollup: 3.26.0 + rollup: 3.26.2 transitivePeerDependencies: - supports-color dev: true - /rollup-plugin-license@3.0.1(rollup@3.26.0): + /rollup-plugin-license/3.0.1_rollup@3.26.2: resolution: {integrity: sha512-/lec6Y94Y3wMfTDeYTO/jSXII0GQ/XkDZCiqkMKxyU5D5nGPaxr/2JNYvAgYsoCYuOLGOanKDPjCCQiTT96p7A==} engines: {node: '>=14.0.0'} peerDependencies: @@ -21961,12 +19066,12 @@ packages: mkdirp: 1.0.4 moment: 2.29.4 package-name-regex: 2.0.6 - rollup: 3.26.0 + rollup: 3.26.2 spdx-expression-validate: 2.0.0 spdx-satisfies: 5.0.1 dev: true - /rollup-plugin-terser@7.0.2(rollup@2.79.1): + /rollup-plugin-terser/7.0.2_rollup@2.79.1: resolution: {integrity: sha512-w3iIaU4OxcF52UUXiZNsNeuXIMDvFrr+ZXK6bFZ0Q60qyVfq4uLptoS4bbq3paG3x216eQllFZX7zt6TIImguQ==} deprecated: This package has been deprecated and is no longer maintained. Please use @rollup/plugin-terser peerDependencies: @@ -21976,144 +19081,149 @@ packages: jest-worker: 26.6.2 rollup: 2.79.1 serialize-javascript: 4.0.0 - terser: 5.15.0 + terser: 5.19.0 dev: true - /rollup@2.79.1: + /rollup/2.79.1: resolution: {integrity: sha512-uKxbd0IhMZOhjAiD5oAFp7BqvkA4Dv47qpOCtaNvng4HBwdbWtdOh8f5nZNuk2rp51PMGk3bzfWu5oayNEuYnw==} engines: {node: '>=10.0.0'} hasBin: true optionalDependencies: fsevents: 2.3.2 + dev: true - /rollup@3.23.0: - resolution: {integrity: sha512-h31UlwEi7FHihLe1zbk+3Q7z1k/84rb9BSwmBSr/XjOCEaBJ2YyedQDuM0t/kfOS0IxM+vk1/zI9XxYj9V+NJQ==} - engines: {node: '>=14.18.0', npm: '>=8.0.0'} - hasBin: true - optionalDependencies: - fsevents: 2.3.2 - - /rollup@3.26.0: - resolution: {integrity: sha512-YzJH0eunH2hr3knvF3i6IkLO/jTjAEwU4HoMUbQl4//Tnl3ou0e7P5SjxdDr8HQJdeUJShlbEHXrrnEHy1l7Yg==} + /rollup/3.26.2: + resolution: {integrity: sha512-6umBIGVz93er97pMgQO08LuH3m6PUb3jlDUUGFsNJB6VgTCUaDFpupf5JfU30529m/UKOgmiX+uY6Sx8cOYpLA==} engines: {node: '>=14.18.0', npm: '>=8.0.0'} hasBin: true optionalDependencies: fsevents: 2.3.2 - /rrweb-cssom@0.6.0: + /rrweb-cssom/0.6.0: resolution: {integrity: sha512-APM0Gt1KoXBz0iIkkdB/kfvGOwC4UuJFeG/c+yV7wSc7q96cG/kJ0HiYCnzivD9SB53cLV1MlHFNfOuPaadYSw==} dev: true - /rst-selector-parser@2.2.3: + /rst-selector-parser/2.2.3: resolution: {integrity: sha512-nDG1rZeP6oFTLN6yNDV/uiAvs1+FS/KlrEwh7+y7dpuApDBy6bI2HTBcc0/V8lv9OTqfyD34eF7au2pm8aBbhA==} dependencies: lodash.flattendeep: 4.4.0 nearley: 2.20.1 dev: true - /rsvp@4.8.5: + /rsvp/4.8.5: resolution: {integrity: sha512-nfMOlASu9OnRJo1mbEk2cz0D56a1MBNrJ7orjRZQG10XDyuvwksKbuXNp6qa+kbn839HwjwhBzhFmdsaEAfauA==} engines: {node: 6.* || >= 7.*} dev: true - /run-async@2.4.1: + /run-async/2.4.1: resolution: {integrity: sha512-tvVnVv01b8c1RrA6Ep7JkStj85Guv/YrMcwqYQnwjsAS2cTmmPGBBjAjpCW7RrSodNSoE2/qg9O4bceNvUuDgQ==} engines: {node: '>=0.12.0'} dev: true - /run-async@3.0.0: + /run-async/3.0.0: resolution: {integrity: sha512-540WwVDOMxA6dN6We19EcT9sc3hkXPw5mzRNGM3FkdN/vtE9NFvj5lFAPNwUDmJjXidm3v7TC1cTE7t17Ulm1Q==} engines: {node: '>=0.12.0'} dev: true - /run-parallel@1.2.0: + /run-parallel/1.2.0: resolution: {integrity: sha512-5l4VyZR86LZ/lDxZTR6jqL8AFE2S0IFLMP26AbjsLVADxHdhB/c0GUsH+y39UfCi3dzz8OlQuPmnaJOMoDHQBA==} dependencies: queue-microtask: 1.2.3 - /run-queue@1.0.3: + /run-queue/1.0.3: resolution: {integrity: sha512-ntymy489o0/QQplUDnpYAYUsO50K9SBrIVaKCWDOJzYJts0f9WH9RFJkyagebkw5+y1oi00R7ynNW/d12GBumg==} dependencies: aproba: 1.2.0 dev: true - /rxjs@7.8.1: + /rxjs/7.8.1: resolution: {integrity: sha512-AA3TVj+0A2iuIoQkWEK/tqFjBq2j+6PO6Y0zJcvzLAFhEFIO3HL0vls9hWLncZbAAbK0mar7oZ4V079I/qPMxg==} dependencies: - tslib: 2.5.3 + tslib: 2.6.0 dev: true - /sade@1.8.1: + /sade/1.8.1: resolution: {integrity: sha512-xal3CZX1Xlo/k4ApwCFrHVACi9fBqJ7V+mwhBsuf/1IOKbBy098Fex+Wa/5QMubw09pSZ/u8EY8PWgevJsXp1A==} engines: {node: '>=6'} dependencies: mri: 1.2.0 dev: true - /safaridriver@0.0.4: + /safaridriver/0.0.4: resolution: {integrity: sha512-EgK9Vc2Bk4WaECq1E7ti9GyeQ6JKKQNs40vNOE/b5Ul5dDEt429G0Kj5Nzs4FRS5ZIVa7nBck1TyHuinOYdz2Q==} dev: true - /safaridriver@0.0.5: + /safaridriver/0.0.5: resolution: {integrity: sha512-997HUPVHdOk0019Yz2qbX/B47bC0LcUxMrHU2PDY8IOO7hiT1uhBQEeEAF1BeCrZKFgx5cmsbWYmFgFN0TfqNA==} dev: true - /safe-buffer@5.1.1: + /safe-array-concat/1.0.0: + resolution: {integrity: sha512-9dVEFruWIsnie89yym+xWTAYASdpw3CJV7Li/6zBewGf9z2i1j31rP6jnY0pHEO4QZh6N0K11bFjWmdR8UGdPQ==} + engines: {node: '>=0.4'} + dependencies: + call-bind: 1.0.2 + get-intrinsic: 1.2.1 + has-symbols: 1.0.3 + isarray: 2.0.5 + dev: true + + /safe-buffer/5.1.1: resolution: {integrity: sha512-kKvNJn6Mm93gAczWVJg7wH+wGYWNrDHdWvpUmHyEsgCtIwwo3bqPtV4tR5tuPaUhTOo/kvhVwd8XwwOllGYkbg==} dev: true - /safe-buffer@5.1.2: + /safe-buffer/5.1.2: resolution: {integrity: sha512-Gd2UZBJDkXlY7GbJxfsE8/nvKkUEU1G38c1siN6QP6a9PT9MmHB8GnpscSmMJSoF8LOIrt8ud/wPtojys4G6+g==} + dev: true - /safe-buffer@5.2.1: + /safe-buffer/5.2.1: resolution: {integrity: sha512-rp3So07KcdmmKbGvgaNxQSJr7bGVSVk5S9Eq1F+ppbRo70+YeaDxkw5Dd8NPN+GD6bjnYm2VuPuCXmpuYvmCXQ==} dev: true - /safe-regex-test@1.0.0: + /safe-regex-test/1.0.0: resolution: {integrity: sha512-JBUUzyOgEwXQY1NuPtvcj/qcBDbDmEvWufhlnXZIm75DEHp+afM1r1ujJpJsV/gSM4t59tpDyPi1sd6ZaPFfsA==} dependencies: call-bind: 1.0.2 - get-intrinsic: 1.2.0 + get-intrinsic: 1.2.1 is-regex: 1.1.4 dev: true - /safe-regex2@2.0.0: - resolution: {integrity: sha512-PaUSFsUaNNuKwkBijoAPHAK6/eM6VirvyPWlZ7BAQy4D+hCvh4B6lIG+nPdhbFfIbP+gTGBcrdsOaUs0F+ZBOQ==} - dependencies: - ret: 0.2.2 - dev: true - - /safe-regex@1.1.0: + /safe-regex/1.1.0: resolution: {integrity: sha512-aJXcif4xnaNUzvUuC5gcb46oTS7zvg4jpMTnuqtrEPlR3vFr4pxtdTwaF1Qs3Enjn9HK+ZlwQui+a7z0SywIzg==} dependencies: ret: 0.1.15 dev: true - /safe-regex@2.1.1: + /safe-regex/2.1.1: resolution: {integrity: sha512-rx+x8AMzKb5Q5lQ95Zoi6ZbJqwCLkqi3XuJXp5P3rT8OEc6sZCJG5AE5dU3lsgRr/F4Bs31jSlVN+j5KrsGu9A==} dependencies: - regexp-tree: 0.1.24 + regexp-tree: 0.1.27 + dev: true + + /safe-regex2/2.0.0: + resolution: {integrity: sha512-PaUSFsUaNNuKwkBijoAPHAK6/eM6VirvyPWlZ7BAQy4D+hCvh4B6lIG+nPdhbFfIbP+gTGBcrdsOaUs0F+ZBOQ==} + dependencies: + ret: 0.2.2 dev: true - /safe-stable-stringify@2.3.1: - resolution: {integrity: sha512-kYBSfT+troD9cDA85VDnHZ1rpHC50O0g1e6WlGHVCz/g+JS+9WKLj+XwFYyR8UbrZN8ll9HUpDAAddY58MGisg==} + /safe-stable-stringify/2.4.3: + resolution: {integrity: sha512-e2bDA2WJT0wxseVd4lsDP4+3ONX6HpMXQa1ZhFQ7SU+GjvORCmShbCMltrtIDfkYhVHrOcPtj+KhmDBdPdZD1g==} engines: {node: '>=10'} dev: true - /safer-buffer@2.1.2: + /safer-buffer/2.1.2: resolution: {integrity: sha512-YZo3K82SD7Riyi0E1EQPojLz7kpepnSQI9IyPbHHg1XXXevb5dJI7tpyN2ADxGcQbHG7vcyRHk0cbwqcQriUtg==} dev: true - /sander@0.5.1: + /sander/0.5.1: resolution: {integrity: sha512-3lVqBir7WuKDHGrKRDn/1Ye3kwpXaDOMsiRP1wd6wpZW56gJhsbp5RqQpA6JG/P+pkXizygnr1dKR8vzWaVsfA==} dependencies: es6-promise: 3.3.1 - graceful-fs: 4.2.10 + graceful-fs: 4.2.11 mkdirp: 0.5.6 rimraf: 2.7.1 dev: true - /sane@4.1.0: + /sane/4.1.0: resolution: {integrity: sha512-hhbzAgTIX8O7SHfp2c8/kREfEn4qO/9q8C9beyY6+tvZ87EpoZ3i1RIEvp27YBswnNbY9mWd6paKVmKbAgLfZA==} engines: {node: 6.* || 8.* || >= 10.*} deprecated: some dependency vulnerabilities fixed, support for node < 10 dropped, and newer ECMAScript syntax/features added @@ -22124,7 +19234,7 @@ packages: capture-exit: 2.0.0 exec-sh: 0.3.6 execa: 1.0.0 - fb-watchman: 2.0.1 + fb-watchman: 2.0.2 micromatch: 3.1.10 minimist: 1.2.8 walker: 1.0.8 @@ -22132,127 +19242,95 @@ packages: - supports-color dev: true - /saxes@5.0.1: - resolution: {integrity: sha512-5LBh1Tls8c9xgGjw3QrMwETmTMVk0oFgvrFSvWx62llR2hcEInrKNZ2GZCCuuy2lvWrdl5jhbpeqc5hRYKFOcw==} - engines: {node: '>=10'} - dependencies: - xmlchars: 2.2.0 - dev: true - - /saxes@6.0.0: + /saxes/6.0.0: resolution: {integrity: sha512-xAg7SOnEhrm5zI3puOOKyy1OMcMlIJZYNJY7xLBwSze0UjhPLnWfj2GF2EpT0jmzaJKIWKHLsaSSajf35bcYnA==} engines: {node: '>=v12.22.7'} dependencies: xmlchars: 2.2.0 dev: true - /scheduler@0.20.2: + /scheduler/0.20.2: resolution: {integrity: sha512-2eWfGgAqqWFGqtdMmcL5zCMK1U8KlXv8SQFGglL3CEtd0aDVDWgeF/YoCmvln55m5zSk3J/20hTaSBeSObsQDQ==} dependencies: loose-envify: 1.4.0 object-assign: 4.1.1 - /scheduler@0.21.0: + /scheduler/0.21.0: resolution: {integrity: sha512-1r87x5fz9MXqswA2ERLo0EbOAU74DpIUO090gIasYTqlVoJeMcl+Z1Rg7WHz+qtPujhS/hGIt9kxZOYBV3faRQ==} dependencies: loose-envify: 1.4.0 - /scheduler@0.23.0: + /scheduler/0.23.0: resolution: {integrity: sha512-CtuThmgHNg7zIZWAXi3AsyIzA3n4xx7aNyjwC2VJldO2LMVDhFK+63xGqq6CsJH4rTAt6/M+N4GhZiDYPx9eUw==} dependencies: loose-envify: 1.4.0 - /schema-utils@1.0.0: + /schema-utils/1.0.0: resolution: {integrity: sha512-i27Mic4KovM/lnGsy8whRCHhc7VicJajAjTrYg11K9zfZXnYIt4k5F+kZkwjnrhKzLic/HLU4j11mjsz2G/75g==} engines: {node: '>= 4'} dependencies: ajv: 6.12.6 - ajv-errors: 1.0.1(ajv@6.12.6) - ajv-keywords: 3.5.2(ajv@6.12.6) + ajv-errors: 1.0.1_ajv@6.12.6 + ajv-keywords: 3.5.2_ajv@6.12.6 dev: true - /schema-utils@2.7.0: + /schema-utils/2.7.0: resolution: {integrity: sha512-0ilKFI6QQF5nxDZLFn2dMjvc4hjg/Wkg7rHd3jK6/A4a1Hl9VFdQWvgB1UMGoU94pad1P/8N7fMcEnLnSiju8A==} engines: {node: '>= 8.9.0'} dependencies: - '@types/json-schema': 7.0.11 + '@types/json-schema': 7.0.12 ajv: 6.12.6 - ajv-keywords: 3.5.2(ajv@6.12.6) + ajv-keywords: 3.5.2_ajv@6.12.6 dev: true - /schema-utils@2.7.1: + /schema-utils/2.7.1: resolution: {integrity: sha512-SHiNtMOUGWBQJwzISiVYKu82GiV4QYGePp3odlY1tuKO7gPtphAT5R/py0fA6xtbgLL/RvtJZnU9b8s0F1q0Xg==} engines: {node: '>= 8.9.0'} dependencies: - '@types/json-schema': 7.0.11 + '@types/json-schema': 7.0.12 ajv: 6.12.6 - ajv-keywords: 3.5.2(ajv@6.12.6) + ajv-keywords: 3.5.2_ajv@6.12.6 dev: true - /schema-utils@3.1.1: - resolution: {integrity: sha512-Y5PQxS4ITlC+EahLuXaY86TXfR7Dc5lw294alXOq86JAHCihAIZfqv8nNCWvaEJvaC51uN9hbLGeV0cFBdH+Fw==} + /schema-utils/3.3.0: + resolution: {integrity: sha512-pN/yOAvcC+5rQ5nERGuwrjLlYvLTbCibnZ1I7B1LaiAz9BRBlE9GMgE/eqV30P7aJQUf7Ddimy/RsbYO/GrVGg==} engines: {node: '>= 10.13.0'} dependencies: - '@types/json-schema': 7.0.11 + '@types/json-schema': 7.0.12 ajv: 6.12.6 - ajv-keywords: 3.5.2(ajv@6.12.6) + ajv-keywords: 3.5.2_ajv@6.12.6 dev: true - /scule@1.0.0: + /scule/1.0.0: resolution: {integrity: sha512-4AsO/FrViE/iDNEPaAQlb77tf0csuq27EsVpy6ett584EcRTp6pTDLoGWVxCD77y5iU5FauOvhsI4o1APwPoSQ==} dev: true - /search-insights@2.6.0: - resolution: {integrity: sha512-vU2/fJ+h/Mkm/DJOe+EaM5cafJv/1rRTZpGJTuFPf/Q5LjzgMDsqPdSaZsAe+GAWHHsfsu+rQSAn6c8IGtBEVw==} - engines: {node: '>=8.16.0'} + /secure-json-parse/2.7.0: + resolution: {integrity: sha512-6aU+Rwsezw7VR8/nyvKTx8QpWH9FrcYiXXlqC4z5d5XQBDRqtbfsRjnwGyqbi3gddNtWHuEk9OANUotL26qKUw==} dev: true - /secure-json-parse@2.5.0: - resolution: {integrity: sha512-ZQruFgZnIWH+WyO9t5rWt4ZEGqCKPwhiw+YbzTwpmT9elgLrLcfuyUiSnwwjUiVy9r4VM3urtbNF1xmEh9IL2w==} - dev: true - - /select-hose@2.0.0: + /select-hose/2.0.0: resolution: {integrity: sha512-mEugaLK+YfkijB4fx0e6kImuJdCIt2LxCRcbEYPqRGCs4F2ogyfZU5IAZRdjCP8JPq2AtdNoC/Dux63d9Kiryg==} dev: true - /semver@5.7.1: - resolution: {integrity: sha512-sauaDf/PZdVgrLTNYHRtpXa1iRiKcaebiKQ1BJdpQlWH2lCvexQdX55snPFyK7QzpudqbCI0qXFfOasHdyNDGQ==} - hasBin: true - dev: true - - /semver@6.3.0: - resolution: {integrity: sha512-b39TBaTSfV6yBrapU89p5fKekE2m/NwnDocOVruQFS1/veMgdzuPcnOM34M6CwxW8jH/lxEa5rBoDeUwu5HHTw==} - hasBin: true - - /semver@7.0.0: - resolution: {integrity: sha512-+GB6zVA9LWh6zovYQLALHwv5rb2PHGlJi3lfiqIHxR0uuwCgefcOJc59v9fv1w8GbStwxuuqqAjI9NMAOOgq1A==} - hasBin: true - dev: true - - /semver@7.3.7: - resolution: {integrity: sha512-QlYTucUYOews+WeEujDoEGziz4K6c47V/Bd+LjSSYcA94p+DmINdf7ncaUinThfvZyu13lN9OY1XDxt8C0Tw0g==} - engines: {node: '>=10'} - hasBin: true - dependencies: - lru-cache: 6.0.0 - dev: true - - /semver@7.5.2: - resolution: {integrity: sha512-SoftuTROv/cRjCze/scjGyiDtcUyxw1rgYQSZY7XTmtR5hX+dm76iDbTH8TkLPHCQmlbQVSSbNZCPM2hb0knnQ==} - engines: {node: '>=10'} - hasBin: true - dependencies: - lru-cache: 6.0.0 + /semver/5.7.2: + resolution: {integrity: sha512-cBznnQ9KjJqU67B52RMC65CMarK2600WFnbkcaiwWq3xy/5haFJlshgnpjovMVJ+Hff49d8GEn0b87C5pDQ10g==} + hasBin: true dev: true - /semver@7.5.4: + /semver/6.3.1: + resolution: {integrity: sha512-BR7VvDCVHO+q2xBEWskxS6DJE1qRnb7DxzUrogb71CWoSficBxYsiAGd+Kl0mmq/MprG9yArRkyrQxTO6XjMzA==} + hasBin: true + + /semver/7.5.4: resolution: {integrity: sha512-1bCSESV6Pv+i21Hvpxp3Dx+pSD8lIPt8uVjRrxAUt/nbswYc+tK6Y2btiULjd4+fnq15PX+nqQDC7Oft7WkwcA==} engines: {node: '>=10'} hasBin: true dependencies: lru-cache: 6.0.0 + dev: true - /send@0.18.0: + /send/0.18.0: resolution: {integrity: sha512-qqWzuOjSFOuqPjFe4NOsMLafToQQwBSOEpS+FwEt3A2V3vKubTquT3vmLTQpFgMXp8AlFWFuP1qKaJZOtPpVXg==} engines: {node: '>= 0.8.0'} dependencies: @@ -22273,32 +19351,36 @@ packages: - supports-color dev: true - /serialize-error@8.1.0: + /serialize-error/8.1.0: resolution: {integrity: sha512-3NnuWfM6vBYoy5gZFvHiYsVbafvI9vZv/+jlIigFn4oP4zjNPK3LhcY0xSCgeb1a5L8jO71Mit9LlNoi2UfDDQ==} engines: {node: '>=10'} dependencies: type-fest: 0.20.2 dev: true - /serialize-javascript@4.0.0: + /serialize-javascript/4.0.0: resolution: {integrity: sha512-GaNA54380uFefWghODBWEGisLZFj00nS5ACs6yHa9nLqlLpVLO8ChDGeKRjZnV4Nh4n0Qi7nhYZD/9fCPzEqkw==} dependencies: randombytes: 2.1.0 dev: true - /serialize-javascript@5.0.1: + /serialize-javascript/5.0.1: resolution: {integrity: sha512-SaaNal9imEO737H2c05Og0/8LUXG7EnsZyMa8MzkmuHoELfT6txuj0cMqRj6zfPKnmQ1yasR4PCJc8x+M4JSPA==} dependencies: randombytes: 2.1.0 dev: true - /serialize-javascript@6.0.0: - resolution: {integrity: sha512-Qr3TosvguFt8ePWqsvRfrKyQXIiW+nGbYpy8XK24NQHE83caxWt+mIymTT19DGFbNWNLfEwsrkSmN64lVWB9ag==} + /serialize-javascript/6.0.1: + resolution: {integrity: sha512-owoXEFjWRllis8/M1Q+Cw5k8ZH40e3zhp/ovX+Xr/vi1qj6QesbyXXViFbpNvWvPNAD62SutwEXavefrLJWj7w==} dependencies: randombytes: 2.1.0 dev: true - /serve-favicon@2.5.0: + /seroval/0.5.1: + resolution: {integrity: sha512-ZfhQVB59hmIauJG5Ydynupy8KHyr5imGNtdDhbZG68Ufh1Ynkv9KOYOAABf71oVbQxJ8VkWnMHAjEHE7fWkH5g==} + engines: {node: '>=10'} + + /serve-favicon/2.5.0: resolution: {integrity: sha512-FMW2RvqNr03x+C0WxTyu6sOv21oOjkq5j8tjquWccwa6ScNyGFOGJVpuS1NmTVGBAHS07xnSKotgf2ehQmf9iA==} engines: {node: '>= 0.8.0'} dependencies: @@ -22309,7 +19391,7 @@ packages: safe-buffer: 5.1.1 dev: true - /serve-static@1.15.0: + /serve-static/1.15.0: resolution: {integrity: sha512-XGuRDNjXUijsUL0vl6nSD7cwURuzEgglbOaFuZM9g3kwDXOWVTck0jLzjPzGD+TazWbboZYu52/9/XPdUgne9g==} engines: {node: '>= 0.8.0'} dependencies: @@ -22321,19 +19403,15 @@ packages: - supports-color dev: true - /set-blocking@2.0.0: + /set-blocking/2.0.0: resolution: {integrity: sha512-KiKBS8AnWGEyLzofFfmvKwpdPzqiy16LvQfK3yv/fVH7Bj13/wl3JSR1J+rfgRE9q7xUJK4qvgS8raSOeLUehw==} dev: true - /set-cookie-parser@2.5.1: - resolution: {integrity: sha512-1jeBGaKNGdEq4FgIrORu/N570dwoPYio8lSoYLWmX7sQ//0JY08Xh9o5pBcgmHQ/MbsYp/aZnOe1s1lIsbLprQ==} - dev: true - - /set-cookie-parser@2.6.0: + /set-cookie-parser/2.6.0: resolution: {integrity: sha512-RVnVQxTXuerk653XfuliOxBP81Sf0+qfQE73LIYKcyMYHG94AuH0kgrQpRDuTZnSmjpysHmzxJXKNfa6PjFhyQ==} dev: true - /set-value@2.0.1: + /set-value/2.0.1: resolution: {integrity: sha512-JxHc1weCN68wRY0fhCoXpyK55m/XPHafOmK4UWD7m2CI14GMcFypt4w/0+NV5f/ZMby2F6S2wwA7fgynh9gWSw==} engines: {node: '>=0.10.0'} dependencies: @@ -22343,15 +19421,15 @@ packages: split-string: 3.1.0 dev: true - /setimmediate@1.0.5: + /setimmediate/1.0.5: resolution: {integrity: sha512-MATJdZp8sLqDl/68LfQmbP8zKPLQNV6BIZoIgrscFDQ+RsvK/BxeDQOgyxKKoh0y/8h3BqVFnCqQ/gd+reiIXA==} dev: true - /setprototypeof@1.2.0: + /setprototypeof/1.2.0: resolution: {integrity: sha512-E5LDX7Wrp85Kil5bhZv46j8jOeboKq5JMmYM3gVGdGH8xFpPWXUMsNrlODCrkoxMEeNi/XZIwuRvY4XNwYMJpw==} dev: true - /sha.js@2.4.11: + /sha.js/2.4.11: resolution: {integrity: sha512-QMEp5B7cftE7APOjk5Y6xgrbWu+WkLVQwk8JNjZ8nKRciZaByEW6MubieAiToS7+dwvrjGhH8jRXz3MVd0AYqQ==} hasBin: true dependencies: @@ -22359,23 +19437,23 @@ packages: safe-buffer: 5.2.1 dev: true - /shallow-clone@3.0.1: + /shallow-clone/3.0.1: resolution: {integrity: sha512-/6KqX+GVUdqPuPPd2LxDDxzX6CAbjJehAAOKlNpqqUpAqPM6HeL8f+o3a+JsyGjn2lv0WY8UsTgUJjU9Ok55NA==} engines: {node: '>=8'} dependencies: kind-of: 6.0.3 dev: true - /sharp-ico@0.1.5: + /sharp-ico/0.1.5: resolution: {integrity: sha512-a3jODQl82NPp1d5OYb0wY+oFaPk7AvyxipIowCHk7pBsZCWgbe0yAkU2OOXdoH0ENyANhyOQbs9xkAiRHcF02Q==} dependencies: decode-ico: 0.4.1 ico-endec: 0.1.6 - sharp: 0.32.1 + sharp: 0.32.2 dev: true - /sharp@0.32.1: - resolution: {integrity: sha512-kQTFtj7ldpUqSe8kDxoGLZc1rnMFU0AO2pqbX6pLy3b7Oj8ivJIdoKNwxHVQG2HN6XpHPJqCSM2nsma2gOXvOg==} + /sharp/0.32.2: + resolution: {integrity: sha512-e4hyWKtU7ks/rLmoPys476zhpQnLqPJopz4+5b6OPeyJfvCTInAp0pe5tGhstjsNdUvDLrUVGEwevewYdZM8Eg==} engines: {node: '>=14.15.0'} requiresBuild: true dependencies: @@ -22383,41 +19461,41 @@ packages: detect-libc: 2.0.1 node-addon-api: 6.1.0 prebuild-install: 7.1.1 - semver: 7.5.2 + semver: 7.5.4 simple-get: 4.0.1 - tar-fs: 2.1.1 + tar-fs: 3.0.4 tunnel-agent: 0.6.0 dev: true - /shebang-command@1.2.0: + /shebang-command/1.2.0: resolution: {integrity: sha512-EV3L1+UQWGor21OmnvojK36mhg+TyIKDh3iFBKBohr5xeXIhNBcx8oWdgkTEEQ+BEFFYdLRuqMfd5L84N1V5Vg==} engines: {node: '>=0.10.0'} dependencies: shebang-regex: 1.0.0 dev: true - /shebang-command@2.0.0: + /shebang-command/2.0.0: resolution: {integrity: sha512-kHxr2zZpYtdmrN1qDjrrX/Z1rR1kG8Dx+gkpK1G4eXmvXswmcE1hTWBWYUzlraYw1/yZp6YuDY77YtvbN0dmDA==} engines: {node: '>=8'} dependencies: shebang-regex: 3.0.0 dev: true - /shebang-regex@1.0.0: + /shebang-regex/1.0.0: resolution: {integrity: sha512-wpoSFAxys6b2a2wHZ1XpDSgD7N9iVjg29Ph9uV/uaP9Ex/KXlkTZTeddxDPSYQpgvzKLGJke2UU0AzoGCjNIvQ==} engines: {node: '>=0.10.0'} dev: true - /shebang-regex@3.0.0: + /shebang-regex/3.0.0: resolution: {integrity: sha512-7++dFhtcx3353uBaq8DDR4NuxBetBzC7ZQOhmTQInHEd6bSrXdiEyzCvG07Z44UYdLShWUyXt5M/yhz8ekcb1A==} engines: {node: '>=8'} dev: true - /shell-quote@1.7.4: - resolution: {integrity: sha512-8o/QEhSSRb1a5i7TFR0iM4G16Z0vYB2OQVs4G3aAFXjn3T6yEx8AZxy1PgDF7I00LZHYA3WxaSYIf5e5sAX8Rw==} + /shell-quote/1.8.1: + resolution: {integrity: sha512-6j1W9l1iAs/4xYBI1SYOVZyFcCis9b4KCLQ8fgAGG07QvzaRLVVRQvAy85yNmmZSjYjg4MWh4gNvlPujU/5LpA==} dev: true - /shiki@0.14.3: + /shiki/0.14.3: resolution: {integrity: sha512-U3S/a+b0KS+UkTyMjoNojvTgrBHjgp7L6ovhFVZsXmBGnVdQ4K4U9oK0z63w538S91ATngv1vXigHCSWOwnr+g==} dependencies: ansi-sequence-parser: 1.1.0 @@ -22426,36 +19504,36 @@ packages: vscode-textmate: 8.0.0 dev: true - /side-channel@1.0.4: + /side-channel/1.0.4: resolution: {integrity: sha512-q5XPytqFEIKHkGdiMIrY10mvLRvnQh42/+GoBlFW3b2LXLE2xxJpZFdm94we0BaoV3RwJyGqg5wS7epxTv0Zvw==} dependencies: call-bind: 1.0.2 - get-intrinsic: 1.2.0 + get-intrinsic: 1.2.1 object-inspect: 1.12.3 dev: true - /siginfo@2.0.0: + /siginfo/2.0.0: resolution: {integrity: sha512-ybx0WO1/8bSBLEWXZvEd7gMW3Sn3JFlW3TvX1nREbDLRNQNaeNN8WK0meBwPdAaOI7TtRRRJn/Es1zhrrCHu7g==} dev: false - /sigmund@1.0.1: + /sigmund/1.0.1: resolution: {integrity: sha512-fCvEXfh6NWpm+YSuY2bpXb/VIihqWA6hLsgboC+0nl71Q7N7o2eaCW8mJa/NLvQhs6jpd3VZV4UiUQlV6+lc8g==} dev: true - /signal-exit@3.0.7: + /signal-exit/3.0.7: resolution: {integrity: sha512-wnD2ZE+l+SPC/uoS0vXeE9L1+0wuaMqKlfz9AMUo38JsyLSBWSFcHR1Rri62LZc12vLr1gb3jl7iwQhgwpAbGQ==} dev: true - /signal-exit@4.0.1: - resolution: {integrity: sha512-uUWsN4aOxJAS8KOuf3QMyFtgm1pkb6I+KRZbRF/ghdf5T7sM+B1lLLzPDxswUjkmHyxQAVzEgG35E3NzDM9GVw==} + /signal-exit/4.0.2: + resolution: {integrity: sha512-MY2/qGx4enyjprQnFaZsHib3Yadh3IXyV2C321GY0pjGfVBu4un0uDJkwgdxqO+Rdx8JMT8IfJIRwbYVz3Ob3Q==} engines: {node: '>=14'} dev: true - /simple-concat@1.0.1: + /simple-concat/1.0.1: resolution: {integrity: sha512-cSFtAPtRhljv69IK0hTVZQ+OfE9nePi/rtJmw5UjHeVyVroEqJXP1sFztKUy1qU+xvz3u/sfYJLa947b7nAN2Q==} dev: true - /simple-get@4.0.1: + /simple-get/4.0.1: resolution: {integrity: sha512-brv7p5WgH0jmQJr1ZDDfKDOSeWWg+OVypG99A/5vYGPqJ6pxiaHLy8nxtFjBA7oMa01ebA9gfh1uMCFqOuXxvA==} dependencies: decompress-response: 6.0.0 @@ -22463,46 +19541,46 @@ packages: simple-concat: 1.0.1 dev: true - /simple-git-hooks@2.8.1: + /simple-git-hooks/2.8.1: resolution: {integrity: sha512-DYpcVR1AGtSfFUNzlBdHrQGPsOhuuEJ/FkmPOOlFysP60AHd3nsEpkGq/QEOdtUyT1Qhk7w9oLmFoMG+75BDog==} hasBin: true requiresBuild: true dev: true - /simple-swizzle@0.2.2: + /simple-swizzle/0.2.2: resolution: {integrity: sha512-JA//kQgZtbuY83m+xT+tXJkmJncGMTFT+C+g2h2R9uxkYIrE2yy9sgmcLhCnw57/WSD+Eh3J97FPEDFnbXnDUg==} dependencies: is-arrayish: 0.3.2 dev: true - /sirv@2.0.3: + /sirv/2.0.3: resolution: {integrity: sha512-O9jm9BsID1P+0HOi81VpXPoDxYP374pkOLzACAoyUQ/3OUVndNpsz6wMnY2z+yOxzbllCKZrM+9QrWsv4THnyA==} engines: {node: '>= 10'} dependencies: '@polka/url': 1.0.0-next.21 mrmime: 1.0.1 - totalist: 3.0.0 + totalist: 3.0.1 - /sisteransi@1.0.5: + /sisteransi/1.0.5: resolution: {integrity: sha512-bLGGlR1QxBcynn2d5YmDX4MGjlZvy2MRBDRNHLJ8VI6l6+9FUiyTFNJ0IveOSP0bcXgVDPRcfGqA0pjaqUpfVg==} dev: true - /slash@2.0.0: + /slash/2.0.0: resolution: {integrity: sha512-ZYKh3Wh2z1PpEXWr0MpSBZ0V6mZHAQfYevttO11c51CaWjGTaadiKZ+wVt1PbMlDV5qhMFslpZCemhwOK7C89A==} engines: {node: '>=6'} dev: true - /slash@3.0.0: + /slash/3.0.0: resolution: {integrity: sha512-g9Q1haeby36OSStwb4ntCGGGaKsaVSjQ68fBxoQcutl5fS1vuY18H3wSt3jFyFtrkx+Kz0V1G85A4MyAdDMi2Q==} engines: {node: '>=8'} dev: true - /slash@4.0.0: + /slash/4.0.0: resolution: {integrity: sha512-3dOsAHXXUkQTpOYcoAxLIorMTp4gIQr5IW3iVb7A7lFIp0VHhnynm9izx6TssdrIcVIESAlVjtnO2K8bg+Coew==} engines: {node: '>=12'} dev: true - /slice-ansi@3.0.0: + /slice-ansi/3.0.0: resolution: {integrity: sha512-pSyv7bSTC7ig9Dcgbw9AuRNUb5k5V6oDudjZoMBSr13qpLBG7tB+zgCkARjq7xIUgdz5P1Qe8u+rSGdouOOIyQ==} engines: {node: '>=8'} dependencies: @@ -22511,7 +19589,7 @@ packages: is-fullwidth-code-point: 3.0.0 dev: true - /slice-ansi@4.0.0: + /slice-ansi/4.0.0: resolution: {integrity: sha512-qMCMfhY040cVHT43K9BFygqYbUPFZKHOg7K73mtTWJRb8pyP3fzf4Ixd5SzdEJQ6MRUg/WBnOLxghZtKKurENQ==} engines: {node: '>=10'} dependencies: @@ -22520,7 +19598,7 @@ packages: is-fullwidth-code-point: 3.0.0 dev: true - /slice-ansi@5.0.0: + /slice-ansi/5.0.0: resolution: {integrity: sha512-FC+lgizVPfie0kkhqUScwRu1O/lF6NOgJmlCgK+/LYxDCTk8sGelYaHDhFcDN+Sn3Cv+3VSa4Byeo+IMCzpMgQ==} engines: {node: '>=12'} dependencies: @@ -22528,7 +19606,7 @@ packages: is-fullwidth-code-point: 4.0.0 dev: true - /snapdragon-node@2.1.1: + /snapdragon-node/2.1.1: resolution: {integrity: sha512-O27l4xaMYt/RSQ5TR3vpWCAB5Kb/czIcqUFOM/C4fYcLnbZUc1PkjTAMjof2pBWaSTwOUd6qUHcFGVGj7aIwnw==} engines: {node: '>=0.10.0'} dependencies: @@ -22537,14 +19615,14 @@ packages: snapdragon-util: 3.0.1 dev: true - /snapdragon-util@3.0.1: + /snapdragon-util/3.0.1: resolution: {integrity: sha512-mbKkMdQKsjX4BAL4bRYTj21edOf8cN7XHdYUJEe+Zn99hVEYcMvKPct1IqNe7+AZPirn8BCDOQBHQZknqmKlZQ==} engines: {node: '>=0.10.0'} dependencies: kind-of: 3.2.2 dev: true - /snapdragon@0.8.2: + /snapdragon/0.8.2: resolution: {integrity: sha512-FtyOnWN/wCHTVXOMwvSv26d+ko5vWlIDD6zoUJ7LW8vh+ZBC8QdljveRP+crNrtBwioEUWy/4dMtbBjA4ioNlg==} engines: {node: '>=0.10.0'} dependencies: @@ -22560,39 +19638,41 @@ packages: - supports-color dev: true - /solid-js@1.5.2: - resolution: {integrity: sha512-4dUeAVVJsMNLuEZ4VjGYf3rUgOc2CXEvzp/Q01UcF1EJBnMoqhYmXTEDiLD829kAyDpgnE1O0bXG1PzYYiXOZQ==} + /solid-js/1.7.8: + resolution: {integrity: sha512-XHBWk1FvFd0JMKljko7FfhefJMTSgYEuVKcQ2a8hzRXfiuSJAGsrPPafqEo+f6l+e8Oe3cROSpIL6kbzjC1fjQ==} dependencies: - csstype: 3.1.0 + csstype: 3.1.2 + seroval: 0.5.1 - /solid-refresh@0.4.1(solid-js@1.5.2): - resolution: {integrity: sha512-v3tD/OXQcUyXLrWjPW1dXZyeWwP7/+GQNs8YTL09GBq+5FguA6IejJWUvJDrLIA4M0ho9/5zK2e9n+uy+4488g==} + /solid-refresh/0.5.3_solid-js@1.7.8: + resolution: {integrity: sha512-Otg5it5sjOdZbQZJnvo99TEBAr6J7PQ5AubZLNU6szZzg3RQQ5MX04oteBIIGDs0y2Qv8aXKm9e44V8z+UnFdw==} peerDependencies: solid-js: ^1.3 dependencies: - '@babel/generator': 7.22.5 + '@babel/generator': 7.22.7 '@babel/helper-module-imports': 7.22.5 '@babel/types': 7.22.5 - solid-js: 1.5.2 + solid-js: 1.7.8 dev: true - /solid-testing-library@0.5.0(solid-js@1.5.2): - resolution: {integrity: sha512-vr4Ke9Dq3bUFLaXOcN8/IVn2e9Q37w4vdmoIOmFBIPs7iCJX9IxuC0IdQqK8nzBZMQqceijkfyCE3Qc407KmaA==} + /solid-testing-library/0.5.1_solid-js@1.7.8: + resolution: {integrity: sha512-CfcCWsI5zIJz2zcyZQz2weq+6cCS5QrcmWeEmUEy03fElJ/BV5Ly4MMTsmwdOK803zY3wJP5pPf026C40VrE1Q==} engines: {node: '>= 14'} + deprecated: This package is now available at @solidjs/testing-library peerDependencies: solid-js: '>=1.0.0' dependencies: - '@testing-library/dom': 8.19.0 - solid-js: 1.5.2 + '@testing-library/dom': 8.20.1 + solid-js: 1.7.8 dev: true - /sonic-boom@3.2.0: - resolution: {integrity: sha512-SbbZ+Kqj/XIunvIAgUZRlqd6CGQYq71tRRbXR92Za8J/R3Yh4Av+TWENiSiEgnlwckYLyP0YZQWVfyNC0dzLaA==} + /sonic-boom/3.3.0: + resolution: {integrity: sha512-LYxp34KlZ1a2Jb8ZQgFCK3niIHzibdwtwNUWKg0qQRzsDoJ3Gfgkf8KdBTFU3SkejDEIlWwnSnpVdOZIhFMl/g==} dependencies: atomic-sleep: 1.0.0 dev: true - /sorcery@0.11.0: + /sorcery/0.11.0: resolution: {integrity: sha512-J69LQ22xrQB1cIFJhPfgtLuI6BpWRiWu1Y3vSsIwK/eAScqJxd/+CJlUuHQRdX2C9NGFamq+KqNywGgaThwfHw==} hasBin: true dependencies: @@ -22602,67 +19682,67 @@ packages: sander: 0.5.1 dev: true - /source-list-map@2.0.1: + /source-list-map/2.0.1: resolution: {integrity: sha512-qnQ7gVMxGNxsiL4lEuJwe/To8UnK7fAnmbGEEH8RpLouuKbeEm0lhbQVFIrNSuB+G7tVrAlVsZgETT5nljf+Iw==} dev: true - /source-map-js@1.0.2: + /source-map-js/1.0.2: resolution: {integrity: sha512-R0XvVJ9WusLiqTCEiGCmICCMplcCkIwwR11mOSD9CR5u+IXYdiseeEuXCVAjS54zqwkLcPNnmU4OeJ6tUrWhDw==} engines: {node: '>=0.10.0'} - /source-map-resolve@0.5.3: + /source-map-resolve/0.5.3: resolution: {integrity: sha512-Htz+RnsXWk5+P2slx5Jh3Q66vhQj1Cllm0zvnaY98+NFx+Dv2CF/f5O/t8x+KaNdrdIAsruNzoh/KpialbqAnw==} deprecated: See https://github.com/lydell/source-map-resolve#deprecated dependencies: atob: 2.1.2 - decode-uri-component: 0.2.0 + decode-uri-component: 0.2.2 resolve-url: 0.2.1 source-map-url: 0.4.1 urix: 0.1.0 dev: true - /source-map-support@0.5.21: + /source-map-support/0.5.21: resolution: {integrity: sha512-uBHU3L3czsIyYXKX88fdrGovxdSCoTGDRZ6SYXtSRxLZUzHg5P/66Ht6uoUlHu9EZod+inXhKo3qQgwXUT/y1w==} dependencies: buffer-from: 1.1.2 source-map: 0.6.1 dev: true - /source-map-url@0.4.1: + /source-map-url/0.4.1: resolution: {integrity: sha512-cPiFOTLUKvJFIg4SKVScy4ilPPW6rFgMgfuZJPNoDuMs3nC1HbMUycBoJw77xFIp6z1UJQJOfx6C9GMH80DiTw==} deprecated: See https://github.com/lydell/source-map-url#deprecated dev: true - /source-map@0.5.7: + /source-map/0.5.7: resolution: {integrity: sha512-LbrmJOMUSdEVxIKvdcJzQC+nQhe8FUZQTXQy6+I75skNgn3OoQ0DZA8YnFa7gp8tqtL3KPf1kmo0R5DoApeSGQ==} engines: {node: '>=0.10.0'} - /source-map@0.6.1: + /source-map/0.6.1: resolution: {integrity: sha512-UjgapumWlbMhkBgzT7Ykc5YXUT46F0iKu8SGXq0bcwP5dz/h0Plj6enJqjz1Zbq2l5WaqYnrVbwWOWMyF3F47g==} engines: {node: '>=0.10.0'} - requiresBuild: true - /source-map@0.7.4: + /source-map/0.7.4: resolution: {integrity: sha512-l3BikUxvPOcn5E74dZiq5BGsTb5yEwhaTSzccU6t4sDOH8NWJCstKO5QT2CvtFoK6F0saL7p9xHAqHOlCPJygA==} engines: {node: '>= 8'} dev: true - /source-map@0.8.0-beta.0: + /source-map/0.8.0-beta.0: resolution: {integrity: sha512-2ymg6oRBpebeZi9UUNsgQ89bhx01TcTkmNTGnNO88imTmbSgy4nfujrgVEFKWpMTEGA11EDkTt7mqObTPdigIA==} engines: {node: '>= 8'} dependencies: whatwg-url: 7.1.0 dev: true - /sourcemap-codec@1.4.8: + /sourcemap-codec/1.4.8: resolution: {integrity: sha512-9NykojV5Uih4lgo5So5dtw+f0JgJX30KCNI8gwhz2J9A15wD0Ml6tjHKwf6fTSa6fAdVBdZeNOs9eJ71qCk8vA==} deprecated: Please use @jridgewell/sourcemap-codec instead + dev: true - /space-separated-tokens@1.1.5: + /space-separated-tokens/1.1.5: resolution: {integrity: sha512-q/JSVd1Lptzhf5bkYm4ob4iWPjx0KiRe3sRFBNrVqbJkFaBm5vbbowy1mymoPNLRa52+oadOhJ+K49wsSeSjTA==} dev: true - /spdx-compare@1.0.0: + /spdx-compare/1.0.0: resolution: {integrity: sha512-C1mDZOX0hnu0ep9dfmuoi03+eOdDoz2yvK79RxbcrVEG1NO1Ph35yW102DHWKN4pk80nwCgeMmSY5L25VE4D9A==} dependencies: array-find-index: 1.0.2 @@ -22670,39 +19750,39 @@ packages: spdx-ranges: 2.1.1 dev: true - /spdx-correct@3.1.1: - resolution: {integrity: sha512-cOYcUWwhCuHCXi49RhFRCyJEK3iPj1Ziz9DpViV3tbZOwXD49QzIN3MpOLJNxh2qwq2lJJZaKMVw9qNi4jTC0w==} + /spdx-correct/3.2.0: + resolution: {integrity: sha512-kN9dJbvnySHULIluDHy32WHRUu3Og7B9sbY7tsFLctQkIqnMh3hErYgdMjTYuqmcXX+lK5T1lnUt3G7zNswmZA==} dependencies: spdx-expression-parse: 3.0.1 - spdx-license-ids: 3.0.12 + spdx-license-ids: 3.0.13 dev: true - /spdx-exceptions@2.3.0: + /spdx-exceptions/2.3.0: resolution: {integrity: sha512-/tTrYOC7PPI1nUAgx34hUpqXuyJG+DTHJTnIULG4rDygi4xu/tfgmq1e1cIRwRzwZgo4NLySi+ricLkZkw4i5A==} dev: true - /spdx-expression-parse@3.0.1: + /spdx-expression-parse/3.0.1: resolution: {integrity: sha512-cbqHunsQWnJNE6KhVSMsMeH5H/L9EpymbzqTQ3uLwNCLZ1Q481oWaofqH7nO6V07xlXwY6PhQdQ2IedWx/ZK4Q==} dependencies: spdx-exceptions: 2.3.0 - spdx-license-ids: 3.0.12 + spdx-license-ids: 3.0.13 dev: true - /spdx-expression-validate@2.0.0: + /spdx-expression-validate/2.0.0: resolution: {integrity: sha512-b3wydZLM+Tc6CFvaRDBOF9d76oGIHNCLYFeHbftFXUWjnfZWganmDmvtM5sm1cRwJc/VDBMLyGGrsLFd1vOxbg==} dependencies: spdx-expression-parse: 3.0.1 dev: true - /spdx-license-ids@3.0.12: - resolution: {integrity: sha512-rr+VVSXtRhO4OHbXUiAF7xW3Bo9DuuF6C5jH+q/x15j2jniycgKbxU09Hr0WqlSLUs4i4ltHGXqTe7VHclYWyA==} + /spdx-license-ids/3.0.13: + resolution: {integrity: sha512-XkD+zwiqXHikFZm4AX/7JSCXA98U5Db4AFd5XUg/+9UNtnH75+Z9KxtpYiJZx36mUDVOwH83pl7yvCer6ewM3w==} dev: true - /spdx-ranges@2.1.1: + /spdx-ranges/2.1.1: resolution: {integrity: sha512-mcdpQFV7UDAgLpXEE/jOMqvK4LBoO0uTQg0uvXUewmEFhpiZx5yJSZITHB8w1ZahKdhfZqP5GPEOKLyEq5p8XA==} dev: true - /spdx-satisfies@5.0.1: + /spdx-satisfies/5.0.1: resolution: {integrity: sha512-Nwor6W6gzFp8XX4neaKQ7ChV4wmpSh2sSDemMFSzHxpTw460jxFYeOn+jq4ybnSSw/5sc3pjka9MQPouksQNpw==} dependencies: spdx-compare: 1.0.0 @@ -22710,24 +19790,24 @@ packages: spdx-ranges: 2.1.1 dev: true - /spdy-transport@3.0.0: + /spdy-transport/3.0.0: resolution: {integrity: sha512-hsLVFE5SjA6TCisWeJXFKniGGOpBgMLmerfO2aCyCU5s7nJ/rpAepqmFifv/GCbSbueEeAJJnmSQ2rKC/g8Fcw==} dependencies: - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 detect-node: 2.1.0 hpack.js: 2.1.6 obuf: 1.1.2 - readable-stream: 3.6.0 + readable-stream: 3.6.2 wbuf: 1.7.3 transitivePeerDependencies: - supports-color dev: true - /spdy@4.0.2: + /spdy/4.0.2: resolution: {integrity: sha512-r46gZQZQV+Kl9oItvl1JZZqJKGr+oEkB08A6BzkiR7593/7IbtuncXHd2YoYeTsG4157ZssMu9KYvUHLcjcDoA==} engines: {node: '>=6.0.0'} dependencies: - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 handle-thing: 2.0.1 http-deceiver: 1.2.7 select-hose: 2.0.0 @@ -22736,27 +19816,27 @@ packages: - supports-color dev: true - /split-string@3.1.0: + /split-string/3.1.0: resolution: {integrity: sha512-NzNVhJDYpwceVVii8/Hu6DKfD2G+NrQHlS/V/qgv763EYudVwEcMQNxd2lh+0VrUByXN/oJkl5grOhYWvQUYiw==} engines: {node: '>=0.10.0'} dependencies: extend-shallow: 3.0.2 dev: true - /split2@4.1.0: - resolution: {integrity: sha512-VBiJxFkxiXRlUIeyMQi8s4hgvKCSjtknJv/LVYbrgALPwf5zSKmEwV9Lst25AkvMDnvxODugjdl6KZgwKM1WYQ==} + /split2/4.2.0: + resolution: {integrity: sha512-UcjcJOWknrNkF6PLX83qcHM6KHgVKNkV62Y8a5uYDVv9ydGQVwAHMKqHdJje1VTWpljG0WYpCDhrCdAOYH4TWg==} engines: {node: '>= 10.x'} dev: true - /splitpanes@3.1.5: + /splitpanes/3.1.5: resolution: {integrity: sha512-r3Mq2ITFQ5a2VXLOy4/Sb2Ptp7OfEO8YIbhVJqJXoFc9hc5nTXXkCvtVDjIGbvC0vdE7tse+xTM9BMjsszP6bw==} dev: true - /sprintf-js@1.0.3: + /sprintf-js/1.0.3: resolution: {integrity: sha512-D9cPgkvLlV3t3IzL0D0YLvGA9Ahk4PcvVwUbN0dSGr1aP0Nrt4AEnTUbuGvquEC0mA64Gqt1fzirlRs5ibXx8g==} dev: true - /sshpk@1.17.0: + /sshpk/1.17.0: resolution: {integrity: sha512-/9HIEs1ZXGhSPE8X6Ccm7Nam1z8KcoCqPdI7ecm1N33EzAetWahvQWVqLZtaZQ+IDKX4IyA2o0gBzqIMkAagHQ==} engines: {node: '>=0.10.0'} hasBin: true @@ -22772,48 +19852,48 @@ packages: tweetnacl: 0.14.5 dev: true - /ssim.js@3.5.0: + /ssim.js/3.5.0: resolution: {integrity: sha512-Aj6Jl2z6oDmgYFFbQqK7fght19bXdOxY7Tj03nF+03M9gCBAjeIiO8/PlEGMfKDwYpw4q6iBqVq2YuREorGg/g==} dev: true - /ssri@6.0.2: + /ssri/6.0.2: resolution: {integrity: sha512-cepbSq/neFK7xB6A50KHN0xHDotYzq58wWCa5LeWqnPrHG8GzfEjO/4O8kpmcGW+oaxkvhEJCWgbgNk4/ZV93Q==} dependencies: figgy-pudding: 3.5.2 dev: true - /ssri@8.0.1: + /ssri/8.0.1: resolution: {integrity: sha512-97qShzy1AiyxvPNIkLWoGua7xoQzzPjQ0HAH4B0rWKo7SZ6USuPcrUiAFrws0UH8RrbWmgq3LMTObhPIHbbBeQ==} engines: {node: '>= 8'} dependencies: - minipass: 3.3.4 + minipass: 3.3.6 dev: true - /stable@0.1.8: + /stable/0.1.8: resolution: {integrity: sha512-ji9qxRnOVfcuLDySj9qzhGSEFVobyt1kIOSkj1qZzYLzq7Tos/oUUWvotUPQLlrsidqsK6tBH89Bc9kL5zHA6w==} deprecated: 'Modern JS already guarantees Array#sort() is a stable sort, so this library is deprecated. See the compatibility table on MDN: https://developer.mozilla.org/en-US/docs/Web/JavaScript/Reference/Global_Objects/Array/sort#browser_compatibility' dev: true - /stack-utils@2.0.5: - resolution: {integrity: sha512-xrQcmYhOsn/1kX+Vraq+7j4oE2j/6BFscZ0etmYg81xuM8Gq0022Pxb8+IqgOFUIaxHs0KaSb7T1+OegiNrNFA==} + /stack-utils/2.0.6: + resolution: {integrity: sha512-XlkWvfIm6RmsWtNJx+uqtKLS8eqFbxUg0ZzLXqY0caEy9l7hruX8IpiDnjsLavoBgqCCR71TqWO8MaXYheJ3RQ==} engines: {node: '>=10'} dependencies: escape-string-regexp: 2.0.0 dev: true - /stackback@0.0.2: + /stackback/0.0.2: resolution: {integrity: sha512-1XMJE5fQo1jGH6Y/7ebnwPOBEkIEnT4QF32d5R1+VXdXveM0IBMJt8zfaxX1P3QhVwrYe+576+jkANtSS2mBbw==} dev: false - /stackframe@1.3.4: + /stackframe/1.3.4: resolution: {integrity: sha512-oeVtt7eWQS+Na6F//S4kJ2K2VbRlS9D43mAlMyVpVWovy9o+jfgH8O9agzANzaiLjclA0oYzUXEM4PurhSUChw==} dev: true - /state-toggle@1.0.3: + /state-toggle/1.0.3: resolution: {integrity: sha512-d/5Z4/2iiCnHw6Xzghyhb+GcmF89bxwgXG60wjIiZaxnymbyOmI8Hk4VqHXiVVp6u2ysaskFfXg3ekCj4WNftQ==} dev: true - /static-extend@0.1.2: + /static-extend/0.1.2: resolution: {integrity: sha512-72E9+uLc27Mt718pMHt9VMNiAL4LMsmDbBva8mxWUCkT07fSzEGMYUCk0XWY6lp0j6RBAG4cJ3mWuZv2OE3s0g==} engines: {node: '>=0.10.0'} dependencies: @@ -22821,83 +19901,82 @@ packages: object-copy: 0.1.0 dev: true - /statuses@2.0.1: + /statuses/2.0.1: resolution: {integrity: sha512-RwNA9Z/7PrK06rYLIzFMlaF+l73iwpzsqRIFgbMLbTcLD6cOao82TaWefPXQvB2fOC4AjuYSEndS7N/mTCbkdQ==} engines: {node: '>= 0.8'} dev: true - /std-env@3.3.3: + /std-env/3.3.3: resolution: {integrity: sha512-Rz6yejtVyWnVjC1RFvNmYL10kgjC49EOghxWn0RFqlCHGFpQx+Xe7yW3I4ceK1SGrWIGMjD5Kbue8W/udkbMJg==} dev: false - /stop-iteration-iterator@1.0.0: + /stop-iteration-iterator/1.0.0: resolution: {integrity: sha512-iCGQj+0l0HOdZ2AEeBADlsRC+vsnDsZsbdSiH1yNSjcfKM7fdpCMfqAL/dwF5BLiw/XhRft/Wax6zQbhq2BcjQ==} engines: {node: '>= 0.4'} dependencies: internal-slot: 1.0.5 dev: true - /store2@2.14.2: + /store2/2.14.2: resolution: {integrity: sha512-siT1RiqlfQnGqgT/YzXVUNsom9S0H1OX+dpdGN1xkyYATo4I6sep5NmsRD/40s3IIOvlCq6akxkqG82urIZW1w==} dev: true - /stream-browserify@2.0.2: + /stream-browserify/2.0.2: resolution: {integrity: sha512-nX6hmklHs/gr2FuxYDltq8fJA1GDlxKQCz8O/IM4atRqBH8OORmBNgfvW5gG10GT/qQ9u0CzIvr2X5Pkt6ntqg==} dependencies: inherits: 2.0.4 - readable-stream: 2.3.7 + readable-stream: 2.3.8 dev: true - /stream-each@1.2.3: + /stream-each/1.2.3: resolution: {integrity: sha512-vlMC2f8I2u/bZGqkdfLQW/13Zihpej/7PmSiMQsbYddxuTsJp8vRe2x2FvVExZg7FaOds43ROAuFJwPR4MTZLw==} dependencies: end-of-stream: 1.4.4 stream-shift: 1.0.1 dev: true - /stream-http@2.8.3: + /stream-http/2.8.3: resolution: {integrity: sha512-+TSkfINHDo4J+ZobQLWiMouQYB+UVYFttRA94FpEzzJ7ZdqcL4uUUQ7WkdkI4DSozGmgBUE/a47L+38PenXhUw==} dependencies: builtin-status-codes: 3.0.0 inherits: 2.0.4 - readable-stream: 2.3.7 + readable-stream: 2.3.8 to-arraybuffer: 1.0.1 xtend: 4.0.2 dev: true - /stream-shift@1.0.1: + /stream-shift/1.0.1: resolution: {integrity: sha512-AiisoFqQ0vbGcZgQPY1cdP2I76glaVA/RauYR4G4thNFgkTqr90yXTo4LYX60Jl+sIlPNHHdGSwo01AvbKUSVQ==} dev: true - /streamsearch@1.1.0: + /streamsearch/1.1.0: resolution: {integrity: sha512-Mcc5wHehp9aXz1ax6bZUyY5afg9u2rv5cqQI3mRrYkGC8rW2hM02jWuwjtL++LS5qinSyhj2QfLyNsuc+VsExg==} engines: {node: '>=10.0.0'} dev: true - /strict-event-emitter@0.2.8: + /streamx/2.15.0: + resolution: {integrity: sha512-HcxY6ncGjjklGs1xsP1aR71INYcsXFJet5CU1CHqihQ2J5nOsbd4OjgjHO42w/4QNv9gZb3BueV+Vxok5pLEXg==} + dependencies: + fast-fifo: 1.3.0 + queue-tick: 1.0.1 + dev: true + + /strict-event-emitter/0.2.8: resolution: {integrity: sha512-KDf/ujU8Zud3YaLtMCcTI4xkZlZVIYxTLr+XIULexP+77EEVWixeXroLUXQXiVtH4XH2W7jr/3PT1v3zBuvc3A==} dependencies: events: 3.3.0 dev: true - /strict-event-emitter@0.4.6: + /strict-event-emitter/0.4.6: resolution: {integrity: sha512-12KWeb+wixJohmnwNFerbyiBrAlq5qJLwIt38etRtKtmmHyDSoGlIqFE9wx+4IwG0aDjI7GV8tc8ZccjWZZtTg==} dev: true - /string-argv@0.3.1: - resolution: {integrity: sha512-a1uQGz7IyVy9YwhqjZIZu1c8JO8dNIe20xBmSS6qu9kv++k3JGzCVmprbNN5Kn+BgzD5E7YYwg1CcjuJMRNsvg==} + /string-argv/0.3.2: + resolution: {integrity: sha512-aqD2Q0144Z+/RqG52NeHEkZauTAUWJO8c6yTftGJKO3Tja5tUgIfmIl6kExvhtxSDP7fXB6DvzkfMpCd/F3G+Q==} engines: {node: '>=0.6.19'} dev: true - /string-length@4.0.2: - resolution: {integrity: sha512-+l6rNN5fYHNhZZy41RXsYptCjA2Igmq4EG7kZAYFQI1E1VTXarr6ZPXBg6eq7Y6eK4FEhY6AJlyuFIb/v/S0VQ==} - engines: {node: '>=10'} - dependencies: - char-regex: 1.0.2 - strip-ansi: 6.0.1 - dev: true - - /string-width@4.2.3: + /string-width/4.2.3: resolution: {integrity: sha512-wKyQRQpjJ0sIp62ErSZdGsjMJWsap5oRNihHhu6G7JVO/9jIB6UyevL+tXuOqrng8j/cxKTWyWUwvSTriiZz/g==} engines: {node: '>=8'} dependencies: @@ -22906,7 +19985,7 @@ packages: strip-ansi: 6.0.1 dev: true - /string-width@5.1.2: + /string-width/5.1.2: resolution: {integrity: sha512-HnLOCR3vjcY8beoNLtcjZ5/nxn2afmME6lhrDrebokqMap+XbeW8n9TXpPDOqdGK5qcI3oT0GKTW6wC7EMiVqA==} engines: {node: '>=12'} dependencies: @@ -22915,75 +19994,75 @@ packages: strip-ansi: 7.1.0 dev: true - /string.prototype.matchall@4.0.7: - resolution: {integrity: sha512-f48okCX7JiwVi1NXCVWcFnZgADDC/n2vePlQ/KUCNqCikLLilQvwjMO8+BHVKvgzH0JB0J9LEPgxOGT02RoETg==} + /string.prototype.matchall/4.0.8: + resolution: {integrity: sha512-6zOCOcJ+RJAQshcTvXPHoxoQGONa3e/Lqx90wUA+wEzX78sg5Bo+1tQo4N0pohS0erG9qtCqJDjNCQBjeWVxyg==} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.20.4 - get-intrinsic: 1.2.0 + es-abstract: 1.21.2 + get-intrinsic: 1.2.1 has-symbols: 1.0.3 internal-slot: 1.0.5 regexp.prototype.flags: 1.5.0 side-channel: 1.0.4 dev: true - /string.prototype.padend@3.1.3: - resolution: {integrity: sha512-jNIIeokznm8SD/TZISQsZKYu7RJyheFNt84DUPrh482GC8RVp2MKqm2O5oBRdGxbDQoXrhhWtPIWQOiy20svUg==} + /string.prototype.padend/3.1.4: + resolution: {integrity: sha512-67otBXoksdjsnXXRUq+KMVTdlVRZ2af422Y0aTyTjVaoQkGr3mxl2Bc5emi7dOQ3OGVVQQskmLEWwFXwommpNw==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.20.4 + es-abstract: 1.21.2 dev: true - /string.prototype.padstart@3.1.3: - resolution: {integrity: sha512-NZydyOMtYxpTjGqp0VN5PYUF/tsU15yDMZnUdj16qRUIUiMJkHHSDElYyQFrMu+/WloTpA7MQSiADhBicDfaoA==} + /string.prototype.padstart/3.1.4: + resolution: {integrity: sha512-XqOHj8horGsF+zwxraBvMTkBFM28sS/jHBJajh17JtJKA92qazidiQbLosV4UA18azvLOVKYo/E3g3T9Y5826w==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.20.4 + es-abstract: 1.21.2 dev: true - /string.prototype.trim@1.2.6: - resolution: {integrity: sha512-8lMR2m+U0VJTPp6JjvJTtGyc4FIGq9CdRt7O9p6T0e6K4vjU+OP+SQJpbe/SBmRcCUIvNUnjsbmY6lnMp8MhsQ==} + /string.prototype.trim/1.2.7: + resolution: {integrity: sha512-p6TmeT1T3411M8Cgg9wBTMRtY2q9+PNy9EV1i2lIXUN/btt763oIfxwN3RR8VU6wHX8j/1CFy0L+YuThm6bgOg==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.20.4 + es-abstract: 1.21.2 dev: true - /string.prototype.trimend@1.0.5: - resolution: {integrity: sha512-I7RGvmjV4pJ7O3kdf+LXFpVfdNOxtCW/2C8f6jNiW4+PQchwxkCDzlk1/7p+Wl4bqFIZeF47qAHXLuHHWKAxog==} + /string.prototype.trimend/1.0.6: + resolution: {integrity: sha512-JySq+4mrPf9EsDBEDYMOb/lM7XQLulwg5R/m1r0PXEFqrV0qHvl58sdTilSXtKOflCsK2E8jxf+GKC0T07RWwQ==} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.20.4 + es-abstract: 1.21.2 dev: true - /string.prototype.trimstart@1.0.5: - resolution: {integrity: sha512-THx16TJCGlsN0o6dl2o6ncWUsdgnLRSA23rRE5pyGBw/mLr3Ej/R2LaqCtgP8VNMGZsvMWnf9ooZPyY2bHvUFg==} + /string.prototype.trimstart/1.0.6: + resolution: {integrity: sha512-omqjMDaY92pbn5HOX7f9IccLA+U1tA9GvtU4JrodiXFfYB7jPzzHpRzpglLAjtUV6bB557zwClJezTqnAiYnQA==} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.20.4 + es-abstract: 1.21.2 dev: true - /string_decoder@1.1.1: + /string_decoder/1.1.1: resolution: {integrity: sha512-n/ShnvDi6FHbbVfviro+WojiFzv+s8MPMHBczVePfUpDJLwoLT0ht1l4YwBCbi8pJAveEEdnkHyPyTP/mzRfwg==} dependencies: safe-buffer: 5.1.2 dev: true - /string_decoder@1.3.0: + /string_decoder/1.3.0: resolution: {integrity: sha512-hkRX8U1WjJFd8LsDJ2yQ/wWWxaopEsABU1XfkM8A+j0+85JAGppt16cr1Whg6KIbb4okU6Mql6BOj+uup/wKeA==} dependencies: safe-buffer: 5.2.1 dev: true - /stringify-object@3.3.0: + /stringify-object/3.3.0: resolution: {integrity: sha512-rHqiFh1elqCQ9WPLIC8I0Q/g/wj5J1eMkyoiD6eoQApWHP0FtlK7rqnhmabL5VUY9JQCcqwwvlOaSuutekgyrw==} engines: {node: '>=4'} dependencies: @@ -22992,35 +20071,28 @@ packages: is-regexp: 1.0.0 dev: true - /strip-ansi@3.0.1: + /strip-ansi/3.0.1: resolution: {integrity: sha512-VhumSSbBqDTP8p2ZLKj40UjBCV4+v8bUSEpUb4KjRgWk9pbqGF4REFj6KEagidb2f/M6AzC0EmFyDNGaw9OCzg==} engines: {node: '>=0.10.0'} dependencies: ansi-regex: 2.1.1 dev: true - /strip-ansi@6.0.1: + /strip-ansi/6.0.1: resolution: {integrity: sha512-Y38VPSHcqkFrCpFnQ9vuSXmquuv5oXOKpGeT6aGrr3o3Gc9AlVa6JBfUSOCnbxGGZF+/0ooI7KrPuUSztUdU5A==} engines: {node: '>=8'} dependencies: ansi-regex: 5.0.1 dev: true - /strip-ansi@7.0.1: - resolution: {integrity: sha512-cXNxvT8dFNRVfhVME3JAe98mkXDYN2O1l7jmcwMnOslDeESg1rF/OZMtK0nRAhiari1unG5cD4jG3rapUAkLbw==} - engines: {node: '>=12'} - dependencies: - ansi-regex: 6.0.1 - dev: true - - /strip-ansi@7.1.0: + /strip-ansi/7.1.0: resolution: {integrity: sha512-iq6eVVI64nQQTRYq2KtEg2d2uU7LElhTJwsH4YzIHZshxlgZms/wIc4VoDQTlG/IvVIrBKG06CrZnp0qv7hkcQ==} engines: {node: '>=12'} dependencies: ansi-regex: 6.0.1 dev: true - /strip-bom@2.0.0: + /strip-bom/2.0.0: resolution: {integrity: sha512-kwrX1y7czp1E69n2ajbG65mIo9dqvJ+8aBQXOGVxqwvNbsXdFM6Lq37dLAY3mknUwru8CfcCbfOLL/gMo+fi3g==} engines: {node: '>=0.10.0'} dependencies: @@ -23028,37 +20100,32 @@ packages: dev: true optional: true - /strip-bom@3.0.0: + /strip-bom/3.0.0: resolution: {integrity: sha512-vavAMRXOgBVNF6nyEEmL3DBK19iRpDcoIwW+swQ+CbGiu7lju6t+JklA1MHweoWtadgt4ISVUsXLyDq34ddcwA==} engines: {node: '>=4'} dev: true - /strip-bom@4.0.0: - resolution: {integrity: sha512-3xurFv5tEgii33Zi8Jtp55wEIILR9eh34FAW00PZf+JnSsTmV/ioewSgQl97JHvgjoRGwPShsWm+IdrxB35d0w==} - engines: {node: '>=8'} - dev: true - - /strip-comments@2.0.1: + /strip-comments/2.0.1: resolution: {integrity: sha512-ZprKx+bBLXv067WTCALv8SSz5l2+XhpYCsVtSqlMnkAXMWDq+/ekVbl1ghqP9rUHTzv6sm/DwCOiYutU/yp1fw==} engines: {node: '>=10'} dev: true - /strip-eof@1.0.0: + /strip-eof/1.0.0: resolution: {integrity: sha512-7FCwGGmx8mD5xQd3RPUvnSpUXHM3BWuzjtpD4TXsfcZ9EL4azvVVUscFYwD9nx8Kh+uCBC00XBtAykoMHwTh8Q==} engines: {node: '>=0.10.0'} dev: true - /strip-final-newline@2.0.0: + /strip-final-newline/2.0.0: resolution: {integrity: sha512-BrpvfNAE3dcvq7ll3xVumzjKjZQ5tI1sEUIKr3Uoks0XUl45St3FlatVqef9prk4jRDzhW6WZg+3bk93y6pLjA==} engines: {node: '>=6'} dev: true - /strip-final-newline@3.0.0: + /strip-final-newline/3.0.0: resolution: {integrity: sha512-dOESqjYr96iWYylGObzd39EuNTa5VJxyvVAEm5Jnh7KGo75V43Hk1odPQkNDyXNmUR6k+gEiDVXnjB8HJ3crXw==} engines: {node: '>=12'} dev: true - /strip-indent@1.0.1: + /strip-indent/1.0.1: resolution: {integrity: sha512-I5iQq6aFMM62fBEAIB/hXzwJD6EEZ0xEGCX2t7oXqaKPIRgt4WruAQ285BISgdkP+HLGWyeGmNJcpIwFeRYRUA==} engines: {node: '>=0.10.0'} hasBin: true @@ -23067,46 +20134,53 @@ packages: dev: true optional: true - /strip-indent@3.0.0: + /strip-indent/3.0.0: resolution: {integrity: sha512-laJTa3Jb+VQpaC6DseHhF7dXVqHTfJPCRDaEbid/drOhgitgYku/letMUqOXFoWV0zIIUbjpdH2t+tYj4bQMRQ==} engines: {node: '>=8'} dependencies: min-indent: 1.0.1 dev: true - /strip-json-comments@2.0.1: + /strip-indent/4.0.0: + resolution: {integrity: sha512-mnVSV2l+Zv6BLpSD/8V87CW/y9EmmbYzGCIavsnsI6/nwn26DwffM/yztm30Z/I2DY9wdS3vXVCMnHDgZaVNoA==} + engines: {node: '>=12'} + dependencies: + min-indent: 1.0.1 + dev: true + + /strip-json-comments/2.0.1: resolution: {integrity: sha512-4gB8na07fecVVkOI6Rs4e7T6NOTki5EmL7TUduTs6bu3EdnSycntVJ4re8kgZA+wx9IueI2Y11bfbgwtzuE0KQ==} engines: {node: '>=0.10.0'} dev: true - /strip-json-comments@3.1.1: + /strip-json-comments/3.1.1: resolution: {integrity: sha512-6fPc+R4ihwqP6N/aIv2f1gMH8lOVtWQHoqC4yK6oSDVVocumAsfCqjkXnqiYMhmMwS/mEHLp7Vehlt3ql6lEig==} engines: {node: '>=8'} dev: true - /strip-literal@1.0.1: + /strip-literal/1.0.1: resolution: {integrity: sha512-QZTsipNpa2Ppr6v1AmJHESqJ3Uz247MUS0OjrnnZjFAvEoWqxuyFuXn2xLgMtRnijJShAa1HL0gtJyUs7u7n3Q==} dependencies: - acorn: 8.9.0 + acorn: 8.10.0 - /style-loader@1.3.0(webpack@4.46.0): + /style-loader/1.3.0_webpack@4.46.0: resolution: {integrity: sha512-V7TCORko8rs9rIqkSrlMfkqA63DfoGBBJmK1kKGCcSi+BWb4cqz0SRsnp4l6rU5iwOEd0/2ePv68SV22VXon4Q==} engines: {node: '>= 8.9.0'} peerDependencies: webpack: ^4.0.0 || ^5.0.0 dependencies: - loader-utils: 2.0.2 + loader-utils: 2.0.4 schema-utils: 2.7.1 webpack: 4.46.0 dev: true - /style-to-object@0.3.0: + /style-to-object/0.3.0: resolution: {integrity: sha512-CzFnRRXhzWIdItT3OmF8SQfWyahHhjq3HwcMNCNLn+N7klOOqPjMeG/4JSu77D7ypZdGvSzvkrbyeTMizz2VrA==} dependencies: inline-style-parser: 0.1.1 dev: true - /styled-jsx@5.0.1(@babel/core@7.22.5)(react@18.0.0): + /styled-jsx/5.0.1_react@18.0.0: resolution: {integrity: sha512-+PIZ/6Uk40mphiQJJI1202b+/dYeTVd9ZnMPR80pgiWbjIwvN2zIp4r9et0BgqBuShh48I0gttPlAXA7WVvBxw==} engines: {node: '>= 12.0.0'} peerDependencies: @@ -23119,93 +20193,85 @@ packages: babel-plugin-macros: optional: true dependencies: - '@babel/core': 7.22.5 react: 18.0.0 dev: false - /stylis@4.0.13: - resolution: {integrity: sha512-xGPXiFVl4YED9Jh7Euv2V220mriG9u4B2TA6Ybjc1catrstKD2PpIdU3U0RKpkVBC2EhmL/F0sPCr9vrFTNRag==} + /stylis/4.2.0: + resolution: {integrity: sha512-Orov6g6BB1sDfYgzWfTHDOxamtX1bE/zo104Dh9e6fqJ3PooipYyfJ0pUmrZO2wAvO8YbEyeFrkV91XTsGMSrw==} dev: false - /sucrase@3.28.0: - resolution: {integrity: sha512-TK9600YInjuiIhVM3729rH4ZKPOsGeyXUwY+Ugu9eilNbdTFyHr6XcAGYbRVZPDgWj6tgI7bx95aaJjHnbffag==} + /sucrase/3.32.0: + resolution: {integrity: sha512-ydQOU34rpSyj2TGyz4D2p8rbktIOZ8QY9s+DGLvFU1i5pWJE8vkpruCjGCMHsdXwnD7JDcS+noSwM/a7zyNFDQ==} engines: {node: '>=8'} hasBin: true dependencies: + '@jridgewell/gen-mapping': 0.3.3 commander: 4.1.1 glob: 7.1.6 lines-and-columns: 1.2.4 mz: 2.7.0 - pirates: 4.0.5 + pirates: 4.0.6 ts-interface-checker: 0.1.13 dev: true - /superagent@8.0.0: - resolution: {integrity: sha512-iudipXEel+SzlP9y29UBWGDjB+Zzag+eeA1iLosaR2YHBRr1Q1kC29iBrF2zIVD9fqVbpZnXkN/VJmwFMVyNWg==} + /superagent/8.0.9: + resolution: {integrity: sha512-4C7Bh5pyHTvU33KpZgwrNKh/VQnvgtCSqPRfJAUdmrtSYePVzVg4E4OzsrbkhJj9O7SO6Bnv75K/F8XVZT8YHA==} engines: {node: '>=6.4.0 <13 || >=14'} dependencies: component-emitter: 1.3.0 - cookiejar: 2.1.3 - debug: 4.3.4(supports-color@8.1.1) + cookiejar: 2.1.4 + debug: 4.3.4 fast-safe-stringify: 2.1.1 form-data: 4.0.0 - formidable: 2.0.1 + formidable: 2.1.2 methods: 1.1.2 mime: 2.6.0 - qs: 6.11.0 - readable-stream: 3.6.0 - semver: 7.5.2 + qs: 6.11.2 + semver: 7.5.4 transitivePeerDependencies: - supports-color dev: true - /supertest@6.2.4: + /supertest/6.2.4: resolution: {integrity: sha512-M8xVnCNv+q2T2WXVzxDECvL2695Uv2uUj2O0utxsld/HRyJvOU8W9f1gvsYxSNU4wmIe0/L/ItnpU4iKq0emDA==} engines: {node: '>=6.4.0'} dependencies: methods: 1.1.2 - superagent: 8.0.0 + superagent: 8.0.9 transitivePeerDependencies: - supports-color dev: true - /supports-color@2.0.0: + /supports-color/2.0.0: resolution: {integrity: sha512-KKNVtd6pCYgPIKU4cp2733HWYCpplQhddZLBUryaAHou723x+FRzQ5Df824Fj+IyyuiQTRoub4SnIFfIcrp70g==} engines: {node: '>=0.8.0'} dev: true - /supports-color@5.5.0: + /supports-color/5.5.0: resolution: {integrity: sha512-QjVjwdXIt408MIiAqCX4oUKsgU2EqAGzs2Ppkm4aQYbjm+ZEWEcW4SfFNTr4uMNZma0ey4f5lgLrkB0aX0QMow==} engines: {node: '>=4'} dependencies: has-flag: 3.0.0 - /supports-color@7.2.0: + /supports-color/7.2.0: resolution: {integrity: sha512-qpCAvRl9stuOHveKsn7HncJRvv501qIacKzQlO/+Lwxc9+0q2wLyv4Dfvt80/DPn2pqOBsJdDiogXGR9+OvwRw==} engines: {node: '>=8'} dependencies: has-flag: 4.0.0 - /supports-color@8.1.1: + /supports-color/8.1.1: resolution: {integrity: sha512-MpUEN2OodtUzxvKQl72cUF7RQ5EiHsGvSsVG0ia9c5RbWGL2CI4C7EpPS8UTBIplnlzZiNuV56w+FuNxy3ty2Q==} engines: {node: '>=10'} dependencies: has-flag: 4.0.0 - - /supports-hyperlinks@2.3.0: - resolution: {integrity: sha512-RpsAZlpWcDwOPQA22aCH4J0t7L8JmAvsCxfOSEwm7cQs3LshN36QaTkwd70DnBOXDWGssw2eUoc8CaRWT0XunA==} - engines: {node: '>=8'} - dependencies: - has-flag: 4.0.0 - supports-color: 7.2.0 dev: true - /supports-preserve-symlinks-flag@1.0.0: + /supports-preserve-symlinks-flag/1.0.0: resolution: {integrity: sha512-ot0WnXS9fgdkgIcePe6RHNk1WA8+muPa6cSjeR3V8K27q9BB1rTE3R1p7Hv0z1ZyAc8s6Vvv8DIyWf681MAt0w==} engines: {node: '>= 0.4'} - /svelte-check@3.4.3(svelte@3.59.1): - resolution: {integrity: sha512-O07soQFY3X0VDt+bcGc6D5naz0cLtjwnmNP9JsEBPVyMemFEqUhL2OdLqvkl5H/u8Jwm50EiAU4BPRn5iin/kg==} + /svelte-check/3.4.6_svelte@3.59.2: + resolution: {integrity: sha512-OBlY8866Zh1zHQTkBMPS6psPi7o2umTUyj6JWm4SacnIHXpWFm658pG32m3dKvKFL49V4ntAkfFHKo4ztH07og==} hasBin: true peerDependencies: svelte: ^3.55.0 || ^4.0.0-next.0 || ^4.0.0 @@ -23216,9 +20282,9 @@ packages: import-fresh: 3.3.0 picocolors: 1.0.0 sade: 1.8.1 - svelte: 3.59.1 - svelte-preprocess: 5.0.4(svelte@3.59.1)(typescript@5.1.3) - typescript: 5.1.3 + svelte: 3.59.2 + svelte-preprocess: 5.0.4_vskbpfd7qchoojf5wqdzq623ya + typescript: 5.1.6 transitivePeerDependencies: - '@babel/core' - coffeescript @@ -23231,16 +20297,16 @@ packages: - sugarss dev: true - /svelte-hmr@0.15.2(svelte@3.59.1): + /svelte-hmr/0.15.2_svelte@3.59.2: resolution: {integrity: sha512-q/bAruCvFLwvNbeE1x3n37TYFb3mTBJ6TrCq6p2CoFbSTNhDE9oAtEfpy+wmc9So8AG0Tja+X0/mJzX9tSfvIg==} engines: {node: ^12.20 || ^14.13.1 || >= 16} peerDependencies: svelte: ^3.19.0 || ^4.0.0-next.0 dependencies: - svelte: 3.59.1 + svelte: 3.59.2 dev: true - /svelte-hmr@0.15.2(svelte@4.0.5): + /svelte-hmr/0.15.2_svelte@4.0.5: resolution: {integrity: sha512-q/bAruCvFLwvNbeE1x3n37TYFb3mTBJ6TrCq6p2CoFbSTNhDE9oAtEfpy+wmc9So8AG0Tja+X0/mJzX9tSfvIg==} engines: {node: ^12.20 || ^14.13.1 || >= 16} peerDependencies: @@ -23249,7 +20315,7 @@ packages: svelte: 4.0.5 dev: true - /svelte-preprocess@5.0.4(svelte@3.59.1)(typescript@5.1.3): + /svelte-preprocess/5.0.4_vskbpfd7qchoojf5wqdzq623ya: resolution: {integrity: sha512-ABia2QegosxOGsVlsSBJvoWeXy1wUKSfF7SWJdTjLAbx/Y3SrVevvvbFNQqrSJw89+lNSsM58SipmZJ5SRi5iw==} engines: {node: '>= 14.10.0'} requiresBuild: true @@ -23292,23 +20358,23 @@ packages: magic-string: 0.27.0 sorcery: 0.11.0 strip-indent: 3.0.0 - svelte: 3.59.1 - typescript: 5.1.3 + svelte: 3.59.2 + typescript: 5.1.6 dev: true - /svelte@3.59.1: - resolution: {integrity: sha512-pKj8fEBmqf6mq3/NfrB9SLtcJcUvjYSWyePlfCqN9gujLB25RitWK8PvFzlwim6hD/We35KbPlRteuA6rnPGcQ==} + /svelte/3.59.2: + resolution: {integrity: sha512-vzSyuGr3eEoAtT/A6bmajosJZIUWySzY2CzB3w2pgPvnkUjGqlDnsNnA0PMO+mMAhuyMul6C2uuZzY6ELSkzyA==} engines: {node: '>= 8'} dev: true - /svelte@4.0.5: + /svelte/4.0.5: resolution: {integrity: sha512-PHKPWP1wiWHBtsE57nCb8xiWB3Ht7/3Kvi3jac0XIxUM2rep8alO7YoAtgWeGD7++tFy46krilOrPW0mG3Dx+A==} engines: {node: '>=16'} dependencies: '@ampproject/remapping': 2.2.1 '@jridgewell/sourcemap-codec': 1.4.15 '@jridgewell/trace-mapping': 0.3.18 - acorn: 8.9.0 + acorn: 8.10.0 aria-query: 5.3.0 axobject-query: 3.2.1 code-red: 1.0.3 @@ -23320,7 +20386,7 @@ packages: periscopic: 3.1.0 dev: true - /sveltedoc-parser@4.2.1: + /sveltedoc-parser/4.2.1: resolution: {integrity: sha512-sWJRa4qOfRdSORSVw9GhfDEwsbsYsegnDzBevUCF6k/Eis/QqCu9lJ6I0+d/E2wOWCjOhlcJ3+jl/Iur+5mmCw==} engines: {node: '>=10.0.0'} dependencies: @@ -23331,15 +20397,15 @@ packages: - supports-color dev: true - /svg-tags@1.0.0: + /svg-tags/1.0.0: resolution: {integrity: sha512-ovssysQTa+luh7A5Weu3Rta6FJlFBBbInjOh722LIt6klpU2/HtdUbszju/G4devcvk8PGt7FCLv5wftu3THUA==} dev: true - /sweetalert2@11.6.16: - resolution: {integrity: sha512-T2FO8LptErsjE4r0WMfiSk4YbeUvPadNaUZ/cADMEOnws000znrf8zFX9S5e/spvzJDyRI5En73WQyDZhGypxQ==} + /sweetalert2/11.7.16: + resolution: {integrity: sha512-vxqVcA358RWdK/XOG1gFtOzT7qBH186Ry4gnW0Xtrx7vIo1mpnR8hG8MxQms4gz3JPbYQ6UIgZn0+hTK7in3Jw==} dev: true - /swr@1.3.0(react@18.2.0): + /swr/1.3.0_react@18.2.0: resolution: {integrity: sha512-dkghQrOl2ORX9HYrMDtPa7LTVHJjCTeZoB1dqTbnnEDlSvN8JEKpYIYurDfvbQFUUS8Cg8PceFVZNkW0KNNYPw==} peerDependencies: react: ^16.11.0 || ^17.0.0 || ^18.0.0 @@ -23347,44 +20413,44 @@ packages: react: 18.2.0 dev: false - /symbol-observable@4.0.0: + /symbol-observable/4.0.0: resolution: {integrity: sha512-b19dMThMV4HVFynSAM1++gBHAbk2Tc/osgLIBZMKsyqh34jb2e8Os7T6ZW/Bt3pJFdBTd2JwAnAAEQV7rSNvcQ==} engines: {node: '>=0.10'} dev: false - /symbol-tree@3.2.4: + /symbol-tree/3.2.4: resolution: {integrity: sha512-9QNk5KwDF+Bvz+PyObkmSYjI5ksVUYtjW7AU22r2NKcfLJcXp96hkDWU3+XndOsUb+AQ9QhfzfCT2O+CNWT5Tw==} dev: true - /symbol.prototype.description@1.0.5: + /symbol.prototype.description/1.0.5: resolution: {integrity: sha512-x738iXRYsrAt9WBhRCVG5BtIC3B7CUkFwbHW2zOvGtwM33s7JjrCDyq8V0zgMYVb5ymsL8+qkzzpANH63CPQaQ==} engines: {node: '>= 0.11.15'} dependencies: call-bind: 1.0.2 get-symbol-description: 1.0.0 has-symbols: 1.0.3 - object.getownpropertydescriptors: 2.1.4 + object.getownpropertydescriptors: 2.1.6 dev: true - /synchronous-promise@2.0.16: - resolution: {integrity: sha512-qImOD23aDfnIDNqlG1NOehdB9IYsn1V9oByPjKY1nakv2MQYCEMyX033/q+aEtYCpmYK1cv2+NTmlH+ra6GA5A==} + /synchronous-promise/2.0.17: + resolution: {integrity: sha512-AsS729u2RHUfEra9xJrE39peJcc2stq2+poBXX8bcM08Y6g9j/i/PUzwNQqkaJde7Ntg1TO7bSREbR5sdosQ+g==} dev: true - /tabbable@6.1.2: - resolution: {integrity: sha512-qCN98uP7i9z0fIS4amQ5zbGBOq+OSigYeGvPy7NDk8Y9yncqDZ9pRPgfsc2PJIVM9RrJj7GIfuRgmjoUU9zTHQ==} + /tabbable/6.2.0: + resolution: {integrity: sha512-Cat63mxsVJlzYvN51JmVXIgNoUokrIaT2zLclCXjRd8boZ0004U4KCs/sToJ75C6sdlByWxpYnb5Boif1VSFew==} dev: true - /tapable@1.1.3: + /tapable/1.1.3: resolution: {integrity: sha512-4WK/bYZmj8xLr+HUCODHGF1ZFzsYffasLUgEiMBY4fgtltdO6B4WJtlSbPaDTLpYTcGVwM2qLnFTICEcNxs3kA==} engines: {node: '>=6'} dev: true - /tapable@2.2.1: + /tapable/2.2.1: resolution: {integrity: sha512-GNzQvQTOIP6RyTfE2Qxb8ZVlNmw0n88vp1szwWRimP02mnTsx3Wtn5qRdqY9w2XduFNUgvOwhNnQsjwCp+kqaQ==} engines: {node: '>=6'} dev: true - /tar-fs@2.1.1: + /tar-fs/2.1.1: resolution: {integrity: sha512-V0r2Y9scmbDRLCNex/+hYzvp/zyYjvFbHPNgVTKfQvVrb6guiE/fxP+XblDNR011utopbkex2nM4dHNV6GDsng==} dependencies: chownr: 1.1.4 @@ -23393,7 +20459,15 @@ packages: tar-stream: 2.2.0 dev: true - /tar-stream@2.2.0: + /tar-fs/3.0.4: + resolution: {integrity: sha512-5AFQU8b9qLfZCX9zp2duONhPmZv0hGYiBPJsyUdqMjzq/mqVpy/rEUSeHk1+YitmxugaptgBh5oDGU3VsAJq4w==} + dependencies: + mkdirp-classic: 0.5.3 + pump: 3.0.0 + tar-stream: 3.1.6 + dev: true + + /tar-stream/2.2.0: resolution: {integrity: sha512-ujeqbceABgwMZxEJnk2HDY2DlnUZ+9oEcb1KzTVfYHio0UE6dG71n60d8D2I4qNvleWrrXpmjpt7vZeF1LnMZQ==} engines: {node: '>=6'} dependencies: @@ -23401,22 +20475,30 @@ packages: end-of-stream: 1.4.4 fs-constants: 1.0.0 inherits: 2.0.4 - readable-stream: 3.6.0 + readable-stream: 3.6.2 dev: true - /tar@6.1.13: - resolution: {integrity: sha512-jdIBIN6LTIe2jqzay/2vtYLlBHa3JF42ot3h1dW8Q0PaAG4v8rm0cvpVePtau5C6OKXGGcgO9q2AMNSWxiLqKw==} + /tar-stream/3.1.6: + resolution: {integrity: sha512-B/UyjYwPpMBv+PaFSWAmtYjwdrlEaZQEhMIBFNC5oEG8lpiW8XjcSdmEaClj28ArfKScKHs2nshz3k2le6crsg==} + dependencies: + b4a: 1.6.4 + fast-fifo: 1.3.0 + streamx: 2.15.0 + dev: true + + /tar/6.1.15: + resolution: {integrity: sha512-/zKt9UyngnxIT/EAGYuxaMYgOIJiP81ab9ZfkILq4oNLPFX50qyYmu7jRj9qeXoxmJHjGlbH0+cm2uy1WCs10A==} engines: {node: '>=10'} dependencies: chownr: 2.0.0 fs-minipass: 2.1.0 - minipass: 4.2.5 + minipass: 5.0.0 minizlib: 2.1.2 mkdirp: 1.0.4 yallist: 4.0.0 dev: true - /telejson@6.0.8: + /telejson/6.0.8: resolution: {integrity: sha512-nerNXi+j8NK1QEfBHtZUN/aLdDcyupA//9kAboYLrtzZlPLpUfqbVGWb9zz91f/mIjRbAYhbgtnJHY8I1b5MBg==} dependencies: '@types/is-function': 1.0.1 @@ -23429,12 +20511,18 @@ packages: memoizerific: 1.11.3 dev: true - /temp-dir@2.0.0: + /telejson/7.1.0: + resolution: {integrity: sha512-jFJO4P5gPebZAERPkJsqMAQ0IMA1Hi0AoSfxpnUaV6j6R2SZqlpkbS20U6dEUtA3RUYt2Ak/mTlkQzHH9Rv/hA==} + dependencies: + memoizerific: 1.11.3 + dev: true + + /temp-dir/2.0.0: resolution: {integrity: sha512-aoBAniQmmwtcKp/7BzsH8Cxzv8OL736p7v1ihGb5e9DJ9kTwGWHrQrVB5+lfVDzfGrdRzXch+ig7LHaY1JTOrg==} engines: {node: '>=8'} dev: true - /tempy@0.6.0: + /tempy/0.6.0: resolution: {integrity: sha512-G13vtMYPT/J8A4X2SjdtBTphZlrp1gKv6hZiOjw14RCWg6GbHuQBGtjlx75xLbYV/wEc0D7G5K4rxKP/cXk8Bw==} engines: {node: '>=10'} dependencies: @@ -23444,15 +20532,7 @@ packages: unique-string: 2.0.0 dev: true - /terminal-link@2.1.1: - resolution: {integrity: sha512-un0FmiRUQNr5PJqy9kP7c40F5BOfpGlYTrxonDChEZB7pzZxRNp/bt+ymiy9/npwXya9KH99nJ/GXFIiUkYGFQ==} - engines: {node: '>=8'} - dependencies: - ansi-escapes: 4.3.2 - supports-hyperlinks: 2.3.0 - dev: true - - /terser-webpack-plugin@1.4.5(webpack@4.46.0): + /terser-webpack-plugin/1.4.5_webpack@4.46.0: resolution: {integrity: sha512-04Rfe496lN8EYruwi6oPQkG0vo8C+HT49X687FZnpPF0qMAIHONI6HEXYPKDOE8e5HjXTyKfqRd/agHtH0kOtw==} engines: {node: '>= 6.9.0'} peerDependencies: @@ -23470,7 +20550,7 @@ packages: worker-farm: 1.7.0 dev: true - /terser-webpack-plugin@4.2.3(webpack@4.46.0): + /terser-webpack-plugin/4.2.3_webpack@4.46.0: resolution: {integrity: sha512-jTgXh40RnvOrLQNgIkwEKnQ8rmHjHK4u+6UBEi+W+FPmvb+uo+chJXntKe7/3lW5mNysgSWD60KyesnhW8D6MQ==} engines: {node: '>= 10.13.0'} peerDependencies: @@ -23480,18 +20560,18 @@ packages: find-cache-dir: 3.3.2 jest-worker: 26.6.2 p-limit: 3.1.0 - schema-utils: 3.1.1 + schema-utils: 3.3.0 serialize-javascript: 5.0.1 source-map: 0.6.1 - terser: 5.15.0 + terser: 5.19.0 webpack: 4.46.0 webpack-sources: 1.4.3 transitivePeerDependencies: - bluebird dev: true - /terser-webpack-plugin@5.3.6(esbuild@0.18.11)(webpack@5.74.0): - resolution: {integrity: sha512-kfLFk+PoLUQIbLmB1+PZDMRSZS99Mp+/MHqDNmMA6tOItzRt+Npe3E+fsMs5mfcM0wCtrrdU387UnV+vnSffXQ==} + /terser-webpack-plugin/5.3.9_webpack@5.88.1: + resolution: {integrity: sha512-ZuXsqE07EcggTWQjXUj+Aot/OMcD0bMKGgF63f7UxYcu5/AJF53aIpK1YoP5xR9l6s/Hy2b+t1AM0bLNPRuhwA==} engines: {node: '>= 10.13.0'} peerDependencies: '@swc/core': '*' @@ -23507,37 +20587,36 @@ packages: optional: true dependencies: '@jridgewell/trace-mapping': 0.3.18 - esbuild: 0.18.11 jest-worker: 27.5.1 - schema-utils: 3.1.1 - serialize-javascript: 6.0.0 - terser: 5.15.0 - webpack: 5.74.0(esbuild@0.18.11) + schema-utils: 3.3.0 + serialize-javascript: 6.0.1 + terser: 5.19.0 + webpack: 5.88.1 dev: true - /terser@4.8.1: + /terser/4.8.1: resolution: {integrity: sha512-4GnLC0x667eJG0ewJTa6z/yXrbLGv80D9Ru6HIpCQmO+Q4PfEtBFi0ObSckqwL6VyQv/7ENJieXHo2ANmdQwgw==} engines: {node: '>=6.0.0'} hasBin: true dependencies: - acorn: 8.9.0 + acorn: 8.10.0 commander: 2.20.3 source-map: 0.6.1 source-map-support: 0.5.21 dev: true - /terser@5.15.0: - resolution: {integrity: sha512-L1BJiXVmheAQQy+as0oF3Pwtlo4s3Wi1X2zNZ2NxOB4wx9bdS9Vk67XQENLFdLYGCK/Z2di53mTj/hBafR+dTA==} + /terser/5.19.0: + resolution: {integrity: sha512-JpcpGOQLOXm2jsomozdMDpd5f8ZHh1rR48OFgWUH3QsyZcfPgv2qDCYbcDEAYNd4OZRj2bWYKpwdll/udZCk/Q==} engines: {node: '>=10'} hasBin: true dependencies: - '@jridgewell/source-map': 0.3.2 - acorn: 8.9.0 + '@jridgewell/source-map': 0.3.5 + acorn: 8.10.0 commander: 2.20.3 source-map-support: 0.5.21 dev: true - /test-exclude@6.0.0: + /test-exclude/6.0.0: resolution: {integrity: sha512-cAGWPIyOHU6zlmg88jwm7VRyXnMN7iV68OGAbYDk/Mh/xC/pzVPlQtY6ngoIH/5/tciuhGfvESU8GrHrcxD56w==} engines: {node: '>=8'} dependencies: @@ -23545,129 +20624,118 @@ packages: glob: 7.2.3 minimatch: 3.1.2 - /text-table@0.2.0: + /text-table/0.2.0: resolution: {integrity: sha512-N+8UisAXDGk8PFXP4HAzVR9nbfmVJ3zYLAWiTIoqC5v5isinhr+r5uaO8+7r3BMfuNIufIsA7RdpVgacC2cSpw==} dev: true - /thenify-all@1.6.0: + /thenify-all/1.6.0: resolution: {integrity: sha512-RNxQH/qI8/t3thXJDwcstUO4zeqo64+Uy/+sNVRBx4Xn2OX+OZ9oP+iJnNFqplFra2ZUVeKCSa2oVWi3T4uVmA==} engines: {node: '>=0.8'} dependencies: thenify: 3.3.1 dev: true - /thenify@3.3.1: + /thenify/3.3.1: resolution: {integrity: sha512-RVZSIV5IG10Hk3enotrhvz0T9em6cyHBLkH/YAZuKqd8hRkKhSfCGIcP2KUY0EPxndzANBmNllzWPwak+bheSw==} dependencies: any-promise: 1.3.0 dev: true - /thread-stream@2.1.0: - resolution: {integrity: sha512-5+Pf2Ya31CsZyIPYYkhINzdTZ3guL+jHq7D8lkBybgGcSQIKDbid3NJku3SpCKeE/gACWAccDA/rH2B6doC5aA==} + /thread-stream/2.3.0: + resolution: {integrity: sha512-kaDqm1DET9pp3NXwR8382WHbnpXnRkN9xGN9dQt3B2+dmXiW8X1SOwmFOxAErEQ47ObhZ96J6yhZNXuyCOL7KA==} dependencies: real-require: 0.2.0 dev: true - /throat@6.0.2: - resolution: {integrity: sha512-WKexMoJj3vEuK0yFEapj8y64V0A6xcuPuK9Gt1d0R+dzCSJc0lHqQytAbSB4cDAK0dWh4T0E2ETkoLE2WZ41OQ==} + /throttleit/1.0.0: + resolution: {integrity: sha512-rkTVqu6IjfQ/6+uNuuc3sZek4CEYxTJom3IktzgdSxcZqdARuebbA/f4QmAxMQIxqq9ZLEUkSYqvuk1I6VKq4g==} dev: true - /throttleit@1.0.0: - resolution: {integrity: sha512-rkTVqu6IjfQ/6+uNuuc3sZek4CEYxTJom3IktzgdSxcZqdARuebbA/f4QmAxMQIxqq9ZLEUkSYqvuk1I6VKq4g==} + /through/2.3.8: + resolution: {integrity: sha512-w89qg7PI8wAdvX60bMDP+bFoD5Dvhm9oLheFp5O4a2QF0cSBGsBX4qZmadPMvVqlLJBBci+WqGGOAPvcDeNSVg==} dev: true - /through2@2.0.5: + /through2/2.0.5: resolution: {integrity: sha512-/mrRod8xqpA+IHSLyGCQ2s8SPHiCDEeQJSep1jqLYeEUClOFG2Qsh+4FU6G9VeqpZnGW/Su8LQGc4YKni5rYSQ==} dependencies: - readable-stream: 2.3.7 + readable-stream: 2.3.8 xtend: 4.0.2 dev: true - /through@2.3.8: - resolution: {integrity: sha512-w89qg7PI8wAdvX60bMDP+bFoD5Dvhm9oLheFp5O4a2QF0cSBGsBX4qZmadPMvVqlLJBBci+WqGGOAPvcDeNSVg==} - dev: true - - /timers-browserify@2.0.12: + /timers-browserify/2.0.12: resolution: {integrity: sha512-9phl76Cqm6FhSX9Xe1ZUAMLtm1BLkKj2Qd5ApyWkXzsMRaA7dgr81kf4wJmQf/hAvg8EEyJxDo3du/0KlhPiKQ==} engines: {node: '>=0.6.0'} dependencies: setimmediate: 1.0.5 dev: true - /tiny-glob@0.2.9: - resolution: {integrity: sha512-g/55ssRPUjShh+xkfx9UPDXqhckHEsHr4Vd9zX55oSdGZc/MD0m3sferOkwWtp98bv+kcVfEHtRJgBVJzelrzg==} - dependencies: - globalyzer: 0.1.0 - globrex: 0.1.2 - dev: true - - /tiny-lru@8.0.2: + /tiny-lru/8.0.2: resolution: {integrity: sha512-ApGvZ6vVvTNdsmt676grvCkUCGwzG9IqXma5Z07xJgiC5L7akUMof5U8G2JTI9Rz/ovtVhJBlY6mNhEvtjzOIg==} engines: {node: '>=6'} dev: true - /tinybench@2.5.0: + /tinybench/2.5.0: resolution: {integrity: sha512-kRwSG8Zx4tjF9ZiyH4bhaebu+EDz1BOx9hOigYHlUW4xxI/wKIUQUqo018UlU4ar6ATPBsaMrdbKZ+tmPdohFA==} dev: false - /tinypool@0.7.0: + /tinypool/0.7.0: resolution: {integrity: sha512-zSYNUlYSMhJ6Zdou4cJwo/p7w5nmAH17GRfU/ui3ctvjXFErXXkruT4MWW6poDeXgCaIBlGLrfU6TbTXxyGMww==} engines: {node: '>=14.0.0'} dev: false - /tinyspy@0.3.3: + /tinyspy/0.3.3: resolution: {integrity: sha512-gRiUR8fuhUf0W9lzojPf1N1euJYA30ISebSfgca8z76FOvXtVXqd5ojEIaKLWbDQhAaC3ibxZIjqbyi4ybjcTw==} engines: {node: '>=14.0.0'} dev: false - /tinyspy@1.0.2: - resolution: {integrity: sha512-bSGlgwLBYf7PnUsQ6WOc6SJ3pGOcd+d8AA6EUnLDDM0kWEstC1JIlSZA3UNliDXhd9ABoS7hiRBDCu+XP/sf1Q==} + /tinyspy/1.1.1: + resolution: {integrity: sha512-UVq5AXt/gQlti7oxoIg5oi/9r0WpF7DGEVwXgqWSMmyN16+e3tl5lIvTaOpJ3TAtu5xFzWccFRM4R5NaWHF+4g==} engines: {node: '>=14.0.0'} dev: true - /tinyspy@2.1.1: + /tinyspy/2.1.1: resolution: {integrity: sha512-XPJL2uSzcOyBMky6OFrusqWlzfFrXtE0hPuMgW8A2HmaqrPo4ZQHRN/V0QXN3FSjKxpsbRrFc5LI7KOwBsT1/w==} engines: {node: '>=14.0.0'} dev: false - /tmp@0.0.33: + /tmp/0.0.33: resolution: {integrity: sha512-jRCJlojKnZ3addtTOjdIqoRuPEKBvNXcGYqzO6zWZX8KfKEpnGY5jfggJQ3EjKuu8D4bJRr0y+cYJFmYbImXGw==} engines: {node: '>=0.6.0'} dependencies: os-tmpdir: 1.0.2 dev: true - /tmp@0.2.1: + /tmp/0.2.1: resolution: {integrity: sha512-76SUhtfqR2Ijn+xllcI5P1oyannHNHByD80W1q447gU3mp9G9PSpGdWmjUOHRDPiHYacIk66W7ubDTuPF3BEtQ==} engines: {node: '>=8.17.0'} dependencies: rimraf: 3.0.2 dev: true - /tmpl@1.0.5: + /tmpl/1.0.5: resolution: {integrity: sha512-3f0uOEAQwIqGuWW2MVzYg8fV/QNnc/IpuJNG837rLuczAaLVHslWHZQj4IGiEl5Hs3kkbhwL9Ab7Hrsmuj+Smw==} dev: true - /to-arraybuffer@1.0.1: + /to-arraybuffer/1.0.1: resolution: {integrity: sha512-okFlQcoGTi4LQBG/PgSYblw9VOyptsz2KJZqc6qtgGdes8VktzUQkj4BI2blit072iS8VODNcMA+tvnS9dnuMA==} dev: true - /to-data-view@1.1.0: + /to-data-view/1.1.0: resolution: {integrity: sha512-1eAdufMg6mwgmlojAx3QeMnzB/BTVp7Tbndi3U7ftcT2zCZadjxkkmLmd97zmaxWi+sgGcgWrokmpEoy0Dn0vQ==} dev: true - /to-fast-properties@2.0.0: + /to-fast-properties/2.0.0: resolution: {integrity: sha512-/OaKK0xYrs3DmxRYqL/yDc+FxFUVYhDlXMhRmv3z915w2HF1tnN1omB354j8VUGO/hbRzyD6Y3sA7v7GS/ceog==} engines: {node: '>=4'} - /to-object-path@0.3.0: + /to-object-path/0.3.0: resolution: {integrity: sha512-9mWHdnGRuh3onocaHzukyvCZhzvr6tiflAy/JRFXcJX0TjgfWA9pk9t8CMbzmBE4Jfw58pXbkngtBtqYxzNEyg==} engines: {node: '>=0.10.0'} dependencies: kind-of: 3.2.2 dev: true - /to-regex-range@2.1.1: + /to-regex-range/2.1.1: resolution: {integrity: sha512-ZZWNfCjUokXXDGXFpZehJIkZqq91BcULFq/Pi7M5i4JnxXdhMKAK682z8bCW3o8Hj1wuuzoKcW3DfVzaP6VuNg==} engines: {node: '>=0.10.0'} dependencies: @@ -23675,13 +20743,13 @@ packages: repeat-string: 1.6.1 dev: true - /to-regex-range@5.0.1: + /to-regex-range/5.0.1: resolution: {integrity: sha512-65P7iz6X5yEr1cwcgvQxbbIw7Uk3gOy5dIdtZ4rDveLqhrdJP+Li/Hx6tyK0NEb+2GCyneCMJiGqrADCSNk8sQ==} engines: {node: '>=8.0'} dependencies: is-number: 7.0.0 - /to-regex@3.0.2: + /to-regex/3.0.2: resolution: {integrity: sha512-FWtleNAtZ/Ki2qtqej2CXTOayOH9bHDQF+Q48VpWyDXjbYxA4Yz8iDB31zXOBUlOHHKidDbqGVrTUvQMPmBGBw==} engines: {node: '>=0.10.0'} dependencies: @@ -23691,16 +20759,16 @@ packages: safe-regex: 1.1.0 dev: true - /toidentifier@1.0.1: + /toidentifier/1.0.1: resolution: {integrity: sha512-o5sSPKEkg/DIQNmH43V0/uerLrpzVedkUh8tGNvaeXpfpuwjKenlSox/2O/BTlZUtEe+JG7s5YhEz608PlAHRA==} engines: {node: '>=0.6'} dev: true - /totalist@3.0.0: - resolution: {integrity: sha512-eM+pCBxXO/njtF7vdFsHuqb+ElbxqtI4r5EAvk6grfAFyJ6IvWlSkfZ5T9ozC6xWw3Fj1fGoSmrl0gUs46JVIw==} + /totalist/3.0.1: + resolution: {integrity: sha512-sf4i37nQ2LBx4m3wB74y+ubopq6W/dIzXg0FDGjsYnZHVa1Da8FH853wlL2gtUhg+xJXjfk3kUZS3BRoQeoQBQ==} engines: {node: '>=6'} - /tough-cookie@2.5.0: + /tough-cookie/2.5.0: resolution: {integrity: sha512-nlLsUzgm1kfLXSXfRZMc1KLAugd4hqJHDTvc2hDIwS3mZAfMEuMbc03SujMF+GEcpaX/qboeycw6iO8JwVv2+g==} engines: {node: '>=0.8'} dependencies: @@ -23708,8 +20776,8 @@ packages: punycode: 2.3.0 dev: true - /tough-cookie@4.1.2: - resolution: {integrity: sha512-G9fqXWoYFZgTc2z8Q5zaHy/vJMjm+WV0AkAeHxVCQiEB1b+dGvWzFW6QV07cY5jQ5gRkeid2qIkzkxUnmoQZUQ==} + /tough-cookie/4.1.3: + resolution: {integrity: sha512-aX/y5pVRkfRnfmuX+OdbSdXvPe6ieKX/G2s7e98f4poJHnqH3281gDPm/metm6E/WRamfx7WC4HUqkWHfQHprw==} engines: {node: '>=6'} dependencies: psl: 1.9.0 @@ -23718,76 +20786,70 @@ packages: url-parse: 1.5.10 dev: true - /tr46@0.0.3: + /tr46/0.0.3: resolution: {integrity: sha512-N3WMsuqV66lT30CrXNbEjx4GEwlow3v6rr4mCcv6prnfwhS01rkgyFdjPNBYd9br7LpXV1+Emh01fHnq2Gdgrw==} - /tr46@1.0.1: + /tr46/1.0.1: resolution: {integrity: sha512-dTpowEjclQ7Kgx5SdBkqRzVhERQXov8/l9Ft9dVM9fmg0W0KQSVaXX9T4i6twCPNtYiZM53lpSSUAwJbFPOHxA==} dependencies: punycode: 2.3.0 dev: true - /tr46@2.1.0: - resolution: {integrity: sha512-15Ih7phfcdP5YxqiB+iDtLoaTz4Nd35+IiAv0kQ5FNKHzXgdWqPoTIqEDDJmXceQt4JZk6lVPT8lnDlPpGDppw==} - engines: {node: '>=8'} - dependencies: - punycode: 2.3.0 - dev: true - - /tr46@3.0.0: + /tr46/3.0.0: resolution: {integrity: sha512-l7FvfAHlcmulp8kr+flpQZmVwtu7nfRV7NZujtN0OqES8EL4O4e0qqzL0DC5gAvx/ZC/9lk6rhcUwYvkBnBnYA==} engines: {node: '>=12'} dependencies: punycode: 2.3.0 dev: true - /tr46@4.1.1: + /tr46/4.1.1: resolution: {integrity: sha512-2lv/66T7e5yNyhAAC4NaKe5nVavzuGJQVVtRYLyQ2OI8tsJ61PMLlelehb0wi2Hx6+hT/OJUWZcw8MjlSRnxvw==} engines: {node: '>=14'} dependencies: punycode: 2.3.0 dev: true - /tree-kill@1.2.2: + /tree-kill/1.2.2: resolution: {integrity: sha512-L0Orpi8qGpRG//Nd+H90vFB+3iHnue1zSSGmNOOCh1GLJ7rUKVwV2HvijphGQS2UmhUZewS9VgvxYIdgr+fG1A==} hasBin: true dev: true - /trim-newlines@1.0.0: + /trim-newlines/1.0.0: resolution: {integrity: sha512-Nm4cF79FhSTzrLKGDMi3I4utBtFv8qKy4sq1enftf2gMdpqI8oVQTAfySkTz5r49giVzDj88SVZXP4CeYQwjaw==} engines: {node: '>=0.10.0'} dev: true optional: true - /trim-trailing-lines@1.1.4: + /trim-trailing-lines/1.1.4: resolution: {integrity: sha512-rjUWSqnfTNrjbB9NQWfPMH/xRK1deHeGsHoVfpxJ++XeYXE0d6B1En37AHfw3jtfTU7dzMzZL2jjpe8Qb5gLIQ==} dev: true - /trim@0.0.1: - resolution: {integrity: sha1-WFhUf2spB1fulczMZm+1AITEYN0=} + /trim/0.0.1: + resolution: {integrity: sha512-YzQV+TZg4AxpKxaTHK3c3D+kRDCGVEE7LemdlQZoQXn0iennk10RsIoY6ikzAqJTc9Xjl9C1/waHom/J86ziAQ==} + deprecated: Use String.prototype.trim() instead dev: true - /trough@1.0.5: + /trough/1.0.5: resolution: {integrity: sha512-rvuRbTarPXmMb79SmzEp8aqXNKcK+y0XaB298IXueQ8I2PsrATcPBCSPyK/dDNa2iWOhKlfNnOjdAOTBU/nkFA==} dev: true - /ts-dedent@2.2.0: + /ts-dedent/2.2.0: resolution: {integrity: sha512-q5W7tVM71e2xjHZTlgfTDoPF/SmqKG5hddq9SzR49CH2hayqRKJtQ4mtRlSxKaJlR/+9rEM+mnBHf7I2/BQcpQ==} engines: {node: '>=6.10'} dev: true - /ts-interface-checker@0.1.13: + /ts-interface-checker/0.1.13: resolution: {integrity: sha512-Y/arvbn+rrz3JCKl9C4kVNfTfSm2/mEp5FSz5EsZSANGPSlQrpRI5M4PKF+mJnE52jOO90PnPSc3Ur3bTQw0gA==} dev: true - /ts-invariant@0.10.3: + /ts-invariant/0.10.3: resolution: {integrity: sha512-uivwYcQaxAucv1CzRp2n/QdYPo4ILf9VXgH19zEIjFx2EJufV16P0JtJVpYHy89DItG6Kwj2oIUjrcK5au+4tQ==} engines: {node: '>=8'} dependencies: - tslib: 2.5.3 + tslib: 2.6.0 dev: false - /ts-node@10.9.1(@types/node@18.16.19)(typescript@5.1.6): + /ts-node/10.9.1_pqdfkuhuhnwv2d7uogwywwxtqq: resolution: {integrity: sha512-NtVysVPkxxrwFGUUxGYhfux8k78pQB3JqYBXlLRZgdGUqTO5wU/UyHop5p70iEbGhB7q5KmiZiU0Y3KlJrScEw==} hasBin: true peerDependencies: @@ -23805,9 +20867,9 @@ packages: '@tsconfig/node10': 1.0.9 '@tsconfig/node12': 1.0.11 '@tsconfig/node14': 1.0.3 - '@tsconfig/node16': 1.0.3 + '@tsconfig/node16': 1.0.4 '@types/node': 18.16.19 - acorn: 8.9.0 + acorn: 8.10.0 acorn-walk: 8.2.0 arg: 4.1.3 create-require: 1.1.1 @@ -23818,7 +20880,7 @@ packages: yn: 3.1.1 dev: true - /ts-pnp@1.2.0(typescript@4.8.4): + /ts-pnp/1.2.0_typescript@4.9.5: resolution: {integrity: sha512-csd+vJOb/gkzvcCHgTGSChYpy5f1/XKNsmvBGO4JXS+z1v2HobugDz4s1IeFXM3wZB44uczs+eazB5Q/ccdhQw==} engines: {node: '>=6'} peerDependencies: @@ -23827,21 +20889,21 @@ packages: typescript: optional: true dependencies: - typescript: 4.8.4 + typescript: 4.9.5 dev: true - /tslib@1.14.1: + /tslib/1.14.1: resolution: {integrity: sha512-Xni35NKzjgMrwevysHTCArtLDpPvye8zV/0E4EyYn43P7/7qvQwPh9BGkHewbMulVntbigmcT7rdX3BNo9wRJg==} dev: true - /tslib@2.4.0: + /tslib/2.4.0: resolution: {integrity: sha512-d6xOpEDfsi2CZVlPQzGeux8XMwLT9hssAsaPYExaQMuYskwb+x1x7J371tWlbBdWHroy99KnVB6qIkUbs5X3UQ==} dev: false - /tslib@2.5.3: - resolution: {integrity: sha512-mSxlJJwl3BMEQCUNnxXBU9jP4JBktcEGhURcPR6VQVlnP0FdDEsIaz0C35dXNGLyRfrATNofF0F5p2KPxQgB+w==} + /tslib/2.6.0: + resolution: {integrity: sha512-7At1WUettjcSRHXCyYtTselblcHl9PJFFVKiCAy/bY97+BPZXSQ2wbq0P9s8tK2G7dFQfNnlJnPAiArVBVBsfA==} - /tsup@6.7.0(ts-node@10.9.1)(typescript@5.1.6): + /tsup/6.7.0_kg5gpyde6u3komamnnl67a6oc4: resolution: {integrity: sha512-L3o8hGkaHnu5TdJns+mCqFsDBo83bJ44rlK7e6VdanIvpea4ArPcU3swWGsLVbXak1PqQx/V+SSmFPujBK+zEQ==} engines: {node: '>=14.18'} hasBin: true @@ -23857,19 +20919,19 @@ packages: typescript: optional: true dependencies: - bundle-require: 4.0.1(esbuild@0.17.18) + bundle-require: 4.0.1_esbuild@0.17.19 cac: 6.7.14 chokidar: 3.5.3 - debug: 4.3.4(supports-color@8.1.1) - esbuild: 0.17.18 + debug: 4.3.4 + esbuild: 0.17.19 execa: 5.1.1 globby: 11.1.0 joycon: 3.1.1 - postcss-load-config: 3.1.4(ts-node@10.9.1) + postcss-load-config: 3.1.4_ts-node@10.9.1 resolve-from: 5.0.0 - rollup: 3.26.0 + rollup: 3.26.2 source-map: 0.8.0-beta.0 - sucrase: 3.28.0 + sucrase: 3.32.0 tree-kill: 1.2.2 typescript: 5.1.6 transitivePeerDependencies: @@ -23877,7 +20939,7 @@ packages: - ts-node dev: true - /tsutils@3.21.0(typescript@5.1.6): + /tsutils/3.21.0_typescript@5.1.6: resolution: {integrity: sha512-mHKK3iUXL+3UF6xL5k0PEhKRUBKPBCv/+RkEOpjRWxxx27KKRBmmA60A9pgOUvMi8GKhRMPEmjBRPzs2W7O1OA==} engines: {node: '>= 6'} peerDependencies: @@ -23887,96 +20949,78 @@ packages: typescript: 5.1.6 dev: true - /tsx@3.11.0: - resolution: {integrity: sha512-q+q4xxu41+AafVwvAGqtNJ1ekPFd33ZhTMXvgIpHMqv/W89efwDRE9IyjhEAZm5iTHsshKaf1BYWSk789BrNCA==} - hasBin: true - dependencies: - '@esbuild-kit/cjs-loader': 2.4.0 - '@esbuild-kit/core-utils': 3.0.0 - '@esbuild-kit/esm-loader': 2.5.0 - optionalDependencies: - fsevents: 2.3.2 - dev: true - - /tsx@3.9.0: - resolution: {integrity: sha512-ofxsE+qjqCYYq4UBt5khglvb+ESgxef1YpuNcdQI92kvcAT2tZVrnSK3g4bRXTUhLmKHcC5q8vIZA47os/stng==} + /tsx/3.12.7: + resolution: {integrity: sha512-C2Ip+jPmqKd1GWVQDvz/Eyc6QJbGfE7NrR3fx5BpEHMZsEHoIxHL1j+lKdGobr8ovEyqeNkPLSKp6SCSOt7gmw==} hasBin: true dependencies: - '@esbuild-kit/cjs-loader': 2.3.3 - '@esbuild-kit/core-utils': 2.3.0 - '@esbuild-kit/esm-loader': 2.4.2 + '@esbuild-kit/cjs-loader': 2.4.2 + '@esbuild-kit/core-utils': 3.1.0 + '@esbuild-kit/esm-loader': 2.5.5 optionalDependencies: fsevents: 2.3.2 dev: true - /tty-browserify@0.0.0: - resolution: {integrity: sha1-oVe6QC2iTpv5V/mqadUk7tQpAaY=} + /tty-browserify/0.0.0: + resolution: {integrity: sha512-JVa5ijo+j/sOoHGjw0sxw734b1LhBkQ3bvUGNdxnVXDCX81Yx7TFgnZygxrIIWn23hbfTaMYLwRmAxFyDuFmIw==} dev: true - /tunnel-agent@0.6.0: + /tunnel-agent/0.6.0: resolution: {integrity: sha512-McnNiV1l8RYeY8tBgEpuodCC1mLUdbSN+CYBL7kJsJNInOP8UjDDEwdk6Mw60vdLLrr5NHKZhMAOSrR2NZuQ+w==} dependencies: safe-buffer: 5.2.1 dev: true - /tweetnacl@0.14.5: + /tweetnacl/0.14.5: resolution: {integrity: sha512-KXXFFdAbFXY4geFIwoyNK+f5Z1b7swfXABfL7HXCmoIWMKU3dmS26672A4EeQtDzLKy7SXmfBu51JolvEKwtGA==} dev: true - /type-check@0.3.2: - resolution: {integrity: sha512-ZCmOJdvOWDBYJlzAoFkC+Q0+bUyEOS1ltgp1MGU03fqHG+dbi9tBFU2Rd9QKiDZFAYrhPh2JUf7rZRIuHRKtOg==} - engines: {node: '>= 0.8.0'} - dependencies: - prelude-ls: 1.1.2 - dev: true - - /type-check@0.4.0: + /type-check/0.4.0: resolution: {integrity: sha512-XleUoc9uwGXqjWwXaUTZAmzMcFZ5858QA2vvx1Ur5xIcixXIP+8LnFDgRplU30us6teqdlskFfu+ae4K79Ooew==} engines: {node: '>= 0.8.0'} dependencies: prelude-ls: 1.2.1 dev: true - /type-detect@4.0.8: + /type-detect/4.0.8: resolution: {integrity: sha512-0fr/mIH1dlO+x7TlcMy+bIDqKPsw/70tVyeHW787goQjhmqaZe10uwLujubK9q9Lg6Fiho1KUKDYz0Z7k7g5/g==} engines: {node: '>=4'} - /type-fest@0.16.0: + /type-fest/0.16.0: resolution: {integrity: sha512-eaBzG6MxNzEn9kiwvtre90cXaNLkmadMWa1zQMs3XORCXNbsH/OewwbxC5ia9dCxIxnTAsSxXJaa/p5y8DlvJg==} engines: {node: '>=10'} dev: true - /type-fest@0.20.2: + /type-fest/0.20.2: resolution: {integrity: sha512-Ne+eE4r0/iWnpAxD852z3A+N0Bt5RN//NjJwRd2VFHEmrywxf5vsZlh4R6lixl6B+wz/8d+maTSAkN1FIkI3LQ==} engines: {node: '>=10'} dev: true - /type-fest@0.21.3: + /type-fest/0.21.3: resolution: {integrity: sha512-t0rzBq87m3fVcduHDUFhKmyyX+9eo6WQjZvf51Ea/M0Q7+T374Jp1aUiyUl0GKxp8M/OETVHSDvmkyPgvX+X2w==} engines: {node: '>=10'} dev: true - /type-fest@0.6.0: + /type-fest/0.6.0: resolution: {integrity: sha512-q+MB8nYR1KDLrgr4G5yemftpMC7/QLqVndBmEEdqzmNj5dcFOO4Oo8qlwZE3ULT3+Zim1F8Kq4cBnikNhlCMlg==} engines: {node: '>=8'} dev: true - /type-fest@0.8.1: + /type-fest/0.8.1: resolution: {integrity: sha512-4dbzIzqvjtgiM5rw1k5rEHtBANKmdudhGyBEajN01fEyhaAIhsoKNy6y7+IN93IfpFtwY9iqi7kD+xwKhQsNJA==} engines: {node: '>=8'} dev: true - /type-fest@1.4.0: + /type-fest/1.4.0: resolution: {integrity: sha512-yGSza74xk0UG8k+pLh5oeoYirvIiWo5t0/o3zHHAO2tRDiZcxWP7fywNlXhqb6/r6sWvwi+RsyQMWhVLe4BVuA==} engines: {node: '>=10'} dev: true - /type-fest@2.19.0: + /type-fest/2.19.0: resolution: {integrity: sha512-RAH822pAdBgcNMAfWnCBU3CFZcfZ/i1eZjwFU/dsLKumyuuP3niueg2UAukXYF0E2AAoc82ZSSf9J0WQBinzHA==} engines: {node: '>=12.20'} dev: true - /type-is@1.6.18: + /type-is/1.6.18: resolution: {integrity: sha512-TkRKr9sUTxEH8MdfuCSP7VizJyzRNMjj2J2do2Jr3Kym598JVdEksuzPQCnlFPW4ky9Q+iA+ma9BGm06XQBy8g==} engines: {node: '>= 0.6'} dependencies: @@ -23984,52 +21028,54 @@ packages: mime-types: 2.1.35 dev: true - /typedarray-to-buffer@3.1.5: + /typed-array-length/1.0.4: + resolution: {integrity: sha512-KjZypGq+I/H7HI5HlOoGHkWUUGq+Q0TPhQurLbyrVrvnKTBgzLhIJ7j6J/XTQOi0d1RjyZ0wdas8bKs2p0x3Ng==} + dependencies: + call-bind: 1.0.2 + for-each: 0.3.3 + is-typed-array: 1.1.10 + dev: true + + /typedarray-to-buffer/3.1.5: resolution: {integrity: sha512-zdu8XMNEDepKKR+XYOXAVPtWui0ly0NtohUscw+UmaHiAWT8hrV1rr//H6V+0DvJ3OQ19S979M0laLfX8rm82Q==} dependencies: is-typedarray: 1.0.0 dev: true - /typedarray@0.0.6: + /typedarray/0.0.6: resolution: {integrity: sha512-/aCDEGatGvZ2BIk+HmLf4ifCJFwvKFNb9/JeZPMulfgFracn9QFcAf5GO8B/mweUjSoblS5In0cWhqpfs/5PQA==} dev: true - /typescript@4.8.4: - resolution: {integrity: sha512-QCh+85mCy+h0IGff8r5XWzOVSbBO+KfeYrMQh7NJ58QujwcE22u+NUSmUxqF+un70P9GXKxa2HCNiTTMJknyjQ==} + /typescript/4.9.5: + resolution: {integrity: sha512-1FXk9E2Hm+QzZQ7z+McJiHL4NW1F2EzMu9Nq9i3zAaGqibafqYwCVU6WyWAuyQRRzOlxou8xZSyXLEN8oKj24g==} engines: {node: '>=4.2.0'} hasBin: true dev: true - /typescript@5.1.3: - resolution: {integrity: sha512-XH627E9vkeqhlZFQuL+UsyAXEnibT0kWR2FWONlr4sTjvxyJYnyefgrkyECLzM5NenmKzRAy2rR/OlYLA1HkZw==} - engines: {node: '>=14.17'} - hasBin: true - dev: true - - /typescript@5.1.6: + /typescript/5.1.6: resolution: {integrity: sha512-zaWCozRZ6DLEWAWFrVDz1H6FVXzUSfTy5FUMWsQlU8Ym5JP9eO4xkTIROFCQvhQf61z6O/G6ugw3SgAnvvm+HA==} engines: {node: '>=14.17'} hasBin: true dev: true - /ua-parser-js@1.0.34: - resolution: {integrity: sha512-K9mwJm/DaB6mRLZfw6q8IMXipcrmuT6yfhYmwhAkuh+81sChuYstYA+znlgaflUPaYUa3odxKPKGw6Vw/lANew==} + /ua-parser-js/1.0.35: + resolution: {integrity: sha512-fKnGuqmTBnIE+/KXSzCn4db8RTigUzw1AN0DmdU6hJovUTbYJKyqj+8Mt1c4VfRDnOVJnENmfYkIPZ946UrSAA==} dev: true - /ufo@0.8.6: + /ufo/0.8.6: resolution: {integrity: sha512-fk6CmUgwKCfX79EzcDQQpSCMxrHstvbLswFChHS0Vump+kFkw7nJBfTZoC1j0bOGoY9I7R3n2DGek5ajbcYnOw==} dev: true - /ufo@1.1.2: + /ufo/1.1.2: resolution: {integrity: sha512-TrY6DsjTQQgyS3E3dBaOXf0TpPD8u9FVrVYmKVegJuFw51n/YB9XPt+U6ydzFG5ZIN7+DIjPbNmXoBj9esYhgQ==} - /uglify-js@3.17.0: - resolution: {integrity: sha512-aTeNPVmgIMPpm1cxXr2Q/nEbvkmV8yq66F3om7X3P/cvOXQ0TMQ64Wk63iyT1gPlmdmGzjGpyLh1f3y8MZWXGg==} + /uglify-js/3.17.4: + resolution: {integrity: sha512-T9q82TJI9e/C1TAxYvfb16xO120tMVFZrGA3f9/P4424DNu6ypK103y0GPFVa17yotwSyZW5iYXgjYHkGrJW/g==} engines: {node: '>=0.8.0'} hasBin: true dev: true - /unbox-primitive@1.0.2: + /unbox-primitive/1.0.2: resolution: {integrity: sha512-61pPlCD9h51VoreyJ0BReideM3MDKMKnh6+V9L08331ipq6Q8OFXZYiqP6n/tbHx4s5I9uRhcye6BrbkizkBDw==} dependencies: call-bind: 1.0.2 @@ -24038,73 +21084,66 @@ packages: which-boxed-primitive: 1.0.2 dev: true - /unbzip2-stream@1.4.3: + /unbzip2-stream/1.4.3: resolution: {integrity: sha512-mlExGW4w71ebDJviH16lQLtZS32VKqsSfk80GCfUlwT/4/hNRFsoscrF/c++9xinkMzECL1uL9DDwXqFWkruPg==} dependencies: buffer: 5.7.1 through: 2.3.8 dev: true - /unconfig@0.3.9: + /unconfig/0.3.9: resolution: {integrity: sha512-8yhetFd48M641mxrkWA+C/lZU4N0rCOdlo3dFsyFPnBHBjMJfjT/3eAZBRT2RxCRqeBMAKBVgikejdS6yeBjMw==} dependencies: - '@antfu/utils': 0.7.4 + '@antfu/utils': 0.7.5 defu: 6.1.2 - jiti: 1.18.2 + jiti: 1.19.1 dev: true - /undici@5.12.0: - resolution: {integrity: sha512-zMLamCG62PGjd9HHMpo05bSLvvwWOZgGeiWlN/vlqu3+lRo3elxktVGEyLMX+IO7c2eflLjcW74AlkhEZm15mg==} - engines: {node: '>=12.18'} - dependencies: - busboy: 1.6.0 - dev: true - - /undici@5.22.1: + /undici/5.22.1: resolution: {integrity: sha512-Ji2IJhFXZY0x/0tVBXeQwgPlLWw13GVzpsWPQ3rV50IFMMof2I55PZZxtm4P6iNq+L5znYN9nSTAq0ZyE6lSJw==} engines: {node: '>=14.0'} dependencies: busboy: 1.6.0 dev: true - /unfetch@4.2.0: + /unfetch/4.2.0: resolution: {integrity: sha512-F9p7yYCn6cIW9El1zi0HI6vqpeIvBsr3dSuRO6Xuppb1u5rXpCPmMvLSyECLhybr9isec8Ohl0hPekMVrEinDA==} dev: true - /unherit@1.1.3: + /unherit/1.1.3: resolution: {integrity: sha512-Ft16BJcnapDKp0+J/rqFC3Rrk6Y/Ng4nzsC028k2jdDII/rdZ7Wd3pPT/6+vIIxRagwRc9K0IUX0Ra4fKvw+WQ==} dependencies: inherits: 2.0.4 xtend: 4.0.2 dev: true - /unicode-canonical-property-names-ecmascript@2.0.0: + /unicode-canonical-property-names-ecmascript/2.0.0: resolution: {integrity: sha512-yY5PpDlfVIU5+y/BSCxAJRBIS1Zc2dDG3Ujq+sR0U+JjUevW2JhocOF+soROYDSaAezOzOKuyyixhD6mBknSmQ==} engines: {node: '>=4'} dev: true - /unicode-match-property-ecmascript@2.0.0: + /unicode-match-property-ecmascript/2.0.0: resolution: {integrity: sha512-5kaZCrbp5mmbz5ulBkDkbY0SsPOjKqVS35VpL9ulMPfSl0J0Xsm+9Evphv9CoIZFwre7aJoa94AY6seMKGVN5Q==} engines: {node: '>=4'} dependencies: unicode-canonical-property-names-ecmascript: 2.0.0 - unicode-property-aliases-ecmascript: 2.0.0 + unicode-property-aliases-ecmascript: 2.1.0 dev: true - /unicode-match-property-value-ecmascript@2.0.0: - resolution: {integrity: sha512-7Yhkc0Ye+t4PNYzOGKedDhXbYIBe1XEQYQxOPyhcXNMJ0WCABqqj6ckydd6pWRZTHV4GuCPKdBAUiMc60tsKVw==} + /unicode-match-property-value-ecmascript/2.1.0: + resolution: {integrity: sha512-qxkjQt6qjg/mYscYMC0XKRn3Rh0wFPlfxB0xkt9CfyTvpX1Ra0+rAmdX2QyAobptSEvuy4RtpPRui6XkV+8wjA==} engines: {node: '>=4'} dev: true - /unicode-property-aliases-ecmascript@2.0.0: - resolution: {integrity: sha512-5Zfuy9q/DFr4tfO7ZPeVXb1aPoeQSdeFMLpYuFebehDAhbuevLs5yxSZmIFN1tP5F9Wl4IpJrYojg85/zgyZHQ==} + /unicode-property-aliases-ecmascript/2.1.0: + resolution: {integrity: sha512-6t3foTQI9qne+OZoVQB/8x8rk2k1eVy1gRXhV3oFQ5T6R1dqQ1xtin3XqSlx3+ATBkliTaR/hHyJBm+LVPNM8w==} engines: {node: '>=4'} dev: true - /unified@9.2.0: + /unified/9.2.0: resolution: {integrity: sha512-vx2Z0vY+a3YoTj8+pttM3tiJHCwY5UFbYdiWrwBEbHmK8pvsPj2rtAX2BFfgXen8T39CJWblWRDT4L5WGXtDdg==} dependencies: - '@types/unist': 2.0.6 + '@types/unist': 2.0.7 bail: 1.0.5 extend: 3.0.2 is-buffer: 2.0.5 @@ -24113,10 +21152,10 @@ packages: vfile: 4.2.1 dev: true - /unimport@3.0.7(rollup@3.26.0): - resolution: {integrity: sha512-2dVQUxJEGcrSZ0U4qtwJVODrlfyGcwmIOoHVqbAFFUx7kPoEN5JWr1cZFhLwoAwTmZOvqAm3YIkzv1engIQocg==} + /unimport/3.0.14: + resolution: {integrity: sha512-67Rh/sGpEuVqdHWkXaZ6NOq+I7sKt86o+DUtKeGB6dh4Hk1A8AQrzyVGg2+LaVEYotStH7HwvV9YSaRjyT7Uqg==} dependencies: - '@rollup/pluginutils': 5.0.2(rollup@3.26.0) + '@rollup/pluginutils': 5.0.2 escape-string-regexp: 5.0.0 fast-glob: 3.3.0 local-pkg: 0.4.3 @@ -24126,12 +21165,12 @@ packages: pkg-types: 1.0.3 scule: 1.0.0 strip-literal: 1.0.1 - unplugin: 1.3.1 + unplugin: 1.3.2 transitivePeerDependencies: - rollup dev: true - /union-value@1.0.1: + /union-value/1.0.1: resolution: {integrity: sha512-tJfXmxMeWYnczCVs7XAEvIV7ieppALdyepWMkHkwciRpZraG/xwT+s2JN8+pr1+8jCRf80FFzvr+MpQeeoF4Xg==} engines: {node: '>=0.10.0'} dependencies: @@ -24141,170 +21180,133 @@ packages: set-value: 2.0.1 dev: true - /unique-filename@1.1.1: + /unique-filename/1.1.1: resolution: {integrity: sha512-Vmp0jIp2ln35UTXuryvjzkjGdRyf9b2lTXuSYUiPmzRcl3FDtYqAwOnTJkAngD9SWhnoJzDbTKwaOrZ+STtxNQ==} dependencies: unique-slug: 2.0.2 dev: true - /unique-slug@2.0.2: + /unique-slug/2.0.2: resolution: {integrity: sha512-zoWr9ObaxALD3DOPfjPSqxt4fnZiWblxHIgeWqW8x7UqDzEtHEQLzji2cuJYQFCU6KmoJikOYAZlrTHHebjx2w==} dependencies: imurmurhash: 0.1.4 dev: true - /unique-string@2.0.0: + /unique-string/2.0.0: resolution: {integrity: sha512-uNaeirEPvpZWSgzwsPGtU2zVSTrn/8L5q/IexZmH0eH6SA73CmAA5U4GwORTxQAZs95TAXLNqeLoPPNO5gZfWg==} engines: {node: '>=8'} dependencies: crypto-random-string: 2.0.0 dev: true - /unist-builder@2.0.3: + /unist-builder/2.0.3: resolution: {integrity: sha512-f98yt5pnlMWlzP539tPc4grGMsFaQQlP/vM396b00jngsiINumNmsY8rkXjfoi1c6QaM8nQ3vaGDuoKWbe/1Uw==} dev: true - /unist-util-generated@1.1.6: + /unist-util-generated/1.1.6: resolution: {integrity: sha512-cln2Mm1/CZzN5ttGK7vkoGw+RZ8VcUH6BtGbq98DDtRGquAAOXig1mrBQYelOwMXYS8rK+vZDyyojSjp7JX+Lg==} dev: true - /unist-util-is@4.1.0: + /unist-util-is/4.1.0: resolution: {integrity: sha512-ZOQSsnce92GrxSqlnEEseX0gi7GH9zTJZ0p9dtu87WRb/37mMPO2Ilx1s/t9vBHrFhbgweUwb+t7cIn5dxPhZg==} dev: true - /unist-util-position@3.1.0: + /unist-util-position/3.1.0: resolution: {integrity: sha512-w+PkwCbYSFw8vpgWD0v7zRCl1FpY3fjDSQ3/N/wNd9Ffa4gPi8+4keqt99N3XW6F99t/mUzp2xAhNmfKWp95QA==} dev: true - /unist-util-remove-position@2.0.1: + /unist-util-remove-position/2.0.1: resolution: {integrity: sha512-fDZsLYIe2uT+oGFnuZmy73K6ZxOPG/Qcm+w7jbEjaFcJgbQ6cqjs/eSPzXhsmGpAsWPkqZM9pYjww5QTn3LHMA==} dependencies: unist-util-visit: 2.0.3 dev: true - /unist-util-remove@2.1.0: + /unist-util-remove/2.1.0: resolution: {integrity: sha512-J8NYPyBm4baYLdCbjmf1bhPu45Cr1MWTm77qd9istEkzWpnN6O9tMsEbB2JhNnBCqGENRqEWomQ+He6au0B27Q==} dependencies: unist-util-is: 4.1.0 dev: true - /unist-util-stringify-position@2.0.3: + /unist-util-stringify-position/2.0.3: resolution: {integrity: sha512-3faScn5I+hy9VleOq/qNbAd6pAx7iH5jYBMS9I1HgQVijz/4mv5Bvw5iw1sC/90CODiKo81G/ps8AJrISn687g==} dependencies: - '@types/unist': 2.0.6 + '@types/unist': 2.0.7 dev: true - /unist-util-visit-parents@3.1.1: + /unist-util-visit-parents/3.1.1: resolution: {integrity: sha512-1KROIZWo6bcMrZEwiH2UrXDyalAa0uqzWCxCJj6lPOvTve2WkfgCytoDTPaMnodXh1WrXOq0haVYHj99ynJlsg==} dependencies: - '@types/unist': 2.0.6 + '@types/unist': 2.0.7 unist-util-is: 4.1.0 dev: true - /unist-util-visit@2.0.3: + /unist-util-visit/2.0.3: resolution: {integrity: sha512-iJ4/RczbJMkD0712mGktuGpm/U4By4FfDonL7N/9tATGIF4imikjOuagyMY53tnZq3NP6BcmlrHhEKAfGWjh7Q==} dependencies: - '@types/unist': 2.0.6 + '@types/unist': 2.0.7 unist-util-is: 4.1.0 unist-util-visit-parents: 3.1.1 dev: true - /universalify@0.2.0: + /universalify/0.2.0: resolution: {integrity: sha512-CJ1QgKmNg3CwvAv/kOFmtnEN05f0D/cn9QntgNOQlQF9dgvVTHj3t+8JPdjqawCHk7V/KA+fbUqzZ9XWhcqPUg==} engines: {node: '>= 4.0.0'} dev: true - /universalify@2.0.0: + /universalify/2.0.0: resolution: {integrity: sha512-hAZsKq7Yy11Zu1DE0OzWjw7nnLZmJZYTDZZyEFHZdUhV8FkH5MCfoU1XMaxXovpyW5nq5scPqq0ZDP9Zyl04oQ==} engines: {node: '>= 10.0.0'} dev: true - /unload@2.2.0: + /unload/2.2.0: resolution: {integrity: sha512-B60uB5TNBLtN6/LsgAf3udH9saB5p7gqJwcFfbOEZ8BcBHnGwCf6G/TGiEqkRAxX7zAFIUtzdrXQSdL3Q/wqNA==} dependencies: - '@babel/runtime': 7.18.9 + '@babel/runtime': 7.22.6 detect-node: 2.1.0 dev: false - /unocss@0.53.4(postcss@8.4.24)(rollup@2.79.1)(vite@4.3.9): - resolution: {integrity: sha512-UUEi+oh1rngHHP0DVESRS+ScoKMRF8q6GIQrElHb67gqG7GDEGpy3oocIA/6+1t71I4FFvnnxLMGIo9qAD0TEw==} - engines: {node: '>=14'} - peerDependencies: - '@unocss/webpack': 0.53.4 - peerDependenciesMeta: - '@unocss/webpack': - optional: true - dependencies: - '@unocss/astro': 0.53.4(rollup@2.79.1)(vite@4.3.9) - '@unocss/cli': 0.53.4(rollup@2.79.1) - '@unocss/core': 0.53.4 - '@unocss/extractor-arbitrary-variants': 0.53.4 - '@unocss/postcss': 0.53.4(postcss@8.4.24) - '@unocss/preset-attributify': 0.53.4 - '@unocss/preset-icons': 0.53.4 - '@unocss/preset-mini': 0.53.4 - '@unocss/preset-tagify': 0.53.4 - '@unocss/preset-typography': 0.53.4 - '@unocss/preset-uno': 0.53.4 - '@unocss/preset-web-fonts': 0.53.4 - '@unocss/preset-wind': 0.53.4 - '@unocss/reset': 0.53.4 - '@unocss/transformer-attributify-jsx': 0.53.4 - '@unocss/transformer-attributify-jsx-babel': 0.53.4 - '@unocss/transformer-compile-class': 0.53.4 - '@unocss/transformer-directives': 0.53.4 - '@unocss/transformer-variant-group': 0.53.4 - '@unocss/vite': 0.53.4(rollup@2.79.1)(vite@4.3.9) - transitivePeerDependencies: - - postcss - - rollup - - supports-color - - vite - dev: true - - /unocss@0.53.4(postcss@8.4.24)(rollup@3.26.0)(vite@4.3.9): - resolution: {integrity: sha512-UUEi+oh1rngHHP0DVESRS+ScoKMRF8q6GIQrElHb67gqG7GDEGpy3oocIA/6+1t71I4FFvnnxLMGIo9qAD0TEw==} + /unocss/0.53.5_vite@4.4.3: + resolution: {integrity: sha512-LXAdtzAaH8iEDWxW4t9i6TvJNw0OSrgdN+jw8rAZAWb73Nx51ZLoKPUB1rFvQMr2Li7LcsUj5hYpOrQbhhafYg==} engines: {node: '>=14'} peerDependencies: - '@unocss/webpack': 0.53.4 + '@unocss/webpack': 0.53.5 peerDependenciesMeta: '@unocss/webpack': optional: true dependencies: - '@unocss/astro': 0.53.4(rollup@3.26.0)(vite@4.3.9) - '@unocss/cli': 0.53.4(rollup@3.26.0) - '@unocss/core': 0.53.4 - '@unocss/extractor-arbitrary-variants': 0.53.4 - '@unocss/postcss': 0.53.4(postcss@8.4.24) - '@unocss/preset-attributify': 0.53.4 - '@unocss/preset-icons': 0.53.4 - '@unocss/preset-mini': 0.53.4 - '@unocss/preset-tagify': 0.53.4 - '@unocss/preset-typography': 0.53.4 - '@unocss/preset-uno': 0.53.4 - '@unocss/preset-web-fonts': 0.53.4 - '@unocss/preset-wind': 0.53.4 - '@unocss/reset': 0.53.4 - '@unocss/transformer-attributify-jsx': 0.53.4 - '@unocss/transformer-attributify-jsx-babel': 0.53.4 - '@unocss/transformer-compile-class': 0.53.4 - '@unocss/transformer-directives': 0.53.4 - '@unocss/transformer-variant-group': 0.53.4 - '@unocss/vite': 0.53.4(rollup@3.26.0)(vite@4.3.9) + '@unocss/astro': 0.53.5_vite@4.4.3 + '@unocss/cli': 0.53.5 + '@unocss/core': 0.53.5 + '@unocss/extractor-arbitrary-variants': 0.53.5 + '@unocss/postcss': 0.53.5 + '@unocss/preset-attributify': 0.53.5 + '@unocss/preset-icons': 0.53.5 + '@unocss/preset-mini': 0.53.5 + '@unocss/preset-tagify': 0.53.5 + '@unocss/preset-typography': 0.53.5 + '@unocss/preset-uno': 0.53.5 + '@unocss/preset-web-fonts': 0.53.5 + '@unocss/preset-wind': 0.53.5 + '@unocss/reset': 0.53.5 + '@unocss/transformer-attributify-jsx': 0.53.5 + '@unocss/transformer-attributify-jsx-babel': 0.53.5 + '@unocss/transformer-compile-class': 0.53.5 + '@unocss/transformer-directives': 0.53.5 + '@unocss/transformer-variant-group': 0.53.5 + '@unocss/vite': 0.53.5_vite@4.4.3 transitivePeerDependencies: - - postcss - rollup - supports-color - vite dev: true - /unpipe@1.0.0: + /unpipe/1.0.0: resolution: {integrity: sha512-pjy2bYhSsufwWlKwPc+l3cN7+wuJlK6uz0YdJEOlQDbl6jo/YlPi4mb8agUkVC8BF7V8NuzeyPNqRksA3hztKQ==} engines: {node: '>= 0.8'} dev: true - /unplugin-auto-import@0.16.4(@vueuse/core@10.2.1)(rollup@3.26.0): - resolution: {integrity: sha512-xdgBa9NAS3JG8HjkAZHSbGSMlrjKpaWKXGUzaF6RzEtr980RCl1t0Zsu0skUInNYrEQfqaHc7aGWPv41DLTK/w==} + /unplugin-auto-import/0.16.6: + resolution: {integrity: sha512-M+YIITkx3C/Hg38hp8HmswP5mShUUyJOzpifv7RTlAbeFlO2Tyw0pwrogSSxnipHDPTtI8VHFBpkYkNKzYSuyA==} engines: {node: '>=14'} peerDependencies: '@nuxt/kit': ^3.2.2 @@ -24315,48 +21317,44 @@ packages: '@vueuse/core': optional: true dependencies: - '@antfu/utils': 0.7.4 - '@rollup/pluginutils': 5.0.2(rollup@3.26.0) - '@vueuse/core': 10.2.1(vue@3.3.4) + '@antfu/utils': 0.7.5 + '@rollup/pluginutils': 5.0.2 + fast-glob: 3.3.0 local-pkg: 0.4.3 magic-string: 0.30.1 - minimatch: 9.0.1 - unimport: 3.0.7(rollup@3.26.0) - unplugin: 1.3.1 + minimatch: 9.0.3 + unimport: 3.0.14 + unplugin: 1.3.2 transitivePeerDependencies: - rollup dev: true - /unplugin-vue-components@0.25.1(rollup@2.79.1)(vue@3.3.4): - resolution: {integrity: sha512-kzS2ZHVMaGU2XEO2keYQcMjNZkanDSGDdY96uQT9EPe+wqSZwwgbFfKVJ5ti0+8rGAcKHColwKUvctBhq2LJ3A==} + /unplugin-auto-import/0.16.6_@vueuse+core@10.2.1: + resolution: {integrity: sha512-M+YIITkx3C/Hg38hp8HmswP5mShUUyJOzpifv7RTlAbeFlO2Tyw0pwrogSSxnipHDPTtI8VHFBpkYkNKzYSuyA==} engines: {node: '>=14'} peerDependencies: - '@babel/parser': ^7.15.8 '@nuxt/kit': ^3.2.2 - vue: 2 || 3 + '@vueuse/core': '*' peerDependenciesMeta: - '@babel/parser': - optional: true '@nuxt/kit': optional: true + '@vueuse/core': + optional: true dependencies: - '@antfu/utils': 0.7.4 - '@rollup/pluginutils': 5.0.2(rollup@2.79.1) - chokidar: 3.5.3 - debug: 4.3.4(supports-color@8.1.1) + '@antfu/utils': 0.7.5 + '@rollup/pluginutils': 5.0.2 + '@vueuse/core': 10.2.1_vue@3.3.4 fast-glob: 3.3.0 local-pkg: 0.4.3 magic-string: 0.30.1 - minimatch: 9.0.1 - resolve: 1.22.2 - unplugin: 1.3.1 - vue: 3.3.4 + minimatch: 9.0.3 + unimport: 3.0.14 + unplugin: 1.3.2 transitivePeerDependencies: - rollup - - supports-color dev: true - /unplugin-vue-components@0.25.1(rollup@3.26.0)(vue@3.3.4): + /unplugin-vue-components/0.25.1_vue@3.3.4: resolution: {integrity: sha512-kzS2ZHVMaGU2XEO2keYQcMjNZkanDSGDdY96uQT9EPe+wqSZwwgbFfKVJ5ti0+8rGAcKHColwKUvctBhq2LJ3A==} engines: {node: '>=14'} peerDependencies: @@ -24369,32 +21367,32 @@ packages: '@nuxt/kit': optional: true dependencies: - '@antfu/utils': 0.7.4 - '@rollup/pluginutils': 5.0.2(rollup@3.26.0) + '@antfu/utils': 0.7.5 + '@rollup/pluginutils': 5.0.2 chokidar: 3.5.3 - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 fast-glob: 3.3.0 local-pkg: 0.4.3 magic-string: 0.30.1 - minimatch: 9.0.1 + minimatch: 9.0.3 resolve: 1.22.2 - unplugin: 1.3.1 + unplugin: 1.3.2 vue: 3.3.4 transitivePeerDependencies: - rollup - supports-color dev: true - /unplugin@1.3.1: - resolution: {integrity: sha512-h4uUTIvFBQRxUKS2Wjys6ivoeofGhxzTe2sRWlooyjHXVttcVfV/JiavNd3d4+jty0SVV0dxGw9AkY9MwiaCEw==} + /unplugin/1.3.2: + resolution: {integrity: sha512-Lh7/2SryjXe/IyWqx9K7IKwuKhuOFZEhotiBquOODsv2IVyDkI9lv/XhgfjdXf/xdbv32txmnBNnC/JVTDJlsA==} dependencies: - acorn: 8.9.0 + acorn: 8.10.0 chokidar: 3.5.3 webpack-sources: 3.2.3 webpack-virtual-modules: 0.5.0 dev: true - /unset-value@1.0.0: + /unset-value/1.0.0: resolution: {integrity: sha512-PcA2tsuGSF9cnySLHTLSh2qrQiJ70mn+r+Glzxv2TWZblxsxCC52BDlZoPCsz7STd9pN7EZetkWZBAvk4cgZdQ==} engines: {node: '>=0.10.0'} dependencies: @@ -24402,7 +21400,7 @@ packages: isobject: 3.0.1 dev: true - /untildify@2.1.0: + /untildify/2.1.0: resolution: {integrity: sha512-sJjbDp2GodvkB0FZZcn7k6afVisqX5BZD7Yq3xp4nN2O15BBK0cLm3Vwn2vQaF7UDS0UUsrQMkkplmDI5fskig==} engines: {node: '>=0.10.0'} dependencies: @@ -24410,38 +21408,38 @@ packages: dev: true optional: true - /untildify@4.0.0: + /untildify/4.0.0: resolution: {integrity: sha512-KK8xQ1mkzZeg9inewmFVDNkg3l5LUhoq9kN6iWYB/CC9YMG8HA+c1Q8HwDe6dEX7kErrEVNVBO3fWsVq5iDgtw==} engines: {node: '>=8'} dev: true - /upath@1.2.0: + /upath/1.2.0: resolution: {integrity: sha512-aZwGpamFO61g3OlfT7OQCHqhGnW43ieH9WZeP7QxN/G/jS4jfqUkZxoryvJgVPEcrl5NL/ggHsSmLMHuH64Lhg==} engines: {node: '>=4'} dev: true - /update-browserslist-db@1.0.5(browserslist@4.21.3): - resolution: {integrity: sha512-dteFFpCyvuDdr9S/ff1ISkKt/9YZxKjI9WlRR99c180GaztJtRa/fn18FdxGVKVsnPY7/a/FDN68mcvUmP4U7Q==} + /update-browserslist-db/1.0.11_browserslist@4.21.9: + resolution: {integrity: sha512-dCwEFf0/oT85M1fHBg4F0jtLwJrutGoHSQXCh7u4o2t1drG+c0a9Flnqww6XUKSfQMPpJBRjU8d4RXB09qtvaA==} hasBin: true peerDependencies: browserslist: '>= 4.21.0' dependencies: - browserslist: 4.21.3 + browserslist: 4.21.9 escalade: 3.1.1 picocolors: 1.0.0 - /uri-js@4.4.1: + /uri-js/4.4.1: resolution: {integrity: sha512-7rKUyy33Q1yc98pQ1DAmLtwX109F7TIfWlW1Ydo8Wl1ii1SeHieeh0HHfPeL2fMXK6z0s8ecKs9frCuLJvndBg==} dependencies: punycode: 2.3.0 dev: true - /urix@0.1.0: + /urix/0.1.0: resolution: {integrity: sha512-Am1ousAhSLBeB9cG/7k7r2R0zj50uDRlZHPGbazid5s9rlF1F/QKYObEKSIunSjIOkJZqwRRLpvewjEkM7pSqg==} deprecated: Please see https://github.com/lydell/urix#deprecated dev: true - /url-loader@4.1.1(file-loader@6.2.0)(webpack@4.46.0): + /url-loader/4.1.1_lit45vopotvaqup7lrvlnvtxwy: resolution: {integrity: sha512-3BTV812+AVHHOJQO8O5MkWgZ5aosP7GnROJwvzLS9hWDj00lZ6Z0wNak423Lp9PBZN05N+Jk/N5Si8jRAlGyWA==} engines: {node: '>= 10.13.0'} peerDependencies: @@ -24451,28 +21449,28 @@ packages: file-loader: optional: true dependencies: - file-loader: 6.2.0(webpack@4.46.0) - loader-utils: 2.0.2 + file-loader: 6.2.0_webpack@4.46.0 + loader-utils: 2.0.4 mime-types: 2.1.35 - schema-utils: 3.1.1 + schema-utils: 3.3.0 webpack: 4.46.0 dev: true - /url-parse@1.5.10: + /url-parse/1.5.10: resolution: {integrity: sha512-WypcfiRhfeUP9vvF0j6rw0J3hrWrw6iZv3+22h6iRMJ/8z1Tj6XfLP4DsUix5MhMPnXpiHDoKyoZ/bdCkwBCiQ==} dependencies: querystringify: 2.2.0 requires-port: 1.0.0 dev: true - /url@0.11.0: - resolution: {integrity: sha512-kbailJa29QrtXnxgq+DdCEGlbTeYM2eJUxsz6vjZavrCYPMIFHMKQmSKYAIuUK2i7hgPm28a8piX5NTUtM/LKQ==} + /url/0.11.1: + resolution: {integrity: sha512-rWS3H04/+mzzJkv0eZ7vEDGiQbgquI1fGfOad6zKvgYQi1SzMmhl7c/DdRGxhaWrVH6z0qWITo8rpnxK/RfEhA==} dependencies: - punycode: 1.3.2 - querystring: 0.2.0 + punycode: 1.4.1 + qs: 6.11.2 dev: true - /use-sync-external-store@1.2.0(react@18.2.0): + /use-sync-external-store/1.2.0_react@18.2.0: resolution: {integrity: sha512-eEgnFxGQ1Ife9bzYs6VLi8/4X6CObHMw9Qr9tPY43iKwsPw8xE8+EFsf/2cFZ5S3esXgpWgtSCtLNS41F+sKPA==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -24480,91 +21478,83 @@ packages: react: 18.2.0 dev: true - /use@3.1.1: + /use/3.1.1: resolution: {integrity: sha512-cwESVXlO3url9YWlFW/TA9cshCEhtu7IKJ/p5soJ/gGpj7vbvFrAY/eIioQ6Dw23KjZhYgiIo8HOs1nQ2vr/oQ==} engines: {node: '>=0.10.0'} dev: true - /util-deprecate@1.0.2: + /util-deprecate/1.0.2: resolution: {integrity: sha512-EPD5q1uXyFxJpCrLnCc1nHnq3gOa6DZBocAIiI2TaSCA7VCJ1UJDMagCzIkXNsUYfD1daK//LTEQ8xiIbrHtcw==} dev: true - /util.promisify@1.0.0: + /util.promisify/1.0.0: resolution: {integrity: sha512-i+6qA2MPhvoKLuxnJNpXAGhg7HphQOSUq2LKMZD0m15EiskXUkMvKdF4Uui0WYeCUGea+o2cw/ZuwehtfsrNkA==} dependencies: define-properties: 1.2.0 - object.getownpropertydescriptors: 2.1.4 + object.getownpropertydescriptors: 2.1.6 dev: true - /util@0.10.3: + /util/0.10.3: resolution: {integrity: sha512-5KiHfsmkqacuKjkRkdV7SsfDJ2EGiPsK92s2MhNSY0craxjTdKTtqKsJaCWp4LW33ZZ0OPUv1WO/TFvNQRiQxQ==} dependencies: inherits: 2.0.1 dev: true - /util@0.11.1: + /util/0.11.1: resolution: {integrity: sha512-HShAsny+zS2TZfaXxD9tYj4HQGlBezXZMZuM/S5PKLLoZkShZiGk9o5CzukI1LVHZvjdvZ2Sj1aW/Ndn2NB/HQ==} dependencies: inherits: 2.0.3 dev: true - /util@0.12.5: + /util/0.12.5: resolution: {integrity: sha512-kZf/K6hEIrWHI6XqOFUiiMa+79wE/D8Q+NCNAWclkyg3b4d2k7s0QGepNjiABc+aR3N1PAyHL7p6UcLY6LmrnA==} dependencies: inherits: 2.0.4 is-arguments: 1.1.1 is-generator-function: 1.0.10 is-typed-array: 1.1.10 - which-typed-array: 1.1.9 + which-typed-array: 1.1.10 dev: true - /utila@0.4.0: + /utila/0.4.0: resolution: {integrity: sha512-Z0DbgELS9/L/75wZbro8xAnT50pBVFQZ+hUEueGDU5FN51YSCYM+jdxsfCiHjwNP/4LCDD0i/graKpeBnOXKRA==} dev: true - /utils-merge@1.0.1: - resolution: {integrity: sha1-n5VxD1CiZ5R7LMwSR0HBAoQn5xM=} + /utils-merge/1.0.1: + resolution: {integrity: sha512-pMZTvIkT1d+TFGvDOqodOclx0QWkkgi6Tdoa8gC8ffGAAqz9pzPTZWAybbsHHoED/ztMtkv/VoYTYyShUn81hA==} engines: {node: '>= 0.4.0'} dev: true - /uuid-browser@3.1.0: + /uuid-browser/3.1.0: resolution: {integrity: sha512-dsNgbLaTrd6l3MMxTtouOCFw4CBFc/3a+GgYA2YyrJvyQ1u6q4pcu3ktLoUZ/VN/Aw9WsauazbgsgdfVWgAKQg==} + deprecated: Package no longer supported and required. Use the uuid package or crypto.randomUUID instead dev: true - /uuid@3.4.0: + /uuid/3.4.0: resolution: {integrity: sha512-HjSDRw6gZE5JMggctHBcjVak08+KEVhSIiDzFnT9S9aegmp85S/bReBVTb4QTFaRNptJ9kuYaNhnbNEOkbKb/A==} deprecated: Please upgrade to version 7 or higher. Older versions may use Math.random() in certain circumstances, which is known to be problematic. See https://v8.dev/blog/math-random for details. hasBin: true dev: true - /uuid@8.3.2: + /uuid/8.3.2: resolution: {integrity: sha512-+NYs2QeMWy+GWFOEm9xnn6HCDp0l7QBD7ml8zLUmJ+93Q5NF0NocErnwkTkXVFNiX3/fpC6afS8Dhb/gz7R7eg==} hasBin: true dev: true - /uuid@9.0.0: + /uuid/9.0.0: resolution: {integrity: sha512-MXcSTerfPa4uqyzStbRoTgt5XIe3x5+42+q1sDuy3R5MDk66URdLMOZe5aPX/SQd+kuYAh0FdP/pO28IkQyTeg==} hasBin: true dev: true - /v8-compile-cache-lib@3.0.1: + /v8-compile-cache-lib/3.0.1: resolution: {integrity: sha512-wa7YjyUGfNZngI/vtK0UHAN+lgDCxBPCylVXGp0zu59Fz5aiGtNXaq3DhIov063MorB+VfufLh3JlF2KdTK3xg==} dev: true - /v8-compile-cache@2.3.0: + /v8-compile-cache/2.3.0: resolution: {integrity: sha512-l8lCEmLcLYZh4nbunNZvQCJc5pv7+RCwa8q/LdUx8u7lsWvPDKmpodJAJNwkAhJC//dFY48KuIEmjtd4RViDrA==} dev: true - /v8-to-istanbul@8.1.1: - resolution: {integrity: sha512-FGtKtv3xIpR6BYhvgH8MI/y78oT7d8Au3ww4QIxymrCtZEh5b8gCw2siywE+puhEmuWKDtmfrvF5UlB298ut3w==} - engines: {node: '>=10.12.0'} - dependencies: - '@types/istanbul-lib-coverage': 2.0.4 - convert-source-map: 1.9.0 - source-map: 0.7.4 - dev: true - - /v8-to-istanbul@9.1.0: + /v8-to-istanbul/9.1.0: resolution: {integrity: sha512-6z3GW9x8G1gd+JIIgQQQxXuiJtCXeAjp6RaPEPLv62mH3iPHPxV6W3robxtCzNErRo6ZwTmzWhsbNvjyEBKzKA==} engines: {node: '>=10.12.0'} dependencies: @@ -24572,23 +21562,27 @@ packages: '@types/istanbul-lib-coverage': 2.0.4 convert-source-map: 1.9.0 - /validate-npm-package-license@3.0.4: + /validate-html-nesting/1.2.2: + resolution: {integrity: sha512-hGdgQozCsQJMyfK5urgFcWEqsSSrK63Awe0t/IMR0bZ0QMtnuaiHzThW81guu3qx9abLi99NEuiaN6P9gVYsNg==} + dev: true + + /validate-npm-package-license/3.0.4: resolution: {integrity: sha512-DpKm2Ui/xN7/HQKCtpZxoRWBhZ9Z0kqtygG8XCgNQ8ZlDnxuQmWhj566j8fN4Cu3/JmbhsDo7fcAJq4s9h27Ew==} dependencies: - spdx-correct: 3.1.1 + spdx-correct: 3.2.0 spdx-expression-parse: 3.0.1 dev: true - /vary@1.1.2: + /vary/1.1.2: resolution: {integrity: sha512-BNGbWLfd0eUPabhkXUVm0j8uuvREyTh5ovRa/dyow/BqAbZJyC+5fU+IzQOzmAKzYqYRAISoRhdQr3eIZ/PXqg==} engines: {node: '>= 0.8'} dev: true - /vecti@2.1.40: + /vecti/2.1.40: resolution: {integrity: sha512-89P1Siijv7itxmhQP2gf/X3X+DTszUEYyUHuHF2EsHE9lgNWULx2WWvVZXCt71DBXx3YJ/Aj8yTZmly9qOkF0g==} dev: true - /verror@1.10.0: + /verror/1.10.0: resolution: {integrity: sha512-ZZKSmDAEFOijERBLkmYfJ+vmk3w+7hOLYDNkRCuRuMJGEmqYNCNLyBBFwWKVMhfwaEF3WOd0Zlw86U/WC/+nYw==} engines: {'0': node >=0.6.0} dependencies: @@ -24597,27 +21591,46 @@ packages: extsprintf: 1.3.0 dev: true - /vfile-location@3.2.0: + /vfile-location/3.2.0: resolution: {integrity: sha512-aLEIZKv/oxuCDZ8lkJGhuhztf/BW4M+iHdCwglA/eWc+vtuRFJj8EtgceYFX4LRjOhCAAiNHsKGssC6onJ+jbA==} dev: true - /vfile-message@2.0.4: + /vfile-message/2.0.4: resolution: {integrity: sha512-DjssxRGkMvifUOJre00juHoP9DPWuzjxKuMDrhNbk2TdaYYBNMStsNhEOt3idrtI12VQYM/1+iM0KOzXi4pxwQ==} dependencies: - '@types/unist': 2.0.6 + '@types/unist': 2.0.7 unist-util-stringify-position: 2.0.3 dev: true - /vfile@4.2.1: + /vfile/4.2.1: resolution: {integrity: sha512-O6AE4OskCG5S1emQ/4gl8zK586RqA3srz3nfK/Viy0UPToBc5Trp9BVFb1u0CjsKrAWwnpr4ifM/KBXPWwJbCA==} dependencies: - '@types/unist': 2.0.6 + '@types/unist': 2.0.7 is-buffer: 2.0.5 unist-util-stringify-position: 2.0.3 vfile-message: 2.0.4 dev: true - /vite-plugin-pages@0.31.0(vite@4.3.9): + /victory-vendor/36.6.11: + resolution: {integrity: sha512-nT8kCiJp8dQh8g991J/R5w5eE2KnO8EAIP0xocWlh9l2okngMWglOPoMZzJvek8Q1KUc4XE/mJxTZnvOB1sTYg==} + dependencies: + '@types/d3-array': 3.0.5 + '@types/d3-ease': 3.0.0 + '@types/d3-interpolate': 3.0.1 + '@types/d3-scale': 4.0.3 + '@types/d3-shape': 3.1.1 + '@types/d3-time': 3.0.0 + '@types/d3-timer': 3.0.0 + d3-array: 3.2.4 + d3-ease: 3.0.1 + d3-interpolate: 3.0.1 + d3-scale: 4.0.2 + d3-shape: 3.2.0 + d3-time: 3.1.0 + d3-timer: 3.0.1 + dev: false + + /vite-plugin-pages/0.31.0_vite@4.4.3: resolution: {integrity: sha512-fw3onBfVTXQI7rOzAbSZhmfwvk50+3qNnGZpERjmD93c8nEjrGLyd53eFXYMxcJV4KA1vzi4qIHt2+6tS4dEMw==} peerDependencies: '@vue/compiler-sfc': ^2.7.0 || ^3.0.0 @@ -24627,74 +21640,76 @@ packages: optional: true dependencies: '@types/debug': 4.1.8 - debug: 4.3.4(supports-color@8.1.1) - deep-equal: 2.2.1 + debug: 4.3.4 + deep-equal: 2.2.2 extract-comments: 1.1.0 fast-glob: 3.3.0 json5: 2.2.3 local-pkg: 0.4.3 picocolors: 1.0.0 - vite: 4.3.9(@types/node@18.16.19) + vite: 4.4.3 yaml: 2.3.1 transitivePeerDependencies: - supports-color dev: true - /vite-plugin-pwa@0.16.4(vite@4.3.9)(workbox-build@7.0.0)(workbox-window@7.0.0): + /vite-plugin-pwa/0.16.4_cqwyifvz3q2qdw6r4piqd2mqaa: resolution: {integrity: sha512-lmwHFIs9zI2H9bXJld/zVTbCqCQHZ9WrpyDMqosICDV0FVnCJwniX1NMDB79HGTIZzOQkY4gSZaVTJTw6maz/Q==} engines: {node: '>=16.0.0'} peerDependencies: vite: ^3.1.0 || ^4.0.0 - workbox-build: ^7.0.0 workbox-window: ^7.0.0 dependencies: - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 fast-glob: 3.3.0 - pretty-bytes: 6.0.0 - vite: 4.3.9(@types/node@18.16.19) + pretty-bytes: 6.1.0 + vite: 4.4.3 workbox-build: 7.0.0 workbox-window: 7.0.0 transitivePeerDependencies: + - '@types/babel__core' - supports-color dev: true - /vite-plugin-ruby@3.1.2(vite@4.3.9): - resolution: {integrity: sha512-Pp/NR79lV96wEOjp5MhVHuFxqUhEMNqc7L/02i+XXl1Mq1ab7s2j9kAgtiqp5QKxMd1jy8gV32PgWWVOmcd7/Q==} + /vite-plugin-ruby/3.2.2_vite@4.4.3: + resolution: {integrity: sha512-cuHG1MajRWPR8YdfF6lvgsQRnKFEBRwZF//asFbRiI1psacxB5aPlHSvYZYxAu5IflrAa0MdR0HxEq+g98M3iQ==} peerDependencies: - vite: '>=2.5.0' + vite: '>=4.0.0' dependencies: - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 fast-glob: 3.3.0 - vite: 4.3.9(@types/node@18.16.19) + vite: 4.4.3 transitivePeerDependencies: - supports-color dev: true - /vite-plugin-solid@2.5.0(solid-js@1.5.2)(vite@4.3.9): - resolution: {integrity: sha512-VneGd3RyFJvwaiffsqgymeMaofn0IzQLPwDzafTV2f1agoWeeJlk5VrI5WqT9BTtLe69vNNbCJWqLhHr9fOdDw==} + /vite-plugin-solid/2.7.0_solid-js@1.7.8+vite@4.4.3: + resolution: {integrity: sha512-avp/Jl5zOp/Itfo67xtDB2O61U7idviaIp4mLsjhCa13PjKNasz+IID0jYTyqUp9SFx6/PmBr6v4KgDppqompg==} peerDependencies: - solid-js: ^1.3.17 || ^1.4.0 || ^1.5.0 || ^1.6.0 + solid-js: ^1.7.2 vite: ^3.0.0 || ^4.0.0 dependencies: - '@babel/core': 7.20.5 - '@babel/preset-typescript': 7.18.6(@babel/core@7.20.5) - babel-preset-solid: 1.6.3(@babel/core@7.20.5) - merge-anything: 5.1.4 - solid-js: 1.5.2 - solid-refresh: 0.4.1(solid-js@1.5.2) - vite: 4.3.9(@types/node@18.16.19) - vitefu: 0.2.3(vite@4.3.9) + '@babel/core': 7.22.8 + '@babel/preset-typescript': 7.22.5_@babel+core@7.22.8 + '@types/babel__core': 7.20.1 + babel-preset-solid: 1.7.7_@babel+core@7.22.8 + merge-anything: 5.1.7 + solid-js: 1.7.8 + solid-refresh: 0.5.3_solid-js@1.7.8 + vite: 4.4.3 + vitefu: 0.2.4_vite@4.4.3 transitivePeerDependencies: - supports-color dev: true - /vite@4.3.9(@types/node@18.16.19): - resolution: {integrity: sha512-qsTNZjO9NoJNW7KnOrgYwczm0WctJ8m/yqYAMAK9Lxt4SoySUfS5S8ia9K7JHpa3KEeMfyF8LoJ3c5NeBJy6pg==} + /vite/4.4.3: + resolution: {integrity: sha512-IMnXQXXWgLi5brBQx/4WzDxdzW0X3pjO4nqFJAuNvwKtxzAmPzFE1wszW3VDpAGQJm3RZkm/brzRdyGsnwgJIA==} engines: {node: ^14.18.0 || >=16.0.0} hasBin: true peerDependencies: '@types/node': '>= 14' less: '*' + lightningcss: ^1.21.0 sass: '*' stylus: '*' sugarss: '*' @@ -24704,6 +21719,8 @@ packages: optional: true less: optional: true + lightningcss: + optional: true sass: optional: true stylus: @@ -24713,20 +21730,20 @@ packages: terser: optional: true dependencies: - '@types/node': 18.16.19 - esbuild: 0.17.18 - postcss: 8.4.24 - rollup: 3.23.0 + esbuild: 0.18.11 + postcss: 8.4.25 + rollup: 3.26.2 optionalDependencies: fsevents: 2.3.2 - /vite@4.3.9(@types/node@18.7.13): - resolution: {integrity: sha512-qsTNZjO9NoJNW7KnOrgYwczm0WctJ8m/yqYAMAK9Lxt4SoySUfS5S8ia9K7JHpa3KEeMfyF8LoJ3c5NeBJy6pg==} + /vite/4.4.3_@types+node@18.16.19: + resolution: {integrity: sha512-IMnXQXXWgLi5brBQx/4WzDxdzW0X3pjO4nqFJAuNvwKtxzAmPzFE1wszW3VDpAGQJm3RZkm/brzRdyGsnwgJIA==} engines: {node: ^14.18.0 || >=16.0.0} hasBin: true peerDependencies: '@types/node': '>= 14' less: '*' + lightningcss: ^1.21.0 sass: '*' stylus: '*' sugarss: '*' @@ -24736,6 +21753,8 @@ packages: optional: true less: optional: true + lightningcss: + optional: true sass: optional: true stylus: @@ -24745,21 +21764,22 @@ packages: terser: optional: true dependencies: - '@types/node': 18.7.13 - esbuild: 0.17.18 - postcss: 8.4.24 - rollup: 3.23.0 + '@types/node': 18.16.19 + esbuild: 0.18.11 + postcss: 8.4.25 + rollup: 3.26.2 optionalDependencies: fsevents: 2.3.2 - dev: false + dev: true - /vite@4.3.9(@types/node@20.4.1): - resolution: {integrity: sha512-qsTNZjO9NoJNW7KnOrgYwczm0WctJ8m/yqYAMAK9Lxt4SoySUfS5S8ia9K7JHpa3KEeMfyF8LoJ3c5NeBJy6pg==} + /vite/4.4.3_@types+node@20.4.1: + resolution: {integrity: sha512-IMnXQXXWgLi5brBQx/4WzDxdzW0X3pjO4nqFJAuNvwKtxzAmPzFE1wszW3VDpAGQJm3RZkm/brzRdyGsnwgJIA==} engines: {node: ^14.18.0 || >=16.0.0} hasBin: true peerDependencies: '@types/node': '>= 14' less: '*' + lightningcss: ^1.21.0 sass: '*' stylus: '*' sugarss: '*' @@ -24769,6 +21789,8 @@ packages: optional: true less: optional: true + lightningcss: + optional: true sass: optional: true stylus: @@ -24779,25 +21801,14 @@ packages: optional: true dependencies: '@types/node': 20.4.1 - esbuild: 0.17.18 - postcss: 8.4.24 - rollup: 3.23.0 + esbuild: 0.18.11 + postcss: 8.4.25 + rollup: 3.26.2 optionalDependencies: fsevents: 2.3.2 - dev: true - - /vitefu@0.2.3(vite@4.3.9): - resolution: {integrity: sha512-75l7TTuU8isAhz1QFtNKjDkqjxvndfMC1AfIMjJ0ZQ59ZD0Ow9QOIsJJX16Wv9PS8f+zMzp6fHy5cCbKG/yVUQ==} - peerDependencies: - vite: ^3.0.0 || ^4.0.0 - peerDependenciesMeta: - vite: - optional: true - dependencies: - vite: 4.3.9(@types/node@18.16.19) - dev: true + dev: false - /vitefu@0.2.4(vite@4.3.9): + /vitefu/0.2.4_vite@4.4.3: resolution: {integrity: sha512-fanAXjSaf9xXtOOeno8wZXIhgia+CZury481LsDaV++lSvcU2R9Ch2bPh3PYFyoHW+w9LqAeYRISVQjUIew14g==} peerDependencies: vite: ^3.0.0 || ^4.0.0 @@ -24805,25 +21816,25 @@ packages: vite: optional: true dependencies: - vite: 4.3.9(@types/node@18.16.19) + vite: 4.4.3 dev: true - /vitepress@1.0.0-beta.5(@types/node@18.16.19)(search-insights@2.6.0): + /vitepress/1.0.0-beta.5: resolution: {integrity: sha512-/RjqqRsSEKkzF6HhK5e5Ij+bZ7ETb9jNCRRgIMm10gJ+ZLC3D1OqkE465lEqCeJUgt2HZ6jmWjDqIBfrJSpv7w==} hasBin: true dependencies: '@docsearch/css': 3.5.1 - '@docsearch/js': 3.5.1(search-insights@2.6.0) - '@vitejs/plugin-vue': 4.2.3(vite@4.3.9)(vue@3.3.4) + '@docsearch/js': 3.5.1 + '@vitejs/plugin-vue': 4.2.3_vite@4.4.3+vue@3.3.4 '@vue/devtools-api': 6.5.0 - '@vueuse/core': 10.2.1(vue@3.3.4) - '@vueuse/integrations': 10.2.1(focus-trap@7.4.3)(vue@3.3.4) + '@vueuse/core': 10.2.1_vue@3.3.4 + '@vueuse/integrations': 10.2.1_focus-trap@7.5.2+vue@3.3.4 body-scroll-lock: 4.0.0-beta.0 - focus-trap: 7.4.3 + focus-trap: 7.5.2 mark.js: 8.11.1 minisearch: 6.1.0 shiki: 0.14.3 - vite: 4.3.9(@types/node@18.16.19) + vite: 4.4.3 vue: 3.3.4 transitivePeerDependencies: - '@algolia/client-search' @@ -24838,6 +21849,7 @@ packages: - idb-keyval - jwt-decode - less + - lightningcss - nprogress - qrcode - react @@ -24851,7 +21863,7 @@ packages: - universal-cookie dev: true - /vitest-sonar-reporter@0.3.3(vitest@packages+vitest): + /vitest-sonar-reporter/0.3.3_vitest@packages+vitest: resolution: {integrity: sha512-OvH+AYMgDFk3SK7sohn5KUHUOhB42tWgSTW7YzB/v/dN3x+7bgXD2L0FZpDYjC1hvBMJJ4HFqOsiO9LsETmgxg==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} peerDependencies: @@ -24861,49 +21873,23 @@ packages: vitest: link:packages/vitest dev: true - /vm-browserify@1.1.2: + /vm-browserify/1.1.2: resolution: {integrity: sha512-2ham8XPWTONajOR0ohOKOHXkm3+gaBmGut3SRuu75xLd/RRaY6vqgh8NBYYk7+RW3u5AtzPQZG8F10LHkl0lAQ==} dev: true - /vscode-oniguruma@1.7.0: + /vscode-oniguruma/1.7.0: resolution: {integrity: sha512-L9WMGRfrjOhgHSdOYgCt/yRMsXzLDJSL7BPrOZt73gU0iWO4mpqzqQzOz5srxqTvMBaR0XZTSrVWo4j55Rc6cA==} dev: true - /vscode-textmate@8.0.0: + /vscode-textmate/8.0.0: resolution: {integrity: sha512-AFbieoL7a5LMqcnOF04ji+rpXadgOXnZsxQr//r83kLPr7biP7am3g9zbaZIaBGwBRWeSvoMD4mgPdX3e4NWBg==} dev: true - /vue-demi@0.13.11(vue@3.2.39): - resolution: {integrity: sha512-IR8HoEEGM65YY3ZJYAjMlKygDQn25D5ajNFNoKh9RSDMQtlzCxtfQjdQgv9jjK+m3377SsJXY8ysq8kLCZL25A==} - engines: {node: '>=12'} - hasBin: true - requiresBuild: true - peerDependencies: - '@vue/composition-api': ^1.0.0-rc.1 - vue: ^3.0.0-0 || ^2.6.0 - peerDependenciesMeta: - '@vue/composition-api': - optional: true - dependencies: - vue: 3.2.39 - dev: false - - /vue-demi@0.14.0(vue@3.2.39): - resolution: {integrity: sha512-gt58r2ogsNQeVoQ3EhoUAvUsH9xviydl0dWJj7dabBC/2L4uBId7ujtCwDRD0JhkGsV1i0CtfLAeyYKBht9oWg==} - engines: {node: '>=12'} - hasBin: true - requiresBuild: true - peerDependencies: - '@vue/composition-api': ^1.0.0-rc.1 - vue: ^3.0.0-0 || ^2.6.0 - peerDependenciesMeta: - '@vue/composition-api': - optional: true - dependencies: - vue: 3.2.39 - dev: false + /vue-component-type-helpers/1.6.5: + resolution: {integrity: sha512-iGdlqtajmiqed8ptURKPJ/Olz0/mwripVZszg6tygfZSIL9kYFPJTNY6+Q6OjWGznl2L06vxG5HvNvAnWrnzbg==} + dev: true - /vue-demi@0.14.5(vue@3.3.4): + /vue-demi/0.14.5_vue@3.3.4: resolution: {integrity: sha512-o9NUVpl/YlsGJ7t+xuqJKx8EBGf1quRhCiT6D/J0pfwmk9zUwYkC7yrF4SZCe6fETvSM3UNL2edcbYrSyc4QHA==} engines: {node: '>=12'} hasBin: true @@ -24917,17 +21903,17 @@ packages: dependencies: vue: 3.3.4 - /vue-eslint-parser@9.3.1(eslint@8.44.0): + /vue-eslint-parser/9.3.1_eslint@8.44.0: resolution: {integrity: sha512-Clr85iD2XFZ3lJ52/ppmUDG/spxQu6+MAeHXjjyI4I1NUYZ9xmenQp4N0oaHJhrA8OOxltCVxMRfANGa70vU0g==} engines: {node: ^14.17.0 || >=16.0.0} peerDependencies: eslint: '>=6.0.0' dependencies: - debug: 4.3.4(supports-color@8.1.1) + debug: 4.3.4 eslint: 8.44.0 eslint-scope: 7.2.0 eslint-visitor-keys: 3.4.1 - espree: 9.5.2 + espree: 9.6.0 esquery: 1.5.0 lodash: 4.17.21 semver: 7.5.4 @@ -24935,7 +21921,7 @@ packages: - supports-color dev: true - /vue-resize@2.0.0-alpha.1(vue@3.3.4): + /vue-resize/2.0.0-alpha.1_vue@3.3.4: resolution: {integrity: sha512-7+iqOueLU7uc9NrMfrzbG8hwMqchfVfSzpVlCMeJQe4pyibqyoifDNbKTZvwxZKDvGkB+PdFeKvnGZMoEb8esg==} peerDependencies: vue: ^3.0.0 @@ -24943,8 +21929,8 @@ packages: vue: 3.3.4 dev: true - /vue-router@4.2.2(vue@3.3.4): - resolution: {integrity: sha512-cChBPPmAflgBGmy3tBsjeoe3f3VOSG6naKyY5pjtrqLGbNEXdzCigFUHgBvp9e3ysAtFtEx7OLqcSDh/1Cq2TQ==} + /vue-router/4.2.4_vue@3.3.4: + resolution: {integrity: sha512-9PISkmaCO02OzPVOMq2w82ilty6+xJmQrarYZDkjZBfl4RvYAlt4PKnEX21oW4KTtWfa9OuO/b3qk1Od3AEdCQ==} peerDependencies: vue: ^3.2.0 dependencies: @@ -24952,15 +21938,15 @@ packages: vue: 3.3.4 dev: true - /vue-template-compiler@2.7.10: - resolution: {integrity: sha512-QO+8R9YRq1Gudm8ZMdo/lImZLJVUIAM8c07Vp84ojdDAf8HmPJc7XB556PcXV218k2AkKznsRz6xB5uOjAC4EQ==} + /vue-template-compiler/2.7.14: + resolution: {integrity: sha512-zyA5Y3ArvVG0NacJDkkzJuPQDF8RFeRlzV2vLeSnhSpieO6LK2OVbdLPi5MPPs09Ii+gMO8nY4S3iKQxBxDmWQ==} dependencies: de-indent: 1.0.2 he: 1.2.0 - vue: 2.7.10 + vue: 2.7.14 dev: true - /vue-tsc@0.40.13(typescript@4.8.4): + /vue-tsc/0.40.13_typescript@4.9.5: resolution: {integrity: sha512-xzuN3g5PnKfJcNrLv4+mAjteMd5wLm5fRhW0034OfNJZY4WhB07vhngea/XeGn7wNYt16r7syonzvW/54dcNiA==} hasBin: true peerDependencies: @@ -24968,67 +21954,38 @@ packages: dependencies: '@volar/vue-language-core': 0.40.13 '@volar/vue-typescript': 0.40.13 - typescript: 4.8.4 + typescript: 4.9.5 dev: true - /vue@2.7.10: - resolution: {integrity: sha512-HmFC70qarSHPXcKtW8U8fgIkF6JGvjEmDiVInTkKZP0gIlEPhlVlcJJLkdGIDiNkIeA2zJPQTWJUI4iWe+AVfg==} - dependencies: - '@vue/compiler-sfc': 2.7.10 - csstype: 3.1.0 - - /vue@3.2.39: - resolution: {integrity: sha512-tRkguhRTw9NmIPXhzk21YFBqXHT2t+6C6wPOgQ50fcFVWnPdetmRqbmySRHznrYjX2E47u0cGlKGcxKZJ38R/g==} + /vue/2.7.14: + resolution: {integrity: sha512-b2qkFyOM0kwqWFuQmgd4o+uHGU7T+2z3T+WQp8UBjADfEv2n4FEMffzBmCKNP0IGzOEEfYjvtcC62xaSKeQDrQ==} dependencies: - '@vue/compiler-dom': 3.2.39 - '@vue/compiler-sfc': 3.2.39 - '@vue/runtime-dom': 3.2.39 - '@vue/server-renderer': 3.2.39(vue@3.2.39) - '@vue/shared': 3.2.39 + '@vue/compiler-sfc': 2.7.14 + csstype: 3.1.2 - /vue@3.3.4: + /vue/3.3.4: resolution: {integrity: sha512-VTyEYn3yvIeY1Py0WaYGZsXnz3y5UnGi62GjVEqvEGPl6nxbOrCXbVOTQWBEJUqAyTUk2uJ5JLVnYJ6ZzGbrSw==} dependencies: '@vue/compiler-dom': 3.3.4 '@vue/compiler-sfc': 3.3.4 '@vue/runtime-dom': 3.3.4 - '@vue/server-renderer': 3.3.4(vue@3.3.4) + '@vue/server-renderer': 3.3.4_vue@3.3.4 '@vue/shared': 3.3.4 - /w3c-hr-time@1.0.2: - resolution: {integrity: sha512-z8P5DvDNjKDoFIHK7q8r8lackT6l+jo/Ye3HOle7l9nICP9lf1Ci25fy9vHd0JOWewkIFzXIEig3TdKT7JQ5fQ==} - dependencies: - browser-process-hrtime: 1.0.0 - dev: true - - /w3c-xmlserializer@2.0.0: - resolution: {integrity: sha512-4tzD0mF8iSiMiNs30BiLO3EpfGLZUT2MSX/G+o7ZywDzliWQ3OPtTZ0PTC3B3ca1UAf4cJMHB+2Bf56EriJuRA==} - engines: {node: '>=10'} - dependencies: - xml-name-validator: 3.0.0 - dev: true - - /w3c-xmlserializer@3.0.0: - resolution: {integrity: sha512-3WFqGEgSXIyGhOmAFtlicJNMjEps8b1MG31NCA0/vOF9+nKMUW1ckhi9cnNHmf88Rzw5V+dwIwsm2C7X8k9aQg==} - engines: {node: '>=12'} - dependencies: - xml-name-validator: 4.0.0 - dev: true - - /w3c-xmlserializer@4.0.0: + /w3c-xmlserializer/4.0.0: resolution: {integrity: sha512-d+BFHzbiCx6zGfz0HyQ6Rg69w9k19nviJspaj4yNscGjrHu94sVP+aRm75yEbCh+r2/yR+7q6hux9LVtbuTGBw==} engines: {node: '>=14'} dependencies: xml-name-validator: 4.0.0 dev: true - /walker@1.0.8: + /walker/1.0.8: resolution: {integrity: sha512-ts/8E8l5b7kY0vlWLewOkDXMmPdLcVV4GmOQLyxuSswIJsweeFZtAsMF7k1Nszz+TYBQrlYRmzOnr398y1JemQ==} dependencies: makeerror: 1.0.12 dev: true - /watchpack-chokidar2@2.0.1: + /watchpack-chokidar2/2.0.1: resolution: {integrity: sha512-nCFfBIPKr5Sh61s4LPpy1Wtfi0HE8isJ3d2Yb5/Ppw2P2B/3eVSEBjKfN0fmHJSK14+31KwMKmcrzs2GM4P0Ww==} requiresBuild: true dependencies: @@ -25038,10 +21995,10 @@ packages: dev: true optional: true - /watchpack@1.7.5: + /watchpack/1.7.5: resolution: {integrity: sha512-9P3MWk6SrKjHsGkLT2KHXdQ/9SNkyoJbabxnKOoJepsvJjJG8uYTR3yTPxPQvNDI3w4Nz1xnE0TLHK4RIVe/MQ==} dependencies: - graceful-fs: 4.2.10 + graceful-fs: 4.2.11 neo-async: 2.6.2 optionalDependencies: chokidar: 3.5.3 @@ -25050,27 +22007,27 @@ packages: - supports-color dev: true - /watchpack@2.4.0: + /watchpack/2.4.0: resolution: {integrity: sha512-Lcvm7MGST/4fup+ifyKi2hjyIAwcdI4HRgtvTpIUxBRhB+RFtUh8XtDOxUfctVCnhVi+QQj49i91OyvzkJl6cg==} engines: {node: '>=10.13.0'} dependencies: glob-to-regexp: 0.4.1 - graceful-fs: 4.2.10 + graceful-fs: 4.2.11 dev: true - /wbuf@1.7.3: + /wbuf/1.7.3: resolution: {integrity: sha512-O84QOnr0icsbFGLS0O3bI5FswxzRr8/gHwWkDlQFskhSPryQXvrTMxjxGP4+iWYoauLoBvfDpkrOauZ+0iZpDA==} dependencies: minimalistic-assert: 1.0.1 dev: true - /wcwidth@1.0.1: + /wcwidth/1.0.1: resolution: {integrity: sha512-XHPEwS0q6TaxcvG85+8EYkbiCux2XtWG2mkc47Ng2A77BQu9+DqIOJldST4HgPkuea7dvKSj5VgX3P1d4rW8Tg==} dependencies: - defaults: 1.0.3 + defaults: 1.0.4 dev: true - /web-encoding@1.1.5: + /web-encoding/1.1.5: resolution: {integrity: sha512-HYLeVCdJ0+lBYV2FvNZmv3HJ2Nt0QYXqZojk3d9FJOLkwnuhzM9tmamh8d7HPM8QqjKH8DeHkFTx+CFlWpZZDA==} dependencies: util: 0.12.5 @@ -25078,11 +22035,11 @@ packages: '@zxing/text-encoding': 0.9.0 dev: true - /web-namespaces@1.1.4: + /web-namespaces/1.1.4: resolution: {integrity: sha512-wYxSGajtmoP4WxfejAPIr4l0fVh+jeMXZb08wNc0tMg6xsfZXj3cECqIK0G7ZAqUq0PP8WlMDtaOGVBTAWztNw==} dev: true - /webdriver@8.12.1: + /webdriver/8.12.1: resolution: {integrity: sha512-Ca+MUYUXfl5gsnX40xAIUgfoa76qQsfX7REGFzMl09Cb7vHKtM17bEOGDaTbXIX4kbkXylyUSAuBpe3gCtDDKg==} engines: {node: ^16.13 || >=18} dependencies: @@ -25093,7 +22050,7 @@ packages: '@wdio/protocols': 8.11.0 '@wdio/types': 8.10.4 '@wdio/utils': 8.12.1 - deepmerge-ts: 5.0.0 + deepmerge-ts: 5.1.0 got: 12.6.1 ky: 0.33.3 ws: 8.13.0 @@ -25102,7 +22059,7 @@ packages: - utf-8-validate dev: true - /webdriverio@8.12.1(typescript@5.1.6): + /webdriverio/8.12.1: resolution: {integrity: sha512-lW0Qo3fy64cVbYWWAZbXxLIOK0pbTARgpY89J+0Sr6zh2K2NKtd/0D11k3WfMeYxd0b0he7E7XC1b6M6w4h75A==} engines: {node: ^16.13 || >=18} dependencies: @@ -25117,15 +22074,15 @@ packages: aria-query: 5.3.0 css-shorthand-properties: 1.1.1 css-value: 0.0.1 - devtools: 8.12.1(typescript@5.1.6) + devtools: 8.12.1 devtools-protocol: 0.0.1161598 grapheme-splitter: 1.0.4 import-meta-resolve: 3.0.0 is-plain-obj: 4.1.0 lodash.clonedeep: 4.5.0 lodash.zip: 4.2.0 - minimatch: 9.0.1 - puppeteer-core: 20.3.0(typescript@5.1.6) + minimatch: 9.0.3 + puppeteer-core: 20.3.0 query-selector-shadow-dom: 1.0.1 resq: 1.11.0 rgb2hex: 0.2.5 @@ -25139,29 +22096,19 @@ packages: - utf-8-validate dev: true - /webidl-conversions@3.0.1: + /webidl-conversions/3.0.1: resolution: {integrity: sha512-2JAn3z8AR6rjK8Sm8orRC0h/bcl/DqL7tRPdGZ4I1CjdF+EaMLmYxBHyXuKL849eucPFhvBoxMsflfOb8kxaeQ==} - /webidl-conversions@4.0.2: + /webidl-conversions/4.0.2: resolution: {integrity: sha512-YQ+BmxuTgd6UXZW3+ICGfyqRyHXVlD5GtQr5+qjiNW7bF0cqrzX500HVXPBOvgXb5YnzDd+h0zqyv61KUD7+Sg==} dev: true - /webidl-conversions@5.0.0: - resolution: {integrity: sha512-VlZwKPCkYKxQgeSbH5EyngOmRp7Ww7I9rQLERETtf5ofd9pGeswWiOtogpEO850jziPRarreGxn5QIiTqpb2wA==} - engines: {node: '>=8'} - dev: true - - /webidl-conversions@6.1.0: - resolution: {integrity: sha512-qBIvFLGiBpLjfwmYAaHPXsn+ho5xZnGvyGvsarywGNc8VyQJUMHJ8OBKGGrPER0okBeMDaan4mNBlgBROxuI8w==} - engines: {node: '>=10.4'} - dev: true - - /webidl-conversions@7.0.0: + /webidl-conversions/7.0.0: resolution: {integrity: sha512-VwddBukDzu71offAQR975unBIGqfKZpM+8ZX6ySk8nYhVoo5CYaZyzt3YBvYtRtO+aoGlqxPg/B87NGVZ/fu6g==} engines: {node: '>=12'} dev: true - /webpack-dev-middleware@3.7.3(webpack@4.46.0): + /webpack-dev-middleware/3.7.3_webpack@4.46.0: resolution: {integrity: sha512-djelc/zGiz9nZj/U7PTBi2ViorGJXEWo/3ltkPbDyxCXhhEXkW0ce99falaok4TPj+AsxLiXJR0EBOb0zh9fKQ==} engines: {node: '>= 6'} peerDependencies: @@ -25175,7 +22122,7 @@ packages: webpack-log: 2.0.0 dev: true - /webpack-filter-warnings-plugin@1.2.1(webpack@4.46.0): + /webpack-filter-warnings-plugin/1.2.1_webpack@4.46.0: resolution: {integrity: sha512-Ez6ytc9IseDMLPo0qCuNNYzgtUl8NovOqjIq4uAU8LTD4uoa1w1KpZyyzFtLTEMZpkkOkLfL9eN+KGYdk1Qtwg==} engines: {node: '>= 4.3 < 5.0.0 || >= 5.10'} peerDependencies: @@ -25184,15 +22131,15 @@ packages: webpack: 4.46.0 dev: true - /webpack-hot-middleware@2.25.2: - resolution: {integrity: sha512-CVgm3NAQyfdIonRvXisRwPTUYuSbyZ6BY7782tMeUzWOO7RmVI2NaBYuCp41qyD4gYCkJyTneAJdK69A13B0+A==} + /webpack-hot-middleware/2.25.4: + resolution: {integrity: sha512-IRmTspuHM06aZh98OhBJtqLpeWFM8FXJS5UYpKYxCJzyFoyWj1w6VGFfomZU7OPA55dMLrQK0pRT1eQ3PACr4w==} dependencies: ansi-html-community: 0.0.8 - html-entities: 2.3.3 + html-entities: 2.4.0 strip-ansi: 6.0.1 dev: true - /webpack-log@2.0.0: + /webpack-log/2.0.0: resolution: {integrity: sha512-cX8G2vR/85UYG59FgkoMamwHUIkSSlV3bBMRsbxVXVUk2j6NleCKjQ/WE9eYg9WY4w25O9w8wKP4rzNZFmUcUg==} engines: {node: '>= 6'} dependencies: @@ -25200,31 +22147,31 @@ packages: uuid: 3.4.0 dev: true - /webpack-sources@1.4.3: + /webpack-sources/1.4.3: resolution: {integrity: sha512-lgTS3Xhv1lCOKo7SA5TjKXMjpSM4sBjNV5+q2bqesbSPs5FjGmU6jjtBSkX9b4qW87vDIsCIlUPOEhbZrMdjeQ==} dependencies: source-list-map: 2.0.1 source-map: 0.6.1 dev: true - /webpack-sources@3.2.3: + /webpack-sources/3.2.3: resolution: {integrity: sha512-/DyMEOrDgLKKIG0fmvtz+4dUX/3Ghozwgm6iPp8KRhvn+eQf9+Q7GWxVNMk3+uCPWfdXYC4ExGBckIXdFEfH1w==} engines: {node: '>=10.13.0'} dev: true - /webpack-virtual-modules@0.2.2: + /webpack-virtual-modules/0.2.2: resolution: {integrity: sha512-kDUmfm3BZrei0y+1NTHJInejzxfhtU8eDj2M7OKb2IWrPFAeO1SOH2KuQ68MSZu9IGEHcxbkKKR1v18FrUSOmA==} dependencies: - debug: 3.2.7(supports-color@8.1.1) + debug: 3.2.7 transitivePeerDependencies: - supports-color dev: true - /webpack-virtual-modules@0.5.0: + /webpack-virtual-modules/0.5.0: resolution: {integrity: sha512-kyDivFZ7ZM0BVOUteVbDFhlRt7Ah/CSPwJdi8hBpkK7QLumUqdLtVfm/PX/hkcnrvr0i77fO5+TjZ94Pe+C9iw==} dev: true - /webpack@4.46.0: + /webpack/4.46.0: resolution: {integrity: sha512-6jJuJjg8znb/xRItk7bkT0+Q7AHCYjjFnvKIWQPkNIOyRqoCGvkOs0ipeQzrqz4l5FtN5ZI/ukEHroeX/o1/5Q==} engines: {node: '>=6.11.5'} hasBin: true @@ -25243,13 +22190,13 @@ packages: '@webassemblyjs/wasm-parser': 1.9.0 acorn: 6.4.2 ajv: 6.12.6 - ajv-keywords: 3.5.2(ajv@6.12.6) + ajv-keywords: 3.5.2_ajv@6.12.6 chrome-trace-event: 1.0.3 enhanced-resolve: 4.5.0 eslint-scope: 4.0.3 json-parse-better-errors: 1.0.2 loader-runner: 2.4.0 - loader-utils: 1.4.0 + loader-utils: 1.4.2 memory-fs: 0.4.1 micromatch: 3.1.10 mkdirp: 0.5.6 @@ -25257,15 +22204,15 @@ packages: node-libs-browser: 2.2.1 schema-utils: 1.0.0 tapable: 1.1.3 - terser-webpack-plugin: 1.4.5(webpack@4.46.0) + terser-webpack-plugin: 1.4.5_webpack@4.46.0 watchpack: 1.7.5 webpack-sources: 1.4.3 transitivePeerDependencies: - supports-color dev: true - /webpack@5.74.0(esbuild@0.18.11): - resolution: {integrity: sha512-A2InDwnhhGN4LYctJj6M1JEaGL7Luj6LOmyBHjcI8529cm5p6VXiTIW2sn6ffvEAKmveLzvu4jrihwXtPojlAA==} + /webpack/5.88.1: + resolution: {integrity: sha512-FROX3TxQnC/ox4N+3xQoWZzvGXSuscxR32rbzjpXgEzWudJFEJBpdlkkob2ylrv5yzzufD1zph1OoFsLtm6stQ==} engines: {node: '>=10.13.0'} hasBin: true peerDependencies: @@ -25275,27 +22222,27 @@ packages: optional: true dependencies: '@types/eslint-scope': 3.7.4 - '@types/estree': 0.0.51 - '@webassemblyjs/ast': 1.11.1 - '@webassemblyjs/wasm-edit': 1.11.1 - '@webassemblyjs/wasm-parser': 1.11.1 - acorn: 8.9.0 - acorn-import-assertions: 1.8.0(acorn@8.9.0) - browserslist: 4.21.3 + '@types/estree': 1.0.1 + '@webassemblyjs/ast': 1.11.6 + '@webassemblyjs/wasm-edit': 1.11.6 + '@webassemblyjs/wasm-parser': 1.11.6 + acorn: 8.10.0 + acorn-import-assertions: 1.9.0_acorn@8.10.0 + browserslist: 4.21.9 chrome-trace-event: 1.0.3 - enhanced-resolve: 5.10.0 - es-module-lexer: 0.9.3 + enhanced-resolve: 5.15.0 + es-module-lexer: 1.3.0 eslint-scope: 5.1.1 events: 3.3.0 glob-to-regexp: 0.4.1 - graceful-fs: 4.2.10 + graceful-fs: 4.2.11 json-parse-even-better-errors: 2.3.1 loader-runner: 4.3.0 mime-types: 2.1.35 neo-async: 2.6.2 - schema-utils: 3.1.1 + schema-utils: 3.3.0 tapable: 2.2.1 - terser-webpack-plugin: 5.3.6(esbuild@0.18.11)(webpack@5.74.0) + terser-webpack-plugin: 5.3.9_webpack@5.88.1 watchpack: 2.4.0 webpack-sources: 3.2.3 transitivePeerDependencies: @@ -25304,29 +22251,19 @@ packages: - uglify-js dev: true - /whatwg-encoding@1.0.5: - resolution: {integrity: sha512-b5lim54JOPN9HtzvK9HFXvBma/rnfFeqsic0hSpjtDbVxR3dJKLc+KB4V6GgiGOvl7CY/KNh8rxSo9DKQrnUEw==} - dependencies: - iconv-lite: 0.4.24 - dev: true - - /whatwg-encoding@2.0.0: + /whatwg-encoding/2.0.0: resolution: {integrity: sha512-p41ogyeMUrw3jWclHWTQg1k05DSVXPLcVxRTYsXUk+ZooOCZLcoYgPZ/HL/D/N+uQPOtcp1me1WhBEaX02mhWg==} engines: {node: '>=12'} dependencies: iconv-lite: 0.6.3 dev: true - /whatwg-mimetype@2.3.0: - resolution: {integrity: sha512-M4yMwr6mAnQz76TbJm914+gPpB/nCwvZbJU28cUD6dR004SAxDLOOSUaB1JDRqLtaOV/vi0IC5lEAGFgrjGv/g==} - dev: true - - /whatwg-mimetype@3.0.0: + /whatwg-mimetype/3.0.0: resolution: {integrity: sha512-nt+N2dzIutVRxARx1nghPKGv1xHikU7HKdfafKkLNLindmPU/ch3U31NOCGGA/dmPcmb1VlofO0vnKAcsm0o/Q==} engines: {node: '>=12'} dev: true - /whatwg-url@11.0.0: + /whatwg-url/11.0.0: resolution: {integrity: sha512-RKT8HExMpoYx4igMiVMY83lN6UeITKJlBQ+vR/8ZJ8OCdSiN3RwCq+9gH0+Xzj0+5IrM6i4j/6LuvzbZIQgEcQ==} engines: {node: '>=12'} dependencies: @@ -25334,7 +22271,7 @@ packages: webidl-conversions: 7.0.0 dev: true - /whatwg-url@12.0.1: + /whatwg-url/12.0.1: resolution: {integrity: sha512-Ed/LrqB8EPlGxjS+TrsXcpUond1mhccS3pchLhzSgPCnTimUCKj3IZE75pAs5m6heB2U2TMerKFUXheyHY+VDQ==} engines: {node: '>=14'} dependencies: @@ -25342,13 +22279,13 @@ packages: webidl-conversions: 7.0.0 dev: true - /whatwg-url@5.0.0: + /whatwg-url/5.0.0: resolution: {integrity: sha512-saE57nupxk6v3HY35+jzBwYa0rKSy0XR8JSxZPwgLr7ys0IBzhGviA1/TUGJLmSVqs8pb9AnvICXEuOHLprYTw==} dependencies: tr46: 0.0.3 webidl-conversions: 3.0.1 - /whatwg-url@7.1.0: + /whatwg-url/7.1.0: resolution: {integrity: sha512-WUu7Rg1DroM7oQvGWfOiAK21n74Gg+T4elXEQYkOhtyLeWiJFoOGLXPKI/9gzIie9CtwVLm8wtw6YJdKyxSjeg==} dependencies: lodash.sortby: 4.7.0 @@ -25356,16 +22293,7 @@ packages: webidl-conversions: 4.0.2 dev: true - /whatwg-url@8.7.0: - resolution: {integrity: sha512-gAojqb/m9Q8a5IV96E3fHJM70AzCkgt4uXYX2O7EmuyOnLrViCQlsEBmF9UQIu3/aeAIp2U17rtbpZWNntQqdg==} - engines: {node: '>=10'} - dependencies: - lodash: 4.17.21 - tr46: 2.1.0 - webidl-conversions: 6.1.0 - dev: true - - /which-boxed-primitive@1.0.2: + /which-boxed-primitive/1.0.2: resolution: {integrity: sha512-bwZdv0AKLpplFY2KZRX6TvyuN7ojjr7lwkg6ml0roIy9YeuSr7JS372qlNW18UQYzgYK9ziGcerWqZOmEn9VNg==} dependencies: is-bigint: 1.0.4 @@ -25375,7 +22303,7 @@ packages: is-symbol: 1.0.4 dev: true - /which-collection@1.0.1: + /which-collection/1.0.1: resolution: {integrity: sha512-W8xeTUwaln8i3K/cY1nGXzdnVZlidBcagyNFtBdD5kxnb4TvGKR7FfSIS3mYpwWS1QUCutfKz8IY8RjftB0+1A==} dependencies: is-map: 2.0.2 @@ -25384,8 +22312,8 @@ packages: is-weakset: 2.0.2 dev: true - /which-typed-array@1.1.9: - resolution: {integrity: sha512-w9c4xkx6mPidwp7180ckYWfMmvxpjlZuIudNtDf4N/tTAUB8VJbX25qZoAsrtGuYNnGw3pa0AXgbGKRB8/EceA==} + /which-typed-array/1.1.10: + resolution: {integrity: sha512-uxoA5vLUfRPdjCuJ1h5LlYdmTLbYfums398v3WLkM+i/Wltl2/XyZpQWKbN++ck5L64SR/grOHqtXCUKmlZPNA==} engines: {node: '>= 0.4'} dependencies: available-typed-arrays: 1.0.5 @@ -25396,14 +22324,14 @@ packages: is-typed-array: 1.1.10 dev: true - /which@1.3.1: + /which/1.3.1: resolution: {integrity: sha512-HxJdYWq1MTIQbJ3nw0cqssHoTNU267KlrDuGZ1WYlxDStUtKUhOaJmh112/TZmHxxUfuJqPXSOm7tDyas0OSIQ==} hasBin: true dependencies: isexe: 2.0.0 dev: true - /which@2.0.2: + /which/2.0.2: resolution: {integrity: sha512-BLI3Tl1TW3Pvl70l3yq3Y64i+awpwXqsGBYWkkqMtnbXgrMD+yj7rhW0kuEDxzJaYXGjEW5ogapKNMEKNMjibA==} engines: {node: '>= 8'} hasBin: true @@ -25411,15 +22339,15 @@ packages: isexe: 2.0.0 dev: true - /which@3.0.0: - resolution: {integrity: sha512-nla//68K9NU6yRiwDY/Q8aU6siKlSs64aEC7+IV56QoAuyQT2ovsJcgGYGyqMOmI/CGN1BOR6mM5EN0FBO+zyQ==} + /which/3.0.1: + resolution: {integrity: sha512-XA1b62dzQzLfaEOSQFTCOd5KFf/1VSzZo7/7TUjnya6u0vGGKzU96UQBZTAThCb2j4/xjBAyii1OhRLJEivHvg==} engines: {node: ^14.17.0 || ^16.13.0 || >=18.0.0} hasBin: true dependencies: isexe: 2.0.0 dev: true - /why-is-node-running@2.2.2: + /why-is-node-running/2.2.2: resolution: {integrity: sha512-6tSwToZxTOcotxHeA+qGCq1mVzKR3CwcJGmVcY+QE8SHy6TnpFnh8PAvPNHYr7EcuVeG0QSMxtYCuO1ta/G/oA==} engines: {node: '>=8'} hasBin: true @@ -25428,54 +22356,49 @@ packages: stackback: 0.0.2 dev: false - /wide-align@1.1.5: + /wide-align/1.1.5: resolution: {integrity: sha512-eDMORYaPNZ4sQIuuYPDHdQvf4gyCF9rEEV/yPxGfwPkRodwEgiMUUXTx/dex+Me0wxx53S+NgUHaP7y3MGlDmg==} dependencies: string-width: 4.2.3 dev: true - /widest-line@3.1.0: + /widest-line/3.1.0: resolution: {integrity: sha512-NsmoXalsWVDMGupxZ5R08ka9flZjjiLvHVAWYOKtiKM8ujtZWr9cRffak+uSE48+Ob8ObalXpwyeUiyDD6QFgg==} engines: {node: '>=8'} dependencies: string-width: 4.2.3 dev: true - /word-wrap@1.2.3: - resolution: {integrity: sha512-Hz/mrNwitNRh/HUAtM/VT/5VH+ygD6DV7mYKZAtHOrbs8U7lvPS6xf7EJKMF0uW1KJCl0H701g3ZGus+muE5vQ==} - engines: {node: '>=0.10.0'} - dev: true - - /wordwrap@1.0.0: + /wordwrap/1.0.0: resolution: {integrity: sha512-gvVzJFlPycKc5dZN4yPkP8w7Dc37BtP1yczEneOb4uq34pXZcvrtRTmWV8W+Ume+XCxKgbjM+nevkyFPMybd4Q==} dev: true - /workbox-background-sync@7.0.0: + /workbox-background-sync/7.0.0: resolution: {integrity: sha512-S+m1+84gjdueM+jIKZ+I0Lx0BDHkk5Nu6a3kTVxP4fdj3gKouRNmhO8H290ybnJTOPfBDtTMXSQA/QLTvr7PeA==} dependencies: idb: 7.1.1 workbox-core: 7.0.0 dev: true - /workbox-broadcast-update@7.0.0: + /workbox-broadcast-update/7.0.0: resolution: {integrity: sha512-oUuh4jzZrLySOo0tC0WoKiSg90bVAcnE98uW7F8GFiSOXnhogfNDGZelPJa+6KpGBO5+Qelv04Hqx2UD+BJqNQ==} dependencies: workbox-core: 7.0.0 dev: true - /workbox-build@7.0.0: + /workbox-build/7.0.0: resolution: {integrity: sha512-CttE7WCYW9sZC+nUYhQg3WzzGPr4IHmrPnjKiu3AMXsiNQKx+l4hHl63WTrnicLmKEKHScWDH8xsGBdrYgtBzg==} engines: {node: '>=16.0.0'} dependencies: - '@apideck/better-ajv-errors': 0.3.6(ajv@8.11.0) - '@babel/core': 7.22.5 - '@babel/preset-env': 7.18.10(@babel/core@7.22.5) - '@babel/runtime': 7.18.9 - '@rollup/plugin-babel': 5.3.1(@babel/core@7.22.5)(rollup@2.79.1) - '@rollup/plugin-node-resolve': 11.2.1(rollup@2.79.1) - '@rollup/plugin-replace': 2.4.2(rollup@2.79.1) + '@apideck/better-ajv-errors': 0.3.6_ajv@8.12.0 + '@babel/core': 7.22.8 + '@babel/preset-env': 7.22.7_@babel+core@7.22.8 + '@babel/runtime': 7.22.6 + '@rollup/plugin-babel': 5.3.1_dk2tutsrvslwzit5bccevt2cya + '@rollup/plugin-node-resolve': 11.2.1_rollup@2.79.1 + '@rollup/plugin-replace': 2.4.2_rollup@2.79.1 '@surma/rollup-plugin-off-main-thread': 2.2.3 - ajv: 8.11.0 + ajv: 8.12.0 common-tags: 1.8.2 fast-json-stable-stringify: 2.1.0 fs-extra: 9.1.0 @@ -25483,7 +22406,7 @@ packages: lodash: 4.17.21 pretty-bytes: 5.6.0 rollup: 2.79.1 - rollup-plugin-terser: 7.0.2(rollup@2.79.1) + rollup-plugin-terser: 7.0.2_rollup@2.79.1 source-map: 0.8.0-beta.0 stringify-object: 3.3.0 strip-comments: 2.0.1 @@ -25509,24 +22432,24 @@ packages: - supports-color dev: true - /workbox-cacheable-response@7.0.0: + /workbox-cacheable-response/7.0.0: resolution: {integrity: sha512-0lrtyGHn/LH8kKAJVOQfSu3/80WDc9Ma8ng0p2i/5HuUndGttH+mGMSvOskjOdFImLs2XZIimErp7tSOPmu/6g==} dependencies: workbox-core: 7.0.0 dev: true - /workbox-core@7.0.0: + /workbox-core/7.0.0: resolution: {integrity: sha512-81JkAAZtfVP8darBpfRTovHg8DGAVrKFgHpOArZbdFd78VqHr5Iw65f2guwjE2NlCFbPFDoez3D3/6ZvhI/rwQ==} dev: true - /workbox-expiration@7.0.0: + /workbox-expiration/7.0.0: resolution: {integrity: sha512-MLK+fogW+pC3IWU9SFE+FRStvDVutwJMR5if1g7oBJx3qwmO69BNoJQVaMXq41R0gg3MzxVfwOGKx3i9P6sOLQ==} dependencies: idb: 7.1.1 workbox-core: 7.0.0 dev: true - /workbox-google-analytics@7.0.0: + /workbox-google-analytics/7.0.0: resolution: {integrity: sha512-MEYM1JTn/qiC3DbpvP2BVhyIH+dV/5BjHk756u9VbwuAhu0QHyKscTnisQuz21lfRpOwiS9z4XdqeVAKol0bzg==} dependencies: workbox-background-sync: 7.0.0 @@ -25535,13 +22458,13 @@ packages: workbox-strategies: 7.0.0 dev: true - /workbox-navigation-preload@7.0.0: + /workbox-navigation-preload/7.0.0: resolution: {integrity: sha512-juWCSrxo/fiMz3RsvDspeSLGmbgC0U9tKqcUPZBCf35s64wlaLXyn2KdHHXVQrb2cqF7I0Hc9siQalainmnXJA==} dependencies: workbox-core: 7.0.0 dev: true - /workbox-precaching@7.0.0: + /workbox-precaching/7.0.0: resolution: {integrity: sha512-EC0vol623LJqTJo1mkhD9DZmMP604vHqni3EohhQVwhJlTgyKyOkMrZNy5/QHfOby+39xqC01gv4LjOm4HSfnA==} dependencies: workbox-core: 7.0.0 @@ -25549,13 +22472,13 @@ packages: workbox-strategies: 7.0.0 dev: true - /workbox-range-requests@7.0.0: + /workbox-range-requests/7.0.0: resolution: {integrity: sha512-SxAzoVl9j/zRU9OT5+IQs7pbJBOUOlriB8Gn9YMvi38BNZRbM+RvkujHMo8FOe9IWrqqwYgDFBfv6sk76I1yaQ==} dependencies: workbox-core: 7.0.0 dev: true - /workbox-recipes@7.0.0: + /workbox-recipes/7.0.0: resolution: {integrity: sha512-DntcK9wuG3rYQOONWC0PejxYYIDHyWWZB/ueTbOUDQgefaeIj1kJ7pdP3LZV2lfrj8XXXBWt+JDRSw1lLLOnww==} dependencies: workbox-cacheable-response: 7.0.0 @@ -25566,49 +22489,49 @@ packages: workbox-strategies: 7.0.0 dev: true - /workbox-routing@7.0.0: + /workbox-routing/7.0.0: resolution: {integrity: sha512-8YxLr3xvqidnbVeGyRGkaV4YdlKkn5qZ1LfEePW3dq+ydE73hUUJJuLmGEykW3fMX8x8mNdL0XrWgotcuZjIvA==} dependencies: workbox-core: 7.0.0 dev: true - /workbox-strategies@7.0.0: + /workbox-strategies/7.0.0: resolution: {integrity: sha512-dg3qJU7tR/Gcd/XXOOo7x9QoCI9nk74JopaJaYAQ+ugLi57gPsXycVdBnYbayVj34m6Y8ppPwIuecrzkpBVwbA==} dependencies: workbox-core: 7.0.0 dev: true - /workbox-streams@7.0.0: + /workbox-streams/7.0.0: resolution: {integrity: sha512-moVsh+5to//l6IERWceYKGiftc+prNnqOp2sgALJJFbnNVpTXzKISlTIsrWY+ogMqt+x1oMazIdHj25kBSq/HQ==} dependencies: workbox-core: 7.0.0 workbox-routing: 7.0.0 dev: true - /workbox-sw@7.0.0: + /workbox-sw/7.0.0: resolution: {integrity: sha512-SWfEouQfjRiZ7GNABzHUKUyj8pCoe+RwjfOIajcx6J5mtgKkN+t8UToHnpaJL5UVVOf5YhJh+OHhbVNIHe+LVA==} dev: true - /workbox-window@7.0.0: + /workbox-window/7.0.0: resolution: {integrity: sha512-j7P/bsAWE/a7sxqTzXo3P2ALb1reTfZdvVp6OJ/uLr/C2kZAMvjeWGm8V4htQhor7DOvYg0sSbFN2+flT5U0qA==} dependencies: - '@types/trusted-types': 2.0.2 + '@types/trusted-types': 2.0.3 workbox-core: 7.0.0 dev: true - /worker-farm@1.7.0: + /worker-farm/1.7.0: resolution: {integrity: sha512-rvw3QTZc8lAxyVrqcSGVm5yP/IJ2UcB3U0graE3LCFoZ0Yn2x4EoVSqJKdB/T5M+FLcRPjz4TDacRf3OCfNUzw==} dependencies: errno: 0.1.8 dev: true - /worker-rpc@0.1.1: + /worker-rpc/0.1.1: resolution: {integrity: sha512-P1WjMrUB3qgJNI9jfmpZ/htmBEjFh//6l/5y8SD9hg1Ef5zTTVVoRjTrTEzPrNBQvmhMxkoTsjOXN10GWU7aCg==} dependencies: microevent.ts: 0.1.1 dev: true - /wrap-ansi@6.2.0: + /wrap-ansi/6.2.0: resolution: {integrity: sha512-r6lPcBGxZXlIcymEu7InxDMhdW0KDxpLgoFLcguasxCaJ/SOIZwINatK9KY/tf+ZrlywOKU0UDj3ATXUBfxJXA==} engines: {node: '>=8'} dependencies: @@ -25617,7 +22540,7 @@ packages: strip-ansi: 6.0.1 dev: true - /wrap-ansi@7.0.0: + /wrap-ansi/7.0.0: resolution: {integrity: sha512-YVGIj2kamLSTxw6NsZjoBxfSwsn0ycdesmc4p+Q21c5zPuZ1pl+NfxVdxPtdHvmNVOQ6XSYG4AUtyt/Fi7D16Q==} engines: {node: '>=10'} dependencies: @@ -25626,8 +22549,8 @@ packages: strip-ansi: 6.0.1 dev: true - /wrap-ansi@8.0.1: - resolution: {integrity: sha512-QFF+ufAqhoYHvoHdajT/Po7KoXVBPXS2bgjIam5isfWJPfIOnQZ50JtUiVvCv/sjgacf3yRrt2ZKUZ/V4itN4g==} + /wrap-ansi/8.1.0: + resolution: {integrity: sha512-si7QWI6zUMq56bESFvagtmzMdGOtoxfR+Sez11Mobfc7tm+VkUckk9bW2UeffTGVUbOksxmSw0AA2gs8g71NCQ==} engines: {node: '>=12'} dependencies: ansi-styles: 6.2.1 @@ -25635,10 +22558,10 @@ packages: strip-ansi: 7.1.0 dev: true - /wrappy@1.0.2: + /wrappy/1.0.2: resolution: {integrity: sha512-l4Sp/DRseor9wL6EvV2+TuQn63dMkPjZ/sp9XkghTEbV9KlPS1xUsZ3u7/IQO4wxtcFB4bgpQPRcR3QCvezPcQ==} - /write-file-atomic@3.0.3: + /write-file-atomic/3.0.3: resolution: {integrity: sha512-AvHcyZ5JnSfq3ioSyjrBkH9yW4m7Ayk8/9My/DD9onKeu/94fwrMocemO2QAJFAlnnDN+ZDS+ZjAR5ua1/PV/Q==} dependencies: imurmurhash: 0.1.4 @@ -25647,33 +22570,7 @@ packages: typedarray-to-buffer: 3.1.5 dev: true - /ws@7.5.9: - resolution: {integrity: sha512-F+P9Jil7UiSKSkppIiD94dN07AwvFixvLIj1Og1Rl9GGMuNipJnV9JzjD6XuqmAeiswGvUmNLjr5cFuXwNS77Q==} - engines: {node: '>=8.3.0'} - peerDependencies: - bufferutil: ^4.0.1 - utf-8-validate: ^5.0.2 - peerDependenciesMeta: - bufferutil: - optional: true - utf-8-validate: - optional: true - dev: true - - /ws@8.11.0: - resolution: {integrity: sha512-HPG3wQd9sNQoT9xHyNCXoDUa+Xw/VevmY9FoHyQ+g+rrMn4j6FB4np7Z0OhdTgjx6MgQLK7jwSy1YecU1+4Asg==} - engines: {node: '>=10.0.0'} - peerDependencies: - bufferutil: ^4.0.1 - utf-8-validate: ^5.0.2 - peerDependenciesMeta: - bufferutil: - optional: true - utf-8-validate: - optional: true - dev: true - - /ws@8.13.0: + /ws/8.13.0: resolution: {integrity: sha512-x9vcZYTrFPC7aSIbj7sRCYo7L/Xb8Iy+pW0ng0wt2vCJv7M9HOMy0UoN3rr+IFC7hb7vXoqS+P9ktyLLLhO+LA==} engines: {node: '>=10.0.0'} peerDependencies: @@ -25685,7 +22582,7 @@ packages: utf-8-validate: optional: true - /ws@8.5.0: + /ws/8.5.0: resolution: {integrity: sha512-BWX0SWVgLPzYwF8lTzEy1egjhS4S4OEAHfsO8o65WOVsrnSRGaSiUaa9e0ggGlkMTtBlmOpEXiie9RUcBO86qg==} engines: {node: '>=10.0.0'} peerDependencies: @@ -25698,52 +22595,48 @@ packages: optional: true dev: true - /x-default-browser@0.4.0: + /x-default-browser/0.4.0: resolution: {integrity: sha512-7LKo7RtWfoFN/rHx1UELv/2zHGMx8MkZKDq1xENmOCTkfIqZJ0zZ26NEJX8czhnPXVcqS0ARjjfJB+eJ0/5Cvw==} hasBin: true optionalDependencies: default-browser-id: 1.0.4 dev: true - /xml-name-validator@3.0.0: - resolution: {integrity: sha512-A5CUptxDsvxKJEU3yO6DuWBSJz/qizqzJKOMIfUJHETbBw/sFaDxgd6fxm1ewUaM0jZ444Fc5vC5ROYurg/4Pw==} - dev: true - - /xml-name-validator@4.0.0: + /xml-name-validator/4.0.0: resolution: {integrity: sha512-ICP2e+jsHvAj2E2lIHxa5tjXRlKDJo4IdvPvCXbXQGdzSfmSpNVyIKMvoZHjDY9DP0zV17iI85o90vRFXNccRw==} engines: {node: '>=12'} dev: true - /xmlchars@2.2.0: + /xmlchars/2.2.0: resolution: {integrity: sha512-JZnDKK8B0RCDw84FNdDAIpZK+JuJw+s7Lz8nksI7SIuU3UXJJslUthsi+uWBUYOwPFwW7W7PRLRfUKpxjtjFCw==} dev: true - /xtend@4.0.2: + /xtend/4.0.2: resolution: {integrity: sha512-LKYU1iAXJXUgAXn9URjiu+MWhyUXHsvfp7mcuYm9dSUKK0/CjtrUwFAxD82/mCWbtLsGjFIad0wIsod4zrTAEQ==} engines: {node: '>=0.4'} dev: true - /y18n@4.0.3: + /y18n/4.0.3: resolution: {integrity: sha512-JKhqTOwSrqNA1NY5lSztJ1GrBiUodLMmIZuLiDaMRJ+itFd+ABVE8XBjOvIWL+rSqNDC74LCSFmlb/U4UZ4hJQ==} dev: true - /y18n@5.0.8: + /y18n/5.0.8: resolution: {integrity: sha512-0pfFzegeDWJHJIAmTLRP2DwHjdF5s7jo9tuztdQxAhINCdvS+3nGINqPd00AphqJR/0LhANUS6/+7SCb98YOfA==} engines: {node: '>=10'} dev: true - /yallist@2.1.2: + /yallist/2.1.2: resolution: {integrity: sha512-ncTzHV7NvsQZkYe1DW7cbDLm0YpzHmZF5r/iyP3ZnQtMiJ+pjzisCiMNI+Sj+xQF5pXhSHxSB3uDbsBTzY/c2A==} dev: true - /yallist@3.1.1: + /yallist/3.1.1: resolution: {integrity: sha512-a4UGQaWPH59mOXUYnAG2ewncQS4i4F43Tv3JoAM+s2VDAmS9NsK8GpDMLrCHPksFT7h3K6TOoUNn2pb7RoXx4g==} - /yallist@4.0.0: + /yallist/4.0.0: resolution: {integrity: sha512-3wdGidZyq5PB084XLES5TpOSRA3wjXAlIWMhum2kRcv/41Sn2emQ0dycQW4uZXLejwKvg6EsvbdlVL+FYEct7A==} dev: true - /yaml-eslint-parser@1.2.2: + /yaml-eslint-parser/1.2.2: resolution: {integrity: sha512-pEwzfsKbTrB8G3xc/sN7aw1v6A6c/pKxLAkjclnAyo5g5qOh6eL9WGu0o3cSDQZKrTNk4KL4lQSwZW+nBkANEg==} engines: {node: ^14.17.0 || >=16.0.0} dependencies: @@ -25752,26 +22645,26 @@ packages: yaml: 2.3.1 dev: true - /yaml@1.10.2: + /yaml/1.10.2: resolution: {integrity: sha512-r3vXyErRCYJ7wg28yvBY5VSoAF8ZvlcW9/BwUzEtUsjvX/DKs24dIkuwjtuprwJJHsbyUbLApepYTR1BN4uHrg==} engines: {node: '>= 6'} - /yaml@2.3.1: + /yaml/2.3.1: resolution: {integrity: sha512-2eHWfjaoXgTBC2jNM1LRef62VQa0umtvRiDSk6HSzW7RvS5YtkabJrwYLLEKWBc8a5U2PTSCs+dJjUTJdlHsWQ==} engines: {node: '>= 14'} dev: true - /yargs-parser@20.2.9: + /yargs-parser/20.2.9: resolution: {integrity: sha512-y11nGElTIV+CT3Zv9t7VKl+Q3hTQoT9a1Qzezhhl6Rp21gJ/IVTW7Z3y9EWXhuUBC2Shnf+DX0antecpAwSP8w==} engines: {node: '>=10'} dev: true - /yargs-parser@21.1.1: + /yargs-parser/21.1.1: resolution: {integrity: sha512-tVpsJW7DdjecAiFpbIB1e3qxIQsE6NoPc5/eTdrbbIC4h0LVsWhnoa3g+m2HclBIujHzsxZ4VJVA+GUuc2/LBw==} engines: {node: '>=12'} dev: true - /yargs@16.2.0: + /yargs/16.2.0: resolution: {integrity: sha512-D1mvvtDG0L5ft/jGWkLpG1+m0eQxOfaBvTNELraWj22wSVUMWxZUvYgJYcKh6jGGIkJFhH4IZPQhR4TKpc8mBw==} engines: {node: '>=10'} dependencies: @@ -25784,11 +22677,11 @@ packages: yargs-parser: 20.2.9 dev: true - /yargs@17.5.1: - resolution: {integrity: sha512-t6YAJcxDkNX7NFYiVtKvWUz8l+PaKTLiL63mJYWR2GnHq2gjEWISzsLp9wg3aY36dY1j+gfIEL3pIF+XlJJfbA==} + /yargs/17.7.1: + resolution: {integrity: sha512-cwiTb08Xuv5fqF4AovYacTFNxk62th7LKJ6BL9IGUpTJrWoU7/7WdQGTP2SjKf1dUNBGzDd28p/Yfs/GI6JrLw==} engines: {node: '>=12'} dependencies: - cliui: 7.0.4 + cliui: 8.0.1 escalade: 3.1.1 get-caller-file: 2.0.5 require-directory: 2.1.1 @@ -25797,8 +22690,8 @@ packages: yargs-parser: 21.1.1 dev: true - /yargs@17.7.1: - resolution: {integrity: sha512-cwiTb08Xuv5fqF4AovYacTFNxk62th7LKJ6BL9IGUpTJrWoU7/7WdQGTP2SjKf1dUNBGzDd28p/Yfs/GI6JrLw==} + /yargs/17.7.2: + resolution: {integrity: sha512-7dSzzRQ++CKnNI/krKnYRV7JKKPUXMEh61soaHKg9mrWEhzFWhFnxPxGl+69cD1Ou63C13NUPCnmIcrvqCuM6w==} engines: {node: '>=12'} dependencies: cliui: 8.0.1 @@ -25810,48 +22703,48 @@ packages: yargs-parser: 21.1.1 dev: true - /yauzl@2.10.0: + /yauzl/2.10.0: resolution: {integrity: sha512-p4a9I6X6nu6IhoGmBqAcbJy1mlC4j27vEPZX9F4L4/vZT3Lyq1VkFHw/V/PUcB9Buo+DG3iHkT0x3Qya58zc3g==} dependencies: buffer-crc32: 0.2.13 fd-slicer: 1.1.0 dev: true - /yn@3.1.1: + /yn/3.1.1: resolution: {integrity: sha512-Ux4ygGWsu2c7isFWe8Yu1YluJmqVhxqK2cLXNQA5AcC3QfbGNpM7fu0Y8b/z16pXLnFxZYvWhd3fhBY9DLmC6Q==} engines: {node: '>=6'} dev: true - /yocto-queue@0.1.0: + /yocto-queue/0.1.0: resolution: {integrity: sha512-rVksvsnNCdJ/ohGc6xgPwyN8eheCxsiLM8mxuE/t/mOVqJewPuO1miLpTHQiRgTKCLexL4MeAFVagts7HmNZ2Q==} engines: {node: '>=10'} dev: true - /yocto-queue@1.0.0: + /yocto-queue/1.0.0: resolution: {integrity: sha512-9bnSc/HEW2uRy67wc+T8UwauLuPJVn28jb+GtJY16iiKWyvmYJRXVT4UamsAEGQfPohgr2q4Tq0sQbQlxTfi1g==} engines: {node: '>=12.20'} - /zen-observable-ts@1.2.5: + /zen-observable-ts/1.2.5: resolution: {integrity: sha512-QZWQekv6iB72Naeake9hS1KxHlotfRpe+WGNbNx5/ta+R3DNjVO2bswf63gXlWDcs+EMd7XY8HfVQyP1X6T4Zg==} dependencies: zen-observable: 0.8.15 dev: false - /zen-observable@0.8.15: + /zen-observable/0.8.15: resolution: {integrity: sha512-PQ2PC7R9rslx84ndNBZB/Dkv8V8fZEpk83RLgXtYd0fwUgEjseMn1Dgajh2x6S8QbZAFa9p2qVCEuYZNgve0dQ==} dev: false - /zip-stream@4.1.0: + /zip-stream/4.1.0: resolution: {integrity: sha512-zshzwQW7gG7hjpBlgeQP9RuyPGNxvJdzR8SUM3QhxCnLjWN2E7j3dOvpeDcQoETfHx0urRS7EtmVToql7YpU4A==} engines: {node: '>= 10'} dependencies: archiver-utils: 2.1.0 compress-commons: 4.1.1 - readable-stream: 3.6.0 + readable-stream: 3.6.2 dev: true - /zustand@4.1.1(react@18.2.0): - resolution: {integrity: sha512-h4F3WMqsZgvvaE0n3lThx4MM81Ls9xebjvrABNzf5+jb3/03YjNTSgZXeyrvXDArMeV9untvWXRw1tY+ntPYbA==} + /zustand/4.3.9_react@18.2.0: + resolution: {integrity: sha512-Tat5r8jOMG1Vcsj8uldMyqYKC5IZvQif8zetmLHs9WoZlntTHmIoNM8TpLRY31ExncuUvUOXehd0kvahkuHjDw==} engines: {node: '>=12.7.0'} peerDependencies: immer: '>=9.0' @@ -25863,10 +22756,10 @@ packages: optional: true dependencies: react: 18.2.0 - use-sync-external-store: 1.2.0(react@18.2.0) + use-sync-external-store: 1.2.0_react@18.2.0 dev: true - /zwitch@1.0.5: + /zwitch/1.0.5: resolution: {integrity: sha512-V50KMwwzqJV0NpZIZFwfOD5/lyny3WlSzRiXgA0G7VUnRlqttta1L6UQIHzd6EuBY/cHGfwTIck7w1yH6Q5zUw==} dev: true From 0989e2731117b1e020e25eadfb4af0afdcff360d Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Wed, 12 Jul 2023 11:02:01 +0200 Subject: [PATCH 63/87] chore: use correct pnpm --- pnpm-lock.yaml | 10707 +++++++++++++++++++++++++++-------------------- 1 file changed, 6120 insertions(+), 4587 deletions(-) diff --git a/pnpm-lock.yaml b/pnpm-lock.yaml index 0e5409f4b4d8..db66ac3aa42c 100644 --- a/pnpm-lock.yaml +++ b/pnpm-lock.yaml @@ -1,4 +1,8 @@ -lockfileVersion: 5.4 +lockfileVersion: '6.0' + +settings: + autoInstallPeers: true + excludeLinksFromLockfile: false overrides: vite: ^4.3.9 @@ -7,1501 +11,1986 @@ overrides: importers: .: - specifiers: - '@antfu/eslint-config': ^0.39.6 - '@antfu/ni': ^0.21.4 - '@rollup/plugin-alias': ^5.0.0 - '@rollup/plugin-commonjs': ^25.0.2 - '@rollup/plugin-json': ^6.0.0 - '@rollup/plugin-node-resolve': ^15.1.0 - '@types/fs-extra': ^11.0.1 - '@types/lodash': ^4.14.195 - '@types/node': ^18.16.19 - '@types/ws': ^8.5.5 - '@vitest/browser': workspace:* - '@vitest/coverage-istanbul': workspace:* - '@vitest/coverage-v8': workspace:* - '@vitest/ui': workspace:* - bumpp: ^9.1.1 - esbuild: ^0.18.11 - eslint: ^8.44.0 - esno: ^0.16.3 - fast-glob: ^3.3.0 - if-node-version: ^1.1.1 - lint-staged: ^13.2.3 - magic-string: ^0.30.1 - node-fetch-native: ^1.2.0 - npm-run-all: ^4.1.5 - ohmyfetch: ^0.4.21 - pathe: ^1.1.1 - pnpm: 8.6.6 - rimraf: ^5.0.1 - rollup: ^3.26.0 - rollup-plugin-dts: ^5.3.0 - rollup-plugin-esbuild: ^5.0.0 - rollup-plugin-license: ^3.0.1 - simple-git-hooks: ^2.8.1 - ts-node: ^10.9.1 - tsup: ^6.7.0 - typescript: ^5.1.6 - vite: ^4.3.9 - vitest: workspace:* devDependencies: - '@antfu/eslint-config': 0.39.7_iqf7tbmerllfqanu4l3d6aqdn4 - '@antfu/ni': 0.21.4 - '@rollup/plugin-alias': 5.0.0_rollup@3.26.2 - '@rollup/plugin-commonjs': 25.0.2_rollup@3.26.2 - '@rollup/plugin-json': 6.0.0_rollup@3.26.2 - '@rollup/plugin-node-resolve': 15.1.0_rollup@3.26.2 - '@types/fs-extra': 11.0.1 - '@types/lodash': 4.14.195 - '@types/node': 18.16.19 - '@types/ws': 8.5.5 - '@vitest/browser': link:packages/browser - '@vitest/coverage-istanbul': link:packages/coverage-istanbul - '@vitest/coverage-v8': link:packages/coverage-v8 - '@vitest/ui': link:packages/ui - bumpp: 9.1.1 - esbuild: 0.18.11 - eslint: 8.44.0 - esno: 0.16.3 - fast-glob: 3.3.0 - if-node-version: 1.1.1 - lint-staged: 13.2.3 - magic-string: 0.30.1 - node-fetch-native: 1.2.0 - npm-run-all: 4.1.5 - ohmyfetch: 0.4.21 - pathe: 1.1.1 - pnpm: 8.6.6 - rimraf: 5.0.1 - rollup: 3.26.2 - rollup-plugin-dts: 5.3.0_btijhbnqj3bkl7p6fnurpsgzhq - rollup-plugin-esbuild: 5.0.0_b5okt2kat7kf37a3hh6exlw3ju - rollup-plugin-license: 3.0.1_rollup@3.26.2 - simple-git-hooks: 2.8.1 - ts-node: 10.9.1_pqdfkuhuhnwv2d7uogwywwxtqq - tsup: 6.7.0_kg5gpyde6u3komamnnl67a6oc4 - typescript: 5.1.6 - vite: 4.4.3_@types+node@18.16.19 - vitest: link:packages/vitest + '@antfu/eslint-config': + specifier: ^0.39.6 + version: 0.39.7(eslint@8.44.0)(typescript@5.1.6) + '@antfu/ni': + specifier: ^0.21.4 + version: 0.21.4 + '@rollup/plugin-alias': + specifier: ^5.0.0 + version: 5.0.0(rollup@3.26.2) + '@rollup/plugin-commonjs': + specifier: ^25.0.2 + version: 25.0.2(rollup@3.26.2) + '@rollup/plugin-json': + specifier: ^6.0.0 + version: 6.0.0(rollup@3.26.2) + '@rollup/plugin-node-resolve': + specifier: ^15.1.0 + version: 15.1.0(rollup@3.26.2) + '@types/fs-extra': + specifier: ^11.0.1 + version: 11.0.1 + '@types/lodash': + specifier: ^4.14.195 + version: 4.14.195 + '@types/node': + specifier: ^18.16.19 + version: 18.16.19 + '@types/ws': + specifier: ^8.5.5 + version: 8.5.5 + '@vitest/browser': + specifier: workspace:* + version: link:packages/browser + '@vitest/coverage-istanbul': + specifier: workspace:* + version: link:packages/coverage-istanbul + '@vitest/coverage-v8': + specifier: workspace:* + version: link:packages/coverage-v8 + '@vitest/ui': + specifier: workspace:* + version: link:packages/ui + bumpp: + specifier: ^9.1.1 + version: 9.1.1 + esbuild: + specifier: ^0.18.11 + version: 0.18.11 + eslint: + specifier: ^8.44.0 + version: 8.44.0 + esno: + specifier: ^0.16.3 + version: 0.16.3 + fast-glob: + specifier: ^3.3.0 + version: 3.3.0 + if-node-version: + specifier: ^1.1.1 + version: 1.1.1 + lint-staged: + specifier: ^13.2.3 + version: 13.2.3 + magic-string: + specifier: ^0.30.1 + version: 0.30.1 + node-fetch-native: + specifier: ^1.2.0 + version: 1.2.0 + npm-run-all: + specifier: ^4.1.5 + version: 4.1.5 + ohmyfetch: + specifier: ^0.4.21 + version: 0.4.21 + pathe: + specifier: ^1.1.1 + version: 1.1.1 + pnpm: + specifier: 8.6.6 + version: 8.6.6 + rimraf: + specifier: ^5.0.1 + version: 5.0.1 + rollup: + specifier: ^3.26.0 + version: 3.26.2 + rollup-plugin-dts: + specifier: ^5.3.0 + version: 5.3.0(rollup@3.26.2)(typescript@5.1.6) + rollup-plugin-esbuild: + specifier: ^5.0.0 + version: 5.0.0(esbuild@0.18.11)(rollup@3.26.2) + rollup-plugin-license: + specifier: ^3.0.1 + version: 3.0.1(rollup@3.26.2) + simple-git-hooks: + specifier: ^2.8.1 + version: 2.8.1 + ts-node: + specifier: ^10.9.1 + version: 10.9.1(@types/node@18.16.19)(typescript@5.1.6) + tsup: + specifier: ^6.7.0 + version: 6.7.0(ts-node@10.9.1)(typescript@5.1.6) + typescript: + specifier: ^5.1.6 + version: 5.1.6 + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:packages/vitest docs: - specifiers: - '@iconify-json/carbon': ^1.1.18 - '@unocss/reset': ^0.53.4 - '@vite-pwa/assets-generator': ^0.0.3 - '@vite-pwa/vitepress': ^0.2.0 - '@vitejs/plugin-vue': latest - '@vueuse/core': ^10.2.1 - esno: ^0.16.3 - fast-glob: ^3.3.0 - fs-extra: ^11.1.1 - https-localhost: ^4.7.1 - jiti: ^1.18.2 - unocss: ^0.53.4 - unplugin-vue-components: ^0.25.1 - vite: ^4.3.9 - vite-plugin-pwa: ^0.16.4 - vitepress: 1.0.0-beta.5 - vue: latest - workbox-window: ^7.0.0 dependencies: - '@vueuse/core': 10.2.1_vue@3.3.4 - jiti: 1.19.1 - vue: 3.3.4 + '@vueuse/core': + specifier: ^10.2.1 + version: 10.2.1(vue@3.3.4) + jiti: + specifier: ^1.18.2 + version: 1.19.1 + vue: + specifier: latest + version: 3.3.4 devDependencies: - '@iconify-json/carbon': 1.1.18 - '@unocss/reset': 0.53.5 - '@vite-pwa/assets-generator': 0.0.3 - '@vite-pwa/vitepress': 0.2.0_vite-plugin-pwa@0.16.4 - '@vitejs/plugin-vue': 4.2.3_vite@4.4.3+vue@3.3.4 - esno: 0.16.3 - fast-glob: 3.3.0 - fs-extra: 11.1.1 - https-localhost: 4.7.1 - unocss: 0.53.5_vite@4.4.3 - unplugin-vue-components: 0.25.1_vue@3.3.4 - vite: 4.4.3 - vite-plugin-pwa: 0.16.4_cqwyifvz3q2qdw6r4piqd2mqaa - vitepress: 1.0.0-beta.5 - workbox-window: 7.0.0 + '@iconify-json/carbon': + specifier: ^1.1.18 + version: 1.1.18 + '@unocss/reset': + specifier: ^0.53.4 + version: 0.53.5 + '@vite-pwa/assets-generator': + specifier: ^0.0.3 + version: 0.0.3 + '@vite-pwa/vitepress': + specifier: ^0.2.0 + version: 0.2.0(vite-plugin-pwa@0.16.4) + '@vitejs/plugin-vue': + specifier: latest + version: 4.2.3(vite@4.4.3)(vue@3.3.4) + esno: + specifier: ^0.16.3 + version: 0.16.3 + fast-glob: + specifier: ^3.3.0 + version: 3.3.0 + fs-extra: + specifier: ^11.1.1 + version: 11.1.1 + https-localhost: + specifier: ^4.7.1 + version: 4.7.1 + unocss: + specifier: ^0.53.4 + version: 0.53.5(postcss@8.4.25)(rollup@2.79.1)(vite@4.4.3) + unplugin-vue-components: + specifier: ^0.25.1 + version: 0.25.1(rollup@2.79.1)(vue@3.3.4) + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vite-plugin-pwa: + specifier: ^0.16.4 + version: 0.16.4(vite@4.4.3)(workbox-build@7.0.0)(workbox-window@7.0.0) + vitepress: + specifier: 1.0.0-beta.5 + version: 1.0.0-beta.5(@types/node@18.16.19)(search-insights@2.7.0) + workbox-window: + specifier: ^7.0.0 + version: 7.0.0 examples/basic: - specifiers: - '@vitest/ui': latest - vite: ^4.3.9 - vitest: workspace:* devDependencies: - '@vitest/ui': link:../../packages/ui - vite: 4.4.3 - vitest: link:../../packages/vitest + '@vitest/ui': + specifier: latest + version: link:../../packages/ui + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest examples/fastify: - specifiers: - '@vitest/ui': latest - axios: ^0.26.1 - fastify: 4.5.3 - supertest: 6.2.4 - tsx: ^3.9.0 - vite: ^4.3.9 - vitest: workspace:* devDependencies: - '@vitest/ui': link:../../packages/ui - axios: 0.26.1 - fastify: 4.5.3 - supertest: 6.2.4 - tsx: 3.12.7 - vite: 4.4.3 - vitest: link:../../packages/vitest + '@vitest/ui': + specifier: latest + version: link:../../packages/ui + axios: + specifier: ^0.26.1 + version: 0.26.1 + fastify: + specifier: 4.5.3 + version: 4.5.3 + supertest: + specifier: 6.2.4 + version: 6.2.4 + tsx: + specifier: ^3.9.0 + version: 3.12.7 + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest examples/graphql: - specifiers: - '@rollup/plugin-graphql': ^1.1.0 - '@vitest/ui': latest - graphql: ^16.5.0 - vite: ^4.3.9 - vitest: workspace:* - dependencies: - '@rollup/plugin-graphql': 1.1.0_graphql@16.7.1 - graphql: 16.7.1 + dependencies: + '@rollup/plugin-graphql': + specifier: ^1.1.0 + version: 1.1.0(graphql@16.7.1)(rollup@2.79.1) + graphql: + specifier: ^16.5.0 + version: 16.7.1 devDependencies: - '@vitest/ui': link:../../packages/ui - vite: 4.4.3 - vitest: link:../../packages/vitest + '@vitest/ui': + specifier: latest + version: link:../../packages/ui + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest examples/image-snapshot: - specifiers: - '@vitest/ui': latest - jest-image-snapshot: ^4.5.1 - vite: ^4.3.9 - vitest: workspace:* devDependencies: - '@vitest/ui': link:../../packages/ui - jest-image-snapshot: 4.5.1 - vite: 4.4.3 - vitest: link:../../packages/vitest + '@vitest/ui': + specifier: latest + version: link:../../packages/ui + jest-image-snapshot: + specifier: ^4.5.1 + version: 4.5.1(jest@27.5.1) + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest examples/lit: - specifiers: - '@vitest/ui': latest - jsdom: latest - lit: ^2.2.5 - vite: ^4.3.9 - vitest: workspace:* - dependencies: - lit: 2.7.6 + dependencies: + lit: + specifier: ^2.2.5 + version: 2.7.6 devDependencies: - '@vitest/ui': link:../../packages/ui - jsdom: 22.1.0 - vite: 4.4.3 - vitest: link:../../packages/vitest + '@vitest/ui': + specifier: latest + version: link:../../packages/ui + jsdom: + specifier: latest + version: 22.1.0 + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest examples/mocks: - specifiers: - '@vitest/ui': latest - '@vueuse/integrations': ^8.5.0 - axios: ^0.26.1 - react: ^18.0.0 - sweetalert2: ^11.6.16 - tinyspy: ^0.3.2 - vite: ^4.3.9 - vitest: workspace:* - vue: ^3.2.39 - zustand: ^4.1.1 - dependencies: - '@vueuse/integrations': 8.9.4_axios@0.26.1+vue@3.3.4 - axios: 0.26.1 - tinyspy: 0.3.3 + dependencies: + '@vueuse/integrations': + specifier: ^8.5.0 + version: 8.9.4(axios@0.26.1)(vue@3.3.4) + axios: + specifier: ^0.26.1 + version: 0.26.1 + tinyspy: + specifier: ^0.3.2 + version: 0.3.3 devDependencies: - '@vitest/ui': link:../../packages/ui - react: 18.2.0 - sweetalert2: 11.7.16 - vite: 4.4.3 - vitest: link:../../packages/vitest - vue: 3.3.4 - zustand: 4.3.9_react@18.2.0 + '@vitest/ui': + specifier: latest + version: link:../../packages/ui + react: + specifier: ^18.0.0 + version: 18.2.0 + sweetalert2: + specifier: ^11.6.16 + version: 11.7.16 + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest + vue: + specifier: ^3.2.39 + version: 3.3.4 + zustand: + specifier: ^4.1.1 + version: 4.3.9(react@18.2.0) examples/nextjs: - specifiers: - '@testing-library/react': ^13.2.0 - '@types/node': latest - '@types/react': latest - '@vitejs/plugin-react': latest - jsdom: latest - next: 12.1.5 - react: 18.0.0 - react-dom: 18.0.0 - typescript: ^4.8.4 - vitest: workspace:* dependencies: - next: 12.1.5_zpnidt7m3osuk7shl3s4oenomq - react: 18.0.0 - react-dom: 18.0.0_react@18.0.0 + next: + specifier: 12.1.5 + version: 12.1.5(@babel/core@7.22.8)(react-dom@18.0.0)(react@18.0.0) + react: + specifier: 18.0.0 + version: 18.0.0 + react-dom: + specifier: 18.0.0 + version: 18.0.0(react@18.0.0) devDependencies: - '@testing-library/react': 13.4.0_zpnidt7m3osuk7shl3s4oenomq - '@types/node': 20.4.1 - '@types/react': 18.2.14 - '@vitejs/plugin-react': 4.0.3 - jsdom: 22.1.0 - typescript: 4.9.5 - vitest: link:../../packages/vitest + '@testing-library/react': + specifier: ^13.2.0 + version: 13.4.0(react-dom@18.0.0)(react@18.0.0) + '@types/node': + specifier: latest + version: 20.4.1 + '@types/react': + specifier: latest + version: 18.2.14 + '@vitejs/plugin-react': + specifier: latest + version: 4.0.3(vite@4.4.3) + jsdom: + specifier: latest + version: 22.1.0 + typescript: + specifier: ^4.8.4 + version: 4.9.5 + vitest: + specifier: workspace:* + version: link:../../packages/vitest examples/playwright: - specifiers: - '@playwright/test': ^1.28.0 - '@vitest/ui': latest - playwright: ^1.28.0 - vite: ^4.3.9 - vitest: workspace:* devDependencies: - '@playwright/test': 1.36.0 - '@vitest/ui': link:../../packages/ui - playwright: 1.36.0 - vite: 4.4.3 - vitest: link:../../packages/vitest + '@playwright/test': + specifier: ^1.28.0 + version: 1.36.0 + '@vitest/ui': + specifier: latest + version: link:../../packages/ui + playwright: + specifier: ^1.28.0 + version: 1.36.0 + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest examples/puppeteer: - specifiers: - '@vitest/ui': latest - puppeteer: ^13.6.0 - vite: ^4.3.9 - vitest: workspace:* devDependencies: - '@vitest/ui': link:../../packages/ui - puppeteer: 13.7.0 - vite: 4.4.3 - vitest: link:../../packages/vitest + '@vitest/ui': + specifier: latest + version: link:../../packages/ui + puppeteer: + specifier: ^13.6.0 + version: 13.7.0 + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest examples/react: - specifiers: - '@types/react': ^17.0.45 - '@types/react-test-renderer': ^17.0.2 - '@vitejs/plugin-react': latest - '@vitest/ui': latest - happy-dom: latest - jsdom: latest - react: ^17.0.2 - react-test-renderer: 17.0.2 - vite: ^4.3.9 - vitest: workspace:* dependencies: - react: 17.0.2 + react: + specifier: ^17.0.2 + version: 17.0.2 devDependencies: - '@types/react': 17.0.62 - '@types/react-test-renderer': 17.0.2 - '@vitejs/plugin-react': 4.0.3_vite@4.4.3 - '@vitest/ui': link:../../packages/ui - happy-dom: 10.1.1 - jsdom: 22.1.0 - react-test-renderer: 17.0.2_react@17.0.2 - vite: 4.4.3 - vitest: link:../../packages/vitest + '@types/react': + specifier: ^17.0.45 + version: 17.0.62 + '@types/react-test-renderer': + specifier: ^17.0.2 + version: 17.0.2 + '@vitejs/plugin-react': + specifier: latest + version: 4.0.3(vite@4.4.3) + '@vitest/ui': + specifier: latest + version: link:../../packages/ui + happy-dom: + specifier: latest + version: 10.1.1 + jsdom: + specifier: latest + version: 22.1.0 + react-test-renderer: + specifier: 17.0.2 + version: 17.0.2(react@17.0.2) + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest examples/react-enzyme: - specifiers: - '@types/enzyme': ^3.10.12 - '@types/react': ^17.0.45 - '@types/react-dom': ^17.0.17 - '@vitejs/plugin-react': latest - '@vitest/ui': latest - '@wojtekmaj/enzyme-adapter-react-17': ^0.6.7 - enzyme: ^3.11.0 - jsdom: ^20.0.3 - react: ^17.0.2 - react-dom: ^17.0.2 - vite: ^4.3.9 - vitest: workspace:* dependencies: - react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react: + specifier: ^17.0.2 + version: 17.0.2 + react-dom: + specifier: ^17.0.2 + version: 17.0.2(react@17.0.2) devDependencies: - '@types/enzyme': 3.10.13 - '@types/react': 17.0.62 - '@types/react-dom': 17.0.20 - '@vitejs/plugin-react': 4.0.3_vite@4.4.3 - '@vitest/ui': link:../../packages/ui - '@wojtekmaj/enzyme-adapter-react-17': 0.6.7_7ltvq4e2railvf5uya4ffxpe2a - enzyme: 3.11.0 - jsdom: 20.0.3 - vite: 4.4.3 - vitest: link:../../packages/vitest + '@types/enzyme': + specifier: ^3.10.12 + version: 3.10.13 + '@types/react': + specifier: ^17.0.45 + version: 17.0.62 + '@types/react-dom': + specifier: ^17.0.17 + version: 17.0.20 + '@vitejs/plugin-react': + specifier: latest + version: 4.0.3(vite@4.4.3) + '@vitest/ui': + specifier: latest + version: link:../../packages/ui + '@wojtekmaj/enzyme-adapter-react-17': + specifier: ^0.6.7 + version: 0.6.7(enzyme@3.11.0)(react-dom@17.0.2)(react@17.0.2) + enzyme: + specifier: ^3.11.0 + version: 3.11.0 + jsdom: + specifier: ^20.0.3 + version: 20.0.3 + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest examples/react-mui: - specifiers: - '@emotion/react': ^11.9.3 - '@emotion/styled': ^11.9.3 - '@mui/material': ^5.9.0 - '@mui/x-date-pickers': 5.0.0-beta.0 - '@testing-library/jest-dom': ^5.16.4 - '@testing-library/react': ^13.3.0 - '@testing-library/user-event': ^14.2.3 - '@vitest/ui': latest - date-fns: ^2.28.0 - history: ^5.3.0 - jsdom: latest - notistack: ^2.0.5 - react: ^18.2.0 - react-dom: ^18.2.0 - react-router-dom: ^6.3.0 - recharts: ^2.1.12 - swr: ^1.3.0 - vite: ^4.3.9 - vitest: workspace:* - dependencies: - '@emotion/react': 11.11.1_react@18.2.0 - '@emotion/styled': 11.11.0_xo5t6f4ryb2nvjgwj2cxjowrye - '@mui/material': 5.14.0_vizhjgize6w4e5tnsjmztd65da - '@mui/x-date-pickers': 5.0.0-beta.0_dc6gge3gqnljarlkhzo67xqsla - history: 5.3.0 - notistack: 2.0.8_tr5jdv7ejqexso4qfp7vkl3yhi - react: 18.2.0 - react-dom: 18.2.0_react@18.2.0 - react-router-dom: 6.14.1_biqbaboplfbrettd7655fr4n2y - recharts: 2.7.2_biqbaboplfbrettd7655fr4n2y - swr: 1.3.0_react@18.2.0 + dependencies: + '@emotion/react': + specifier: ^11.9.3 + version: 11.11.1(react@18.2.0) + '@emotion/styled': + specifier: ^11.9.3 + version: 11.11.0(@emotion/react@11.11.1)(react@18.2.0) + '@mui/material': + specifier: ^5.9.0 + version: 5.14.0(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(react-dom@18.2.0)(react@18.2.0) + '@mui/x-date-pickers': + specifier: 5.0.0-beta.0 + version: 5.0.0-beta.0(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(@mui/material@5.14.0)(@mui/system@5.14.0)(date-fns@2.30.0)(react-dom@18.2.0)(react@18.2.0) + history: + specifier: ^5.3.0 + version: 5.3.0 + notistack: + specifier: ^2.0.5 + version: 2.0.8(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(@mui/material@5.14.0)(react-dom@18.2.0)(react@18.2.0) + react: + specifier: ^18.2.0 + version: 18.2.0 + react-dom: + specifier: ^18.2.0 + version: 18.2.0(react@18.2.0) + react-router-dom: + specifier: ^6.3.0 + version: 6.14.1(react-dom@18.2.0)(react@18.2.0) + recharts: + specifier: ^2.1.12 + version: 2.7.2(prop-types@15.8.1)(react-dom@18.2.0)(react@18.2.0) + swr: + specifier: ^1.3.0 + version: 1.3.0(react@18.2.0) devDependencies: - '@testing-library/jest-dom': 5.16.5 - '@testing-library/react': 13.4.0_biqbaboplfbrettd7655fr4n2y - '@testing-library/user-event': 14.4.3 - '@vitest/ui': link:../../packages/ui - date-fns: 2.30.0 - jsdom: 22.1.0 - vite: 4.4.3 - vitest: link:../../packages/vitest + '@testing-library/jest-dom': + specifier: ^5.16.4 + version: 5.16.5 + '@testing-library/react': + specifier: ^13.3.0 + version: 13.4.0(react-dom@18.2.0)(react@18.2.0) + '@testing-library/user-event': + specifier: ^14.2.3 + version: 14.4.3(@testing-library/dom@9.3.1) + '@vitest/ui': + specifier: latest + version: link:../../packages/ui + date-fns: + specifier: ^2.28.0 + version: 2.30.0 + jsdom: + specifier: latest + version: 22.1.0 + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest examples/react-storybook: - specifiers: - '@babel/core': ^7.18.2 - '@storybook/addon-actions': ^6.5.5 - '@storybook/addon-essentials': ^6.5.5 - '@storybook/addon-links': ^6.5.5 - '@storybook/builder-vite': ^0.1.35 - '@storybook/react': ^6.5.5 - '@storybook/testing-library': ^0.0.11 - '@storybook/testing-react': ^1.3.0 - '@testing-library/jest-dom': ^5.16.4 - '@testing-library/react': ^12.1.5 - '@types/react': ^17.0.45 - '@types/react-dom': ^17.0.17 - '@vitejs/plugin-react': ^4.0.1 - '@vitest/ui': latest - babel-loader: ^8.2.5 - cross-fetch: ^3.1.5 - jsdom: latest - msw: ^0.49.2 - msw-storybook-addon: ^1.6.3 - react: ^17.0.2 - react-dom: ^17.0.2 - react-query: ^3.39.0 - typescript: ^4.8.4 - vite: ^4.3.9 - vitest: workspace:* - dependencies: - cross-fetch: 3.1.8 - react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 - react-query: 3.39.3_sfoxds7t5ydpegc3knd667wn6m + dependencies: + cross-fetch: + specifier: ^3.1.5 + version: 3.1.8 + react: + specifier: ^17.0.2 + version: 17.0.2 + react-dom: + specifier: ^17.0.2 + version: 17.0.2(react@17.0.2) + react-query: + specifier: ^3.39.0 + version: 3.39.3(react-dom@17.0.2)(react@17.0.2) devDependencies: - '@babel/core': 7.22.8 - '@storybook/addon-actions': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/addon-essentials': 6.5.16_7i6vyke6ny6b2xsni3leqxtq5y - '@storybook/addon-links': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/builder-vite': 0.1.41_qr3s4pqg2febfejexmksv4rlaa - '@storybook/react': 6.5.16_7i6vyke6ny6b2xsni3leqxtq5y - '@storybook/testing-library': 0.0.11 - '@storybook/testing-react': 1.3.0_o7jp7fwfcghoqe4nbzdqvmyhrm - '@testing-library/jest-dom': 5.16.5 - '@testing-library/react': 12.1.5_sfoxds7t5ydpegc3knd667wn6m - '@types/react': 17.0.62 - '@types/react-dom': 17.0.20 - '@vitejs/plugin-react': 4.0.3_vite@4.4.3 - '@vitest/ui': link:../../packages/ui - babel-loader: 8.3.0_@babel+core@7.22.8 - jsdom: 22.1.0 - msw: 0.49.3_typescript@4.9.5 - msw-storybook-addon: 1.8.0_msw@0.49.3 - typescript: 4.9.5 - vite: 4.4.3 - vitest: link:../../packages/vitest + '@babel/core': + specifier: ^7.18.2 + version: 7.22.8 + '@storybook/addon-actions': + specifier: ^6.5.5 + version: 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/addon-essentials': + specifier: ^6.5.5 + version: 6.5.16(@babel/core@7.22.8)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5)(webpack@5.88.1) + '@storybook/addon-links': + specifier: ^6.5.5 + version: 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/builder-vite': + specifier: ^0.1.35 + version: 0.1.41(@babel/core@7.22.8)(@storybook/core-common@6.5.16)(@storybook/node-logger@6.5.16)(@storybook/source-loader@6.5.16)(react@17.0.2)(typescript@4.9.5)(vite@4.4.3) + '@storybook/react': + specifier: ^6.5.5 + version: 6.5.16(@babel/core@7.22.8)(esbuild@0.18.11)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(require-from-string@2.0.2)(typescript@4.9.5) + '@storybook/testing-library': + specifier: ^0.0.11 + version: 0.0.11 + '@storybook/testing-react': + specifier: ^1.3.0 + version: 1.3.0(@storybook/addons@6.5.16)(@storybook/client-api@6.5.16)(@storybook/preview-web@6.5.16)(@storybook/react@6.5.16)(react@17.0.2) + '@testing-library/jest-dom': + specifier: ^5.16.4 + version: 5.16.5 + '@testing-library/react': + specifier: ^12.1.5 + version: 12.1.5(react-dom@17.0.2)(react@17.0.2) + '@types/react': + specifier: ^17.0.45 + version: 17.0.62 + '@types/react-dom': + specifier: ^17.0.17 + version: 17.0.20 + '@vitejs/plugin-react': + specifier: ^4.0.1 + version: 4.0.3(vite@4.4.3) + '@vitest/ui': + specifier: latest + version: link:../../packages/ui + babel-loader: + specifier: ^8.2.5 + version: 8.3.0(@babel/core@7.22.8)(webpack@5.88.1) + jsdom: + specifier: latest + version: 22.1.0 + msw: + specifier: ^0.49.2 + version: 0.49.3(typescript@4.9.5) + msw-storybook-addon: + specifier: ^1.6.3 + version: 1.8.0(msw@0.49.3) + typescript: + specifier: ^4.8.4 + version: 4.9.5 + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest examples/react-testing-lib: - specifiers: - '@testing-library/jest-dom': ^5.16.4 - '@testing-library/react': ^13.4.0 - '@testing-library/user-event': ^14.4.3 - '@types/react': ^18.0.24 - '@types/react-dom': ^18.0.8 - '@vitejs/plugin-react': latest - '@vitest/coverage-v8': latest - '@vitest/ui': latest - jsdom: latest - react: ^18.2.0 - react-dom: ^18.2.0 - typescript: ^4.8.4 - vite: ^4.3.9 - vitest: workspace:* dependencies: - react: 18.2.0 - react-dom: 18.2.0_react@18.2.0 + react: + specifier: ^18.2.0 + version: 18.2.0 + react-dom: + specifier: ^18.2.0 + version: 18.2.0(react@18.2.0) devDependencies: - '@testing-library/jest-dom': 5.16.5 - '@testing-library/react': 13.4.0_biqbaboplfbrettd7655fr4n2y - '@testing-library/user-event': 14.4.3 - '@types/react': 18.2.14 - '@types/react-dom': 18.2.6 - '@vitejs/plugin-react': 4.0.3_vite@4.4.3 - '@vitest/coverage-v8': link:../../packages/coverage-v8 - '@vitest/ui': link:../../packages/ui - jsdom: 22.1.0 - typescript: 4.9.5 - vite: 4.4.3 - vitest: link:../../packages/vitest + '@testing-library/jest-dom': + specifier: ^5.16.4 + version: 5.16.5 + '@testing-library/react': + specifier: ^13.4.0 + version: 13.4.0(react-dom@18.2.0)(react@18.2.0) + '@testing-library/user-event': + specifier: ^14.4.3 + version: 14.4.3(@testing-library/dom@9.3.1) + '@types/react': + specifier: ^18.0.24 + version: 18.2.14 + '@types/react-dom': + specifier: ^18.0.8 + version: 18.2.6 + '@vitejs/plugin-react': + specifier: latest + version: 4.0.3(vite@4.4.3) + '@vitest/coverage-v8': + specifier: latest + version: link:../../packages/coverage-v8 + '@vitest/ui': + specifier: latest + version: link:../../packages/ui + jsdom: + specifier: latest + version: 22.1.0 + typescript: + specifier: ^4.8.4 + version: 4.9.5 + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest examples/react-testing-lib-msw: - specifiers: - '@apollo/client': ^3.6.6 - '@testing-library/react': ^12.1.5 - '@testing-library/user-event': ^13.5.0 - '@types/react': ^17.0.45 - '@types/react-dom': ^17.0.17 - '@vitejs/plugin-react': ^4.0.1 - '@vitest/ui': latest - cross-fetch: ^3.1.5 - jsdom: latest - msw: ^1.2.1 - react: ^17.0.2 - react-dom: ^17.0.2 - vite: ^4.3.9 - vitest: workspace:* - dependencies: - '@apollo/client': 3.7.17_sfoxds7t5ydpegc3knd667wn6m - react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + dependencies: + '@apollo/client': + specifier: ^3.6.6 + version: 3.7.17(graphql@16.7.1)(react-dom@17.0.2)(react@17.0.2) + react: + specifier: ^17.0.2 + version: 17.0.2 + react-dom: + specifier: ^17.0.2 + version: 17.0.2(react@17.0.2) devDependencies: - '@testing-library/react': 12.1.5_sfoxds7t5ydpegc3knd667wn6m - '@testing-library/user-event': 13.5.0 - '@types/react': 17.0.62 - '@types/react-dom': 17.0.20 - '@vitejs/plugin-react': 4.0.3_vite@4.4.3 - '@vitest/ui': link:../../packages/ui - cross-fetch: 3.1.8 - jsdom: 22.1.0 - msw: 1.2.2 - vite: 4.4.3 - vitest: link:../../packages/vitest + '@testing-library/react': + specifier: ^12.1.5 + version: 12.1.5(react-dom@17.0.2)(react@17.0.2) + '@testing-library/user-event': + specifier: ^13.5.0 + version: 13.5.0(@testing-library/dom@9.3.1) + '@types/react': + specifier: ^17.0.45 + version: 17.0.62 + '@types/react-dom': + specifier: ^17.0.17 + version: 17.0.20 + '@vitejs/plugin-react': + specifier: ^4.0.1 + version: 4.0.3(vite@4.4.3) + '@vitest/ui': + specifier: latest + version: link:../../packages/ui + cross-fetch: + specifier: ^3.1.5 + version: 3.1.8 + jsdom: + specifier: latest + version: 22.1.0 + msw: + specifier: ^1.2.1 + version: 1.2.2(typescript@5.1.6) + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest examples/ruby: - specifiers: - '@vitejs/plugin-vue': latest - '@vue/test-utils': latest - jsdom: latest - vite: ^4.3.9 - vite-plugin-ruby: ^3.0.12 - vitest: workspace:* - vue: latest devDependencies: - '@vitejs/plugin-vue': 4.2.3_vite@4.4.3+vue@3.3.4 - '@vue/test-utils': 2.4.0_vue@3.3.4 - jsdom: 22.1.0 - vite: 4.4.3 - vite-plugin-ruby: 3.2.2_vite@4.4.3 - vitest: link:../../packages/vitest - vue: 3.3.4 + '@vitejs/plugin-vue': + specifier: latest + version: 4.2.3(vite@4.4.3)(vue@3.3.4) + '@vue/test-utils': + specifier: latest + version: 2.4.0(vue@3.3.4) + jsdom: + specifier: latest + version: 22.1.0 + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vite-plugin-ruby: + specifier: ^3.0.12 + version: 3.2.2(vite@4.4.3) + vitest: + specifier: workspace:* + version: link:../../packages/vitest + vue: + specifier: latest + version: 3.3.4 examples/solid: - specifiers: - '@testing-library/jest-dom': ^5.16.4 - jsdom: latest - solid-js: ^1.4.3 - solid-testing-library: ^0.5.0 - vite: ^4.3.9 - vite-plugin-solid: ^2.5.0 - vitest: workspace:* dependencies: - solid-js: 1.7.8 + solid-js: + specifier: ^1.4.3 + version: 1.7.8 devDependencies: - '@testing-library/jest-dom': 5.16.5 - jsdom: 22.1.0 - solid-testing-library: 0.5.1_solid-js@1.7.8 - vite: 4.4.3 - vite-plugin-solid: 2.7.0_solid-js@1.7.8+vite@4.4.3 - vitest: link:../../packages/vitest + '@testing-library/jest-dom': + specifier: ^5.16.4 + version: 5.16.5 + jsdom: + specifier: latest + version: 22.1.0 + solid-testing-library: + specifier: ^0.5.0 + version: 0.5.1(solid-js@1.7.8) + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vite-plugin-solid: + specifier: ^2.5.0 + version: 2.7.0(solid-js@1.7.8)(vite@4.4.3) + vitest: + specifier: workspace:* + version: link:../../packages/vitest examples/svelte: - specifiers: - '@sveltejs/vite-plugin-svelte': latest - '@testing-library/svelte': ^4.0.3 - '@vitest/ui': latest - jsdom: latest - svelte: latest - vite: ^4.3.9 - vitest: workspace:* devDependencies: - '@sveltejs/vite-plugin-svelte': 2.4.2_svelte@4.0.5+vite@4.4.3 - '@testing-library/svelte': 4.0.3_svelte@4.0.5 - '@vitest/ui': link:../../packages/ui - jsdom: 22.1.0 - svelte: 4.0.5 - vite: 4.4.3 - vitest: link:../../packages/vitest + '@sveltejs/vite-plugin-svelte': + specifier: latest + version: 2.4.2(svelte@4.0.5)(vite@4.4.3) + '@testing-library/svelte': + specifier: ^4.0.3 + version: 4.0.3(svelte@4.0.5) + '@vitest/ui': + specifier: latest + version: link:../../packages/ui + jsdom: + specifier: latest + version: 22.1.0 + svelte: + specifier: latest + version: 4.0.5 + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest examples/sveltekit: - specifiers: - '@sveltejs/adapter-auto': ^2.1.0 - '@sveltejs/kit': ^1.20.2 - prettier: ^2.8.8 - prettier-plugin-svelte: ^2.10.1 - svelte: ^3.59.1 - svelte-check: ^3.4.3 - tslib: ^2.5.3 - typescript: ^5.1.3 - vite: ^4.3.9 - vitest: workspace:* devDependencies: - '@sveltejs/adapter-auto': 2.1.0_@sveltejs+kit@1.22.2 - '@sveltejs/kit': 1.22.2_svelte@3.59.2+vite@4.4.3 - prettier: 2.8.8 - prettier-plugin-svelte: 2.10.1_jlgs5vq3kify7hyf3gm4oz2klm - svelte: 3.59.2 - svelte-check: 3.4.6_svelte@3.59.2 - tslib: 2.6.0 - typescript: 5.1.6 - vite: 4.4.3 - vitest: link:../../packages/vitest + '@sveltejs/adapter-auto': + specifier: ^2.1.0 + version: 2.1.0(@sveltejs/kit@1.22.2) + '@sveltejs/kit': + specifier: ^1.20.2 + version: 1.22.2(svelte@3.59.2)(vite@4.4.3) + prettier: + specifier: ^2.8.8 + version: 2.8.8 + prettier-plugin-svelte: + specifier: ^2.10.1 + version: 2.10.1(prettier@2.8.8)(svelte@3.59.2) + svelte: + specifier: ^3.59.1 + version: 3.59.2 + svelte-check: + specifier: ^3.4.3 + version: 3.4.6(svelte@3.59.2) + tslib: + specifier: ^2.5.3 + version: 2.6.0 + typescript: + specifier: ^5.1.3 + version: 5.1.6 + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest examples/vitesse: - specifiers: - '@vitejs/plugin-vue': latest - '@vue/test-utils': ^2.0.2 - jsdom: latest - unplugin-auto-import: latest - unplugin-vue-components: latest - vite: ^4.3.9 - vitest: workspace:* - vue: latest dependencies: - vue: 3.3.4 + vue: + specifier: latest + version: 3.3.4 devDependencies: - '@vitejs/plugin-vue': 4.2.3_vite@4.4.3+vue@3.3.4 - '@vue/test-utils': 2.4.0_vue@3.3.4 - jsdom: 22.1.0 - unplugin-auto-import: 0.16.6 - unplugin-vue-components: 0.25.1_vue@3.3.4 - vite: 4.4.3 - vitest: link:../../packages/vitest + '@vitejs/plugin-vue': + specifier: latest + version: 4.2.3(vite@4.4.3)(vue@3.3.4) + '@vue/test-utils': + specifier: ^2.0.2 + version: 2.4.0(vue@3.3.4) + jsdom: + specifier: latest + version: 22.1.0 + unplugin-auto-import: + specifier: latest + version: 0.16.6(@vueuse/core@10.2.1)(rollup@3.26.2) + unplugin-vue-components: + specifier: latest + version: 0.25.1(rollup@3.26.2)(vue@3.3.4) + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest examples/vue: - specifiers: - '@vitejs/plugin-vue': latest - '@vue/test-utils': ^2.0.0 - jsdom: latest - vite: ^4.3.9 - vitest: workspace:* - vue: latest dependencies: - vue: 3.3.4 + vue: + specifier: latest + version: 3.3.4 devDependencies: - '@vitejs/plugin-vue': 4.2.3_vite@4.4.3+vue@3.3.4 - '@vue/test-utils': 2.4.0_vue@3.3.4 - jsdom: 22.1.0 - vite: 4.4.3 - vitest: link:../../packages/vitest + '@vitejs/plugin-vue': + specifier: latest + version: 4.2.3(vite@4.4.3)(vue@3.3.4) + '@vue/test-utils': + specifier: ^2.0.0 + version: 2.4.0(vue@3.3.4) + jsdom: + specifier: latest + version: 22.1.0 + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest examples/vue-jsx: - specifiers: - '@vitejs/plugin-vue': latest - '@vitejs/plugin-vue-jsx': latest - '@vue/test-utils': latest - jsdom: latest - vite: ^4.3.9 - vitest: workspace:* - vue: latest devDependencies: - '@vitejs/plugin-vue': 4.2.3_vite@4.4.3+vue@3.3.4 - '@vitejs/plugin-vue-jsx': 3.0.1_vite@4.4.3+vue@3.3.4 - '@vue/test-utils': 2.4.0_vue@3.3.4 - jsdom: 22.1.0 - vite: 4.4.3 - vitest: link:../../packages/vitest - vue: 3.3.4 + '@vitejs/plugin-vue': + specifier: latest + version: 4.2.3(vite@4.4.3)(vue@3.3.4) + '@vitejs/plugin-vue-jsx': + specifier: latest + version: 3.0.1(vite@4.4.3)(vue@3.3.4) + '@vue/test-utils': + specifier: latest + version: 2.4.0(vue@3.3.4) + jsdom: + specifier: latest + version: 22.1.0 + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest + vue: + specifier: latest + version: 3.3.4 examples/vue2: - specifiers: - '@vitejs/plugin-vue2': ^1.1.2 - '@vue/test-utils': ^1.3.0 - jsdom: latest - vite: ^4.3.9 - vitest: workspace:* - vue: ^2.7.2 - vue-template-compiler: ^2.7.2 dependencies: - vue: 2.7.14 + vue: + specifier: ^2.7.2 + version: 2.7.14 devDependencies: - '@vitejs/plugin-vue2': 1.1.2_vite@4.4.3+vue@2.7.14 - '@vue/test-utils': 1.3.6_rhqkolmkwunxzlyyxxsuwaiuri - jsdom: 22.1.0 - vite: 4.4.3 - vitest: link:../../packages/vitest - vue-template-compiler: 2.7.14 + '@vitejs/plugin-vue2': + specifier: ^1.1.2 + version: 1.1.2(vite@4.4.3)(vue@2.7.14) + '@vue/test-utils': + specifier: ^1.3.0 + version: 1.3.6(vue-template-compiler@2.7.14)(vue@2.7.14) + jsdom: + specifier: latest + version: 22.1.0 + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest + vue-template-compiler: + specifier: ^2.7.2 + version: 2.7.14 packages/browser: - specifiers: - '@types/estree': ^1.0.1 - '@types/ws': ^8.5.5 - '@vitest/runner': workspace:* - '@vitest/ui': workspace:* - '@vitest/ws-client': workspace:* - estree-walker: ^3.0.3 - magic-string: ^0.30.1 - modern-node-polyfills: ^0.1.3 - periscopic: ^3.1.0 - rollup: ^3.26.0 - sirv: ^2.0.3 - vitest: workspace:* dependencies: - estree-walker: 3.0.3 - magic-string: 0.30.1 - modern-node-polyfills: 0.1.3_rollup@3.26.2 - sirv: 2.0.3 + estree-walker: + specifier: ^3.0.3 + version: 3.0.3 + magic-string: + specifier: ^0.30.1 + version: 0.30.1 + modern-node-polyfills: + specifier: ^0.1.3 + version: 0.1.3(rollup@3.26.2) + sirv: + specifier: ^2.0.3 + version: 2.0.3 devDependencies: - '@types/estree': 1.0.1 - '@types/ws': 8.5.5 - '@vitest/runner': link:../runner - '@vitest/ui': link:../ui - '@vitest/ws-client': link:../ws-client - periscopic: 3.1.0 - rollup: 3.26.2 - vitest: link:../vitest + '@types/estree': + specifier: ^1.0.1 + version: 1.0.1 + '@types/ws': + specifier: ^8.5.5 + version: 8.5.5 + '@vitest/runner': + specifier: workspace:* + version: link:../runner + '@vitest/ui': + specifier: workspace:* + version: link:../ui + '@vitest/ws-client': + specifier: workspace:* + version: link:../ws-client + periscopic: + specifier: ^3.1.0 + version: 3.1.0 + rollup: + specifier: ^3.26.0 + version: 3.26.2 + vitest: + specifier: workspace:* + version: link:../vitest packages/coverage-istanbul: - specifiers: - '@types/istanbul-lib-coverage': ^2.0.4 - '@types/istanbul-lib-instrument': ^1.7.4 - '@types/istanbul-lib-report': ^3.0.0 - '@types/istanbul-lib-source-maps': ^4.0.1 - '@types/istanbul-reports': ^3.0.1 - istanbul-lib-coverage: ^3.2.0 - istanbul-lib-instrument: ^5.2.1 - istanbul-lib-report: ^3.0.0 - istanbul-lib-source-maps: ^4.0.1 - istanbul-reports: ^3.1.5 - pathe: ^1.1.1 - test-exclude: ^6.0.0 - vitest: workspace:* dependencies: - istanbul-lib-coverage: 3.2.0 - istanbul-lib-instrument: 5.2.1 - istanbul-lib-report: 3.0.0 - istanbul-lib-source-maps: 4.0.1 - istanbul-reports: 3.1.5 - test-exclude: 6.0.0 + istanbul-lib-coverage: + specifier: ^3.2.0 + version: 3.2.0 + istanbul-lib-instrument: + specifier: ^5.2.1 + version: 5.2.1 + istanbul-lib-report: + specifier: ^3.0.0 + version: 3.0.0 + istanbul-lib-source-maps: + specifier: ^4.0.1 + version: 4.0.1 + istanbul-reports: + specifier: ^3.1.5 + version: 3.1.5 + test-exclude: + specifier: ^6.0.0 + version: 6.0.0 devDependencies: - '@types/istanbul-lib-coverage': 2.0.4 - '@types/istanbul-lib-instrument': 1.7.4 - '@types/istanbul-lib-report': 3.0.0 - '@types/istanbul-lib-source-maps': 4.0.1 - '@types/istanbul-reports': 3.0.1 - pathe: 1.1.1 - vitest: link:../vitest + '@types/istanbul-lib-coverage': + specifier: ^2.0.4 + version: 2.0.4 + '@types/istanbul-lib-instrument': + specifier: ^1.7.4 + version: 1.7.4 + '@types/istanbul-lib-report': + specifier: ^3.0.0 + version: 3.0.0 + '@types/istanbul-lib-source-maps': + specifier: ^4.0.1 + version: 4.0.1 + '@types/istanbul-reports': + specifier: ^3.0.1 + version: 3.0.1 + pathe: + specifier: ^1.1.1 + version: 1.1.1 + vitest: + specifier: workspace:* + version: link:../vitest packages/coverage-v8: - specifiers: - '@ampproject/remapping': ^2.2.1 - '@bcoe/v8-coverage': ^0.2.3 - '@types/istanbul-lib-coverage': ^2.0.4 - '@types/istanbul-lib-report': ^3.0.0 - '@types/istanbul-lib-source-maps': ^4.0.1 - '@types/istanbul-reports': ^3.0.1 - istanbul-lib-coverage: ^3.2.0 - istanbul-lib-report: ^3.0.0 - istanbul-lib-source-maps: ^4.0.1 - istanbul-reports: ^3.1.5 - magic-string: ^0.30.1 - pathe: ^1.1.1 - picocolors: ^1.0.0 - std-env: ^3.3.3 - test-exclude: ^6.0.0 - v8-to-istanbul: ^9.1.0 - vite-node: workspace:* - vitest: workspace:* dependencies: - '@ampproject/remapping': 2.2.1 - '@bcoe/v8-coverage': 0.2.3 - istanbul-lib-coverage: 3.2.0 - istanbul-lib-report: 3.0.0 - istanbul-lib-source-maps: 4.0.1 - istanbul-reports: 3.1.5 - magic-string: 0.30.1 - picocolors: 1.0.0 - std-env: 3.3.3 - test-exclude: 6.0.0 - v8-to-istanbul: 9.1.0 + '@ampproject/remapping': + specifier: ^2.2.1 + version: 2.2.1 + '@bcoe/v8-coverage': + specifier: ^0.2.3 + version: 0.2.3 + istanbul-lib-coverage: + specifier: ^3.2.0 + version: 3.2.0 + istanbul-lib-report: + specifier: ^3.0.0 + version: 3.0.0 + istanbul-lib-source-maps: + specifier: ^4.0.1 + version: 4.0.1 + istanbul-reports: + specifier: ^3.1.5 + version: 3.1.5 + magic-string: + specifier: ^0.30.1 + version: 0.30.1 + picocolors: + specifier: ^1.0.0 + version: 1.0.0 + std-env: + specifier: ^3.3.3 + version: 3.3.3 + test-exclude: + specifier: ^6.0.0 + version: 6.0.0 + v8-to-istanbul: + specifier: ^9.1.0 + version: 9.1.0 devDependencies: - '@types/istanbul-lib-coverage': 2.0.4 - '@types/istanbul-lib-report': 3.0.0 - '@types/istanbul-lib-source-maps': 4.0.1 - '@types/istanbul-reports': 3.0.1 - pathe: 1.1.1 - vite-node: link:../vite-node - vitest: link:../vitest + '@types/istanbul-lib-coverage': + specifier: ^2.0.4 + version: 2.0.4 + '@types/istanbul-lib-report': + specifier: ^3.0.0 + version: 3.0.0 + '@types/istanbul-lib-source-maps': + specifier: ^4.0.1 + version: 4.0.1 + '@types/istanbul-reports': + specifier: ^3.0.1 + version: 3.0.1 + pathe: + specifier: ^1.1.1 + version: 1.1.1 + vite-node: + specifier: workspace:* + version: link:../vite-node + vitest: + specifier: workspace:* + version: link:../vitest packages/expect: - specifiers: - '@vitest/runner': workspace:* - '@vitest/spy': workspace:* - '@vitest/utils': workspace:* - chai: ^4.3.7 - picocolors: ^1.0.0 - dependencies: - '@vitest/spy': link:../spy - '@vitest/utils': link:../utils - chai: 4.3.7 + dependencies: + '@vitest/spy': + specifier: workspace:* + version: link:../spy + '@vitest/utils': + specifier: workspace:* + version: link:../utils + chai: + specifier: ^4.3.7 + version: 4.3.7 devDependencies: - '@vitest/runner': link:../runner - picocolors: 1.0.0 + '@vitest/runner': + specifier: workspace:* + version: link:../runner + picocolors: + specifier: ^1.0.0 + version: 1.0.0 packages/runner: - specifiers: - '@vitest/utils': workspace:* - p-limit: ^4.0.0 - pathe: ^1.1.1 dependencies: - '@vitest/utils': link:../utils - p-limit: 4.0.0 - pathe: 1.1.1 + '@vitest/utils': + specifier: workspace:* + version: link:../utils + p-limit: + specifier: ^4.0.0 + version: 4.0.0 + pathe: + specifier: ^1.1.1 + version: 1.1.1 packages/snapshot: - specifiers: - '@types/natural-compare': ^1.4.1 - '@vitest/utils': workspace:* - magic-string: ^0.30.1 - natural-compare: ^1.4.0 - pathe: ^1.1.1 - pretty-format: ^29.5.0 dependencies: - magic-string: 0.30.1 - pathe: 1.1.1 - pretty-format: 29.6.1 + magic-string: + specifier: ^0.30.1 + version: 0.30.1 + pathe: + specifier: ^1.1.1 + version: 1.1.1 + pretty-format: + specifier: ^29.5.0 + version: 29.6.1 devDependencies: - '@types/natural-compare': 1.4.1 - '@vitest/utils': link:../utils - natural-compare: 1.4.0 + '@types/natural-compare': + specifier: ^1.4.1 + version: 1.4.1 + '@vitest/utils': + specifier: workspace:* + version: link:../utils + natural-compare: + specifier: ^1.4.0 + version: 1.4.0 packages/spy: - specifiers: - tinyspy: ^2.1.1 dependencies: - tinyspy: 2.1.1 + tinyspy: + specifier: ^2.1.1 + version: 2.1.1 packages/ui: - specifiers: - '@faker-js/faker': ^8.0.2 - '@testing-library/cypress': ^9.0.0 - '@types/codemirror': ^5.60.8 - '@types/d3-force': ^3.0.4 - '@types/d3-selection': ^3.0.5 - '@types/ws': ^8.5.5 - '@unocss/reset': ^0.53.4 - '@vitejs/plugin-vue': ^4.2.3 - '@vitejs/plugin-vue-jsx': ^3.0.1 - '@vitest/runner': workspace:* - '@vitest/utils': workspace:* - '@vitest/ws-client': workspace:* - '@vueuse/core': ^10.2.1 - ansi-to-html: ^0.7.2 - birpc: 0.2.12 - codemirror: ^5.65.13 - codemirror-theme-vars: ^0.1.2 - cypress: ^12.16.0 - d3-graph-controller: ^2.5.2 - fast-glob: ^3.3.0 - fflate: ^0.8.0 - flatted: ^3.2.7 - floating-vue: ^2.0.0-y.0 - pathe: ^1.1.1 - picocolors: ^1.0.0 - sirv: ^2.0.3 - splitpanes: ^3.1.5 - unocss: ^0.53.4 - unplugin-auto-import: ^0.16.4 - unplugin-vue-components: ^0.25.1 - vite: ^4.3.9 - vite-plugin-pages: ^0.31.0 - vue: ^3.3.4 - vue-router: ^4.2.2 - dependencies: - '@vitest/utils': link:../utils - fast-glob: 3.3.0 - fflate: 0.8.0 - flatted: 3.2.7 - pathe: 1.1.1 - picocolors: 1.0.0 - sirv: 2.0.3 + dependencies: + '@vitest/utils': + specifier: workspace:* + version: link:../utils + fast-glob: + specifier: ^3.3.0 + version: 3.3.0 + fflate: + specifier: ^0.8.0 + version: 0.8.0 + flatted: + specifier: ^3.2.7 + version: 3.2.7 + pathe: + specifier: ^1.1.1 + version: 1.1.1 + picocolors: + specifier: ^1.0.0 + version: 1.0.0 + sirv: + specifier: ^2.0.3 + version: 2.0.3 + vitest: + specifier: '>=0.30.1 <1' + version: link:../vitest devDependencies: - '@faker-js/faker': 8.0.2 - '@testing-library/cypress': 9.0.0_cypress@12.17.1 - '@types/codemirror': 5.60.8 - '@types/d3-force': 3.0.4 - '@types/d3-selection': 3.0.5 - '@types/ws': 8.5.5 - '@unocss/reset': 0.53.5 - '@vitejs/plugin-vue': 4.2.3_vite@4.4.3+vue@3.3.4 - '@vitejs/plugin-vue-jsx': 3.0.1_vite@4.4.3+vue@3.3.4 - '@vitest/runner': link:../runner - '@vitest/ws-client': link:../ws-client - '@vueuse/core': 10.2.1_vue@3.3.4 - ansi-to-html: 0.7.2 - birpc: 0.2.12 - codemirror: 5.65.13 - codemirror-theme-vars: 0.1.2 - cypress: 12.17.1 - d3-graph-controller: 2.5.2 - floating-vue: 2.0.0-y.0_vue@3.3.4 - splitpanes: 3.1.5 - unocss: 0.53.5_vite@4.4.3 - unplugin-auto-import: 0.16.6_@vueuse+core@10.2.1 - unplugin-vue-components: 0.25.1_vue@3.3.4 - vite: 4.4.3 - vite-plugin-pages: 0.31.0_vite@4.4.3 - vue: 3.3.4 - vue-router: 4.2.4_vue@3.3.4 + '@faker-js/faker': + specifier: ^8.0.2 + version: 8.0.2 + '@testing-library/cypress': + specifier: ^9.0.0 + version: 9.0.0(cypress@12.17.1) + '@types/codemirror': + specifier: ^5.60.8 + version: 5.60.8 + '@types/d3-force': + specifier: ^3.0.4 + version: 3.0.4 + '@types/d3-selection': + specifier: ^3.0.5 + version: 3.0.5 + '@types/ws': + specifier: ^8.5.5 + version: 8.5.5 + '@unocss/reset': + specifier: ^0.53.4 + version: 0.53.5 + '@vitejs/plugin-vue': + specifier: ^4.2.3 + version: 4.2.3(vite@4.4.3)(vue@3.3.4) + '@vitejs/plugin-vue-jsx': + specifier: ^3.0.1 + version: 3.0.1(vite@4.4.3)(vue@3.3.4) + '@vitest/runner': + specifier: workspace:* + version: link:../runner + '@vitest/ws-client': + specifier: workspace:* + version: link:../ws-client + '@vueuse/core': + specifier: ^10.2.1 + version: 10.2.1(vue@3.3.4) + ansi-to-html: + specifier: ^0.7.2 + version: 0.7.2 + birpc: + specifier: 0.2.12 + version: 0.2.12 + codemirror: + specifier: ^5.65.13 + version: 5.65.13 + codemirror-theme-vars: + specifier: ^0.1.2 + version: 0.1.2 + cypress: + specifier: ^12.16.0 + version: 12.17.1 + d3-graph-controller: + specifier: ^2.5.2 + version: 2.5.2 + floating-vue: + specifier: ^2.0.0-y.0 + version: 2.0.0-y.0(vue@3.3.4) + splitpanes: + specifier: ^3.1.5 + version: 3.1.5 + unocss: + specifier: ^0.53.4 + version: 0.53.5(postcss@8.4.25)(rollup@3.26.2)(vite@4.4.3) + unplugin-auto-import: + specifier: ^0.16.4 + version: 0.16.6(@vueuse/core@10.2.1)(rollup@3.26.2) + unplugin-vue-components: + specifier: ^0.25.1 + version: 0.25.1(rollup@3.26.2)(vue@3.3.4) + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vite-plugin-pages: + specifier: ^0.31.0 + version: 0.31.0(vite@4.4.3) + vue: + specifier: ^3.3.4 + version: 3.3.4 + vue-router: + specifier: ^4.2.2 + version: 4.2.4(vue@3.3.4) packages/utils: - specifiers: - diff-sequences: ^29.4.3 - loupe: ^2.3.6 - pretty-format: ^29.5.0 dependencies: - diff-sequences: 29.4.3 - loupe: 2.3.6 - pretty-format: 29.6.1 + diff-sequences: + specifier: ^29.4.3 + version: 29.4.3 + loupe: + specifier: ^2.3.6 + version: 2.3.6 + pretty-format: + specifier: ^29.5.0 + version: 29.6.1 packages/vite-node: - specifiers: - '@jridgewell/trace-mapping': ^0.3.18 - '@types/debug': ^4.1.8 - cac: ^6.7.14 - debug: ^4.3.4 - mlly: ^1.4.0 - pathe: ^1.1.1 - picocolors: ^1.0.0 - rollup: ^2.79.1 - vite: ^4.3.9 dependencies: - cac: 6.7.14 - debug: 4.3.4 - mlly: 1.4.0 - pathe: 1.1.1 - picocolors: 1.0.0 - vite: 4.4.3 + cac: + specifier: ^6.7.14 + version: 6.7.14 + debug: + specifier: ^4.3.4 + version: 4.3.4(supports-color@8.1.1) + mlly: + specifier: ^1.4.0 + version: 1.4.0 + pathe: + specifier: ^1.1.1 + version: 1.1.1 + picocolors: + specifier: ^1.0.0 + version: 1.0.0 + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) devDependencies: - '@jridgewell/trace-mapping': 0.3.18 - '@types/debug': 4.1.8 - rollup: 2.79.1 + '@jridgewell/trace-mapping': + specifier: ^0.3.18 + version: 0.3.18 + '@types/debug': + specifier: ^4.1.8 + version: 4.1.8 + rollup: + specifier: ^2.79.1 + version: 2.79.1 packages/vitest: - specifiers: - '@ampproject/remapping': ^2.2.1 - '@antfu/install-pkg': ^0.1.1 - '@edge-runtime/vm': 3.0.3 - '@jridgewell/trace-mapping': ^0.3.18 - '@sinonjs/fake-timers': ^11.0.0 - '@types/chai': ^4.3.5 - '@types/chai-subset': ^1.3.3 - '@types/diff': ^5.0.3 - '@types/estree': ^1.0.1 - '@types/istanbul-lib-coverage': ^2.0.4 - '@types/istanbul-reports': ^3.0.1 - '@types/jsdom': ^21.1.1 - '@types/micromatch': ^4.0.2 - '@types/node': '*' - '@types/prompts': ^2.4.4 - '@types/sinonjs__fake-timers': ^8.1.2 - '@vitest/expect': workspace:* - '@vitest/runner': workspace:* - '@vitest/snapshot': workspace:* - '@vitest/spy': workspace:* - '@vitest/utils': workspace:* - acorn: ^8.9.0 - acorn-walk: ^8.2.0 - birpc: 0.2.12 - cac: ^6.7.14 - chai: ^4.3.7 - chai-subset: ^1.6.0 - cli-truncate: ^3.1.0 - debug: ^4.3.4 - event-target-polyfill: ^0.0.3 - execa: ^7.1.1 - expect-type: ^0.16.0 - fast-glob: ^3.3.0 - find-up: ^6.3.0 - flatted: ^3.2.7 - get-tsconfig: ^4.6.2 - happy-dom: ^9.20.3 - jsdom: ^22.1.0 - local-pkg: ^0.4.3 - log-update: ^5.0.1 - magic-string: ^0.30.1 - micromatch: ^4.0.5 - mlly: ^1.4.0 - p-limit: ^4.0.0 - pathe: ^1.1.1 - picocolors: ^1.0.0 - pkg-types: ^1.0.3 - playwright: ^1.35.1 - pretty-format: ^29.5.0 - prompts: ^2.4.2 - safaridriver: ^0.0.5 - std-env: ^3.3.3 - strip-ansi: ^7.1.0 - strip-literal: ^1.0.1 - tinybench: ^2.5.0 - tinypool: ^0.7.0 - vite: ^4.3.9 - vite-node: workspace:* - webdriverio: ^8.11.2 - why-is-node-running: ^2.2.2 - ws: ^8.13.0 dependencies: - '@types/chai': 4.3.5 - '@types/chai-subset': 1.3.3 - '@types/node': 20.4.1 - '@vitest/expect': link:../expect - '@vitest/runner': link:../runner - '@vitest/snapshot': link:../snapshot - '@vitest/spy': link:../spy - '@vitest/utils': link:../utils - acorn: 8.10.0 - acorn-walk: 8.2.0 - cac: 6.7.14 - chai: 4.3.7 - debug: 4.3.4 - local-pkg: 0.4.3 - magic-string: 0.30.1 - pathe: 1.1.1 - picocolors: 1.0.0 - std-env: 3.3.3 - strip-literal: 1.0.1 - tinybench: 2.5.0 - tinypool: 0.7.0 - vite: 4.4.3_@types+node@20.4.1 - vite-node: link:../vite-node - why-is-node-running: 2.2.2 + '@types/chai': + specifier: ^4.3.5 + version: 4.3.5 + '@types/chai-subset': + specifier: ^1.3.3 + version: 1.3.3 + '@types/node': + specifier: '*' + version: 20.4.1 + '@vitest/browser': + specifier: '*' + version: link:../browser + '@vitest/expect': + specifier: workspace:* + version: link:../expect + '@vitest/runner': + specifier: workspace:* + version: link:../runner + '@vitest/snapshot': + specifier: workspace:* + version: link:../snapshot + '@vitest/spy': + specifier: workspace:* + version: link:../spy + '@vitest/ui': + specifier: '*' + version: link:../ui + '@vitest/utils': + specifier: workspace:* + version: link:../utils + acorn: + specifier: ^8.9.0 + version: 8.10.0 + acorn-walk: + specifier: ^8.2.0 + version: 8.2.0 + cac: + specifier: ^6.7.14 + version: 6.7.14 + chai: + specifier: ^4.3.7 + version: 4.3.7 + debug: + specifier: ^4.3.4 + version: 4.3.4(supports-color@8.1.1) + local-pkg: + specifier: ^0.4.3 + version: 0.4.3 + magic-string: + specifier: ^0.30.1 + version: 0.30.1 + pathe: + specifier: ^1.1.1 + version: 1.1.1 + picocolors: + specifier: ^1.0.0 + version: 1.0.0 + std-env: + specifier: ^3.3.3 + version: 3.3.3 + strip-literal: + specifier: ^1.0.1 + version: 1.0.1 + tinybench: + specifier: ^2.5.0 + version: 2.5.0 + tinypool: + specifier: ^0.7.0 + version: 0.7.0 + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@20.4.1) + vite-node: + specifier: workspace:* + version: link:../vite-node + why-is-node-running: + specifier: ^2.2.2 + version: 2.2.2 devDependencies: - '@ampproject/remapping': 2.2.1 - '@antfu/install-pkg': 0.1.1 - '@edge-runtime/vm': 3.0.3 - '@jridgewell/trace-mapping': 0.3.18 - '@sinonjs/fake-timers': 11.0.0 - '@types/diff': 5.0.3 - '@types/estree': 1.0.1 - '@types/istanbul-lib-coverage': 2.0.4 - '@types/istanbul-reports': 3.0.1 - '@types/jsdom': 21.1.1 - '@types/micromatch': 4.0.2 - '@types/prompts': 2.4.4 - '@types/sinonjs__fake-timers': 8.1.2 - birpc: 0.2.12 - chai-subset: 1.6.0 - cli-truncate: 3.1.0 - event-target-polyfill: 0.0.3 - execa: 7.1.1 - expect-type: 0.16.0 - fast-glob: 3.3.0 - find-up: 6.3.0 - flatted: 3.2.7 - get-tsconfig: 4.6.2 - happy-dom: 9.20.3 - jsdom: 22.1.0 - log-update: 5.0.1 - micromatch: 4.0.5 - mlly: 1.4.0 - p-limit: 4.0.0 - pkg-types: 1.0.3 - playwright: 1.36.0 - pretty-format: 29.6.1 - prompts: 2.4.2 - safaridriver: 0.0.5 - strip-ansi: 7.1.0 - webdriverio: 8.12.1 - ws: 8.13.0 + '@ampproject/remapping': + specifier: ^2.2.1 + version: 2.2.1 + '@antfu/install-pkg': + specifier: ^0.1.1 + version: 0.1.1 + '@edge-runtime/vm': + specifier: 3.0.3 + version: 3.0.3 + '@jridgewell/trace-mapping': + specifier: ^0.3.18 + version: 0.3.18 + '@sinonjs/fake-timers': + specifier: ^11.0.0 + version: 11.0.0 + '@types/diff': + specifier: ^5.0.3 + version: 5.0.3 + '@types/estree': + specifier: ^1.0.1 + version: 1.0.1 + '@types/istanbul-lib-coverage': + specifier: ^2.0.4 + version: 2.0.4 + '@types/istanbul-reports': + specifier: ^3.0.1 + version: 3.0.1 + '@types/jsdom': + specifier: ^21.1.1 + version: 21.1.1 + '@types/micromatch': + specifier: ^4.0.2 + version: 4.0.2 + '@types/prompts': + specifier: ^2.4.4 + version: 2.4.4 + '@types/sinonjs__fake-timers': + specifier: ^8.1.2 + version: 8.1.2 + birpc: + specifier: 0.2.12 + version: 0.2.12 + chai-subset: + specifier: ^1.6.0 + version: 1.6.0 + cli-truncate: + specifier: ^3.1.0 + version: 3.1.0 + event-target-polyfill: + specifier: ^0.0.3 + version: 0.0.3 + execa: + specifier: ^7.1.1 + version: 7.1.1 + expect-type: + specifier: ^0.16.0 + version: 0.16.0 + fast-glob: + specifier: ^3.3.0 + version: 3.3.0 + find-up: + specifier: ^6.3.0 + version: 6.3.0 + flatted: + specifier: ^3.2.7 + version: 3.2.7 + get-tsconfig: + specifier: ^4.6.2 + version: 4.6.2 + happy-dom: + specifier: ^9.20.3 + version: 9.20.3 + jsdom: + specifier: ^22.1.0 + version: 22.1.0 + log-update: + specifier: ^5.0.1 + version: 5.0.1 + micromatch: + specifier: ^4.0.5 + version: 4.0.5 + mlly: + specifier: ^1.4.0 + version: 1.4.0 + p-limit: + specifier: ^4.0.0 + version: 4.0.0 + pkg-types: + specifier: ^1.0.3 + version: 1.0.3 + playwright: + specifier: ^1.35.1 + version: 1.36.0 + pretty-format: + specifier: ^29.5.0 + version: 29.6.1 + prompts: + specifier: ^2.4.2 + version: 2.4.2 + safaridriver: + specifier: ^0.0.5 + version: 0.0.5 + strip-ansi: + specifier: ^7.1.0 + version: 7.1.0 + webdriverio: + specifier: ^8.11.2 + version: 8.12.1(typescript@5.1.6) + ws: + specifier: ^8.13.0 + version: 8.13.0 packages/web-worker: - specifiers: - '@types/debug': ^4.1.8 - '@types/ungap__structured-clone': ^0.3.0 - '@ungap/structured-clone': ^1.2.0 - debug: ^4.3.4 dependencies: - debug: 4.3.4 + debug: + specifier: ^4.3.4 + version: 4.3.4(supports-color@8.1.1) + vitest: + specifier: '>=0.33.0' + version: link:../vitest devDependencies: - '@types/debug': 4.1.8 - '@types/ungap__structured-clone': 0.3.0 - '@ungap/structured-clone': 1.2.0 + '@types/debug': + specifier: ^4.1.8 + version: 4.1.8 + '@types/ungap__structured-clone': + specifier: ^0.3.0 + version: 0.3.0 + '@ungap/structured-clone': + specifier: ^1.2.0 + version: 1.2.0 packages/ws-client: - specifiers: - '@vitest/runner': workspace:* - birpc: 0.2.12 - flatted: ^3.2.7 - rollup: ^2.79.1 - ws: ^8.13.0 - dependencies: - birpc: 0.2.12 - flatted: 3.2.7 - ws: 8.13.0 + dependencies: + birpc: + specifier: 0.2.12 + version: 0.2.12 + flatted: + specifier: ^3.2.7 + version: 3.2.7 + ws: + specifier: ^8.13.0 + version: 8.13.0 devDependencies: - '@vitest/runner': link:../runner - rollup: 2.79.1 + '@vitest/runner': + specifier: workspace:* + version: link:../runner + rollup: + specifier: ^2.79.1 + version: 2.79.1 test/bail: - specifiers: - '@vitest/browser': workspace:* - vite: ^4.3.9 - vitest: workspace:* - webdriverio: latest devDependencies: - '@vitest/browser': link:../../packages/browser - vite: 4.4.3 - vitest: link:../../packages/vitest - webdriverio: 8.12.1 + '@vitest/browser': + specifier: workspace:* + version: link:../../packages/browser + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest + webdriverio: + specifier: latest + version: 8.12.1(typescript@5.1.6) test/base: - specifiers: - vitest: workspace:* devDependencies: - vitest: link:../../packages/vitest + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/benchmark: - specifiers: - vitest: workspace:* devDependencies: - vitest: link:../../packages/vitest + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/browser: - specifiers: - '@vitest/browser': workspace:* - execa: ^7.1.1 - safaridriver: ^0.0.4 - vitest: workspace:* devDependencies: - '@vitest/browser': link:../../packages/browser - execa: 7.1.1 - safaridriver: 0.0.4 - vitest: link:../../packages/vitest + '@vitest/browser': + specifier: workspace:* + version: link:../../packages/browser + execa: + specifier: ^7.1.1 + version: 7.1.1 + safaridriver: + specifier: ^0.0.4 + version: 0.0.4 + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/cache: - specifiers: - vitest: workspace:* devDependencies: - vitest: link:../../packages/vitest + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/cjs: - specifiers: - '@types/fs-extra': ^9.0.13 - '@types/prettier': ^2.6.1 - fs-extra: ^10.1.0 - givens: 1.3.9 - history: ^5.3.0 - lodash: ^4.17.21 - prettier: ^2.6.2 - temp-dir: ^2.0.0 - vitest: workspace:* devDependencies: - '@types/fs-extra': 9.0.13 - '@types/prettier': 2.7.3 - fs-extra: 10.1.0 - givens: 1.3.9 - history: 5.3.0 - lodash: 4.17.21 - prettier: 2.8.8 - temp-dir: 2.0.0 - vitest: link:../../packages/vitest + '@types/fs-extra': + specifier: ^9.0.13 + version: 9.0.13 + '@types/prettier': + specifier: ^2.6.1 + version: 2.7.3 + fs-extra: + specifier: ^10.1.0 + version: 10.1.0 + givens: + specifier: 1.3.9 + version: 1.3.9 + history: + specifier: ^5.3.0 + version: 5.3.0 + lodash: + specifier: ^4.17.21 + version: 4.17.21 + prettier: + specifier: ^2.6.2 + version: 2.8.8 + temp-dir: + specifier: ^2.0.0 + version: 2.0.0 + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/config: - specifiers: - vite: ^4.3.9 - vitest: workspace:* devDependencies: - vite: 4.4.3 - vitest: link:../../packages/vitest + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/core: - specifiers: - '@vitest/expect': workspace:* - '@vitest/runner': workspace:* - '@vitest/utils': workspace:* - acorn: ^8.8.2 - tinyspy: ^1.0.2 - url: ^0.11.0 - vitest: workspace:* devDependencies: - '@vitest/expect': link:../../packages/expect - '@vitest/runner': link:../../packages/runner - '@vitest/utils': link:../../packages/utils - acorn: 8.10.0 - tinyspy: 1.1.1 - url: 0.11.1 - vitest: link:../../packages/vitest + '@vitest/expect': + specifier: workspace:* + version: link:../../packages/expect + '@vitest/runner': + specifier: workspace:* + version: link:../../packages/runner + '@vitest/utils': + specifier: workspace:* + version: link:../../packages/utils + acorn: + specifier: ^8.8.2 + version: 8.10.0 + tinyspy: + specifier: ^1.0.2 + version: 1.1.1 + url: + specifier: ^0.11.0 + version: 0.11.1 + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/coverage-test: - specifiers: - '@types/istanbul-lib-coverage': ^2.0.4 - '@vitejs/plugin-vue': latest - '@vitest/browser': workspace:* - '@vitest/coverage-istanbul': workspace:* - '@vitest/coverage-v8': workspace:* - '@vue/test-utils': latest - happy-dom: latest - istanbul-lib-coverage: ^3.2.0 - vite: ^4.3.9 - vitest: workspace:* - vue: latest - webdriverio: latest devDependencies: - '@types/istanbul-lib-coverage': 2.0.4 - '@vitejs/plugin-vue': 4.2.3_vite@4.4.3+vue@3.3.4 - '@vitest/browser': link:../../packages/browser - '@vitest/coverage-istanbul': link:../../packages/coverage-istanbul - '@vitest/coverage-v8': link:../../packages/coverage-v8 - '@vue/test-utils': 2.4.0_vue@3.3.4 - happy-dom: 10.1.1 - istanbul-lib-coverage: 3.2.0 - vite: 4.4.3 - vitest: link:../../packages/vitest - vue: 3.3.4 - webdriverio: 8.12.1 + '@types/istanbul-lib-coverage': + specifier: ^2.0.4 + version: 2.0.4 + '@vitejs/plugin-vue': + specifier: latest + version: 4.2.3(vite@4.4.3)(vue@3.3.4) + '@vitest/browser': + specifier: workspace:* + version: link:../../packages/browser + '@vitest/coverage-istanbul': + specifier: workspace:* + version: link:../../packages/coverage-istanbul + '@vitest/coverage-v8': + specifier: workspace:* + version: link:../../packages/coverage-v8 + '@vue/test-utils': + specifier: latest + version: 2.4.0(vue@3.3.4) + happy-dom: + specifier: latest + version: 10.1.1 + istanbul-lib-coverage: + specifier: ^3.2.0 + version: 3.2.0 + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest + vue: + specifier: latest + version: 3.3.4 + webdriverio: + specifier: latest + version: 8.12.1(typescript@5.1.6) test/css: - specifiers: - jsdom: ^20.0.0 - vitest: workspace:* devDependencies: - jsdom: 20.0.3 - vitest: link:../../packages/vitest + jsdom: + specifier: ^20.0.0 + version: 20.0.3 + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/edge-runtime: - specifiers: - '@edge-runtime/vm': 1.1.0-beta.26 - '@vitest/web-worker': workspace:* - vitest: workspace:* devDependencies: - '@edge-runtime/vm': 1.1.0-beta.26 - '@vitest/web-worker': link:../../packages/web-worker - vitest: link:../../packages/vitest + '@edge-runtime/vm': + specifier: 1.1.0-beta.26 + version: 1.1.0-beta.26 + '@vitest/web-worker': + specifier: workspace:* + version: link:../../packages/web-worker + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/env-custom: - specifiers: - vitest: workspace:* - vitest-environment-custom: file:./vitest-environment-custom devDependencies: - vitest: link:../../packages/vitest - vitest-environment-custom: file:test/env-custom/vitest-environment-custom + vitest: + specifier: workspace:* + version: link:../../packages/vitest + vitest-environment-custom: + specifier: file:./vitest-environment-custom + version: file:test/env-custom/vitest-environment-custom test/env-glob: - specifiers: - vitest: workspace:* devDependencies: - vitest: link:../../packages/vitest + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/env-mixed: - specifiers: - happy-dom: latest - vite: ^4.3.9 - vitest: workspace:* devDependencies: - happy-dom: 10.1.1 - vite: 4.4.3 - vitest: link:../../packages/vitest + happy-dom: + specifier: latest + version: 10.1.1 + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/esm: - specifiers: - css-what: 6.1.0 - tslib: 2.4.0 - vitest: workspace:* dependencies: - css-what: 6.1.0 - tslib: 2.4.0 + css-what: + specifier: 6.1.0 + version: 6.1.0 + tslib: + specifier: 2.4.0 + version: 2.4.0 devDependencies: - vitest: link:../../packages/vitest + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/failing: - specifiers: - '@vitest/runner': workspace:* - vitest: workspace:* devDependencies: - '@vitest/runner': link:../../packages/runner - vitest: link:../../packages/vitest + '@vitest/runner': + specifier: workspace:* + version: link:../../packages/runner + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/fails: - specifiers: - '@vitest/coverage-istanbul': workspace:* - jsdom: ^21.0.0 - vitest: workspace:* devDependencies: - '@vitest/coverage-istanbul': link:../../packages/coverage-istanbul - jsdom: 21.1.2 - vitest: link:../../packages/vitest + '@vitest/coverage-istanbul': + specifier: workspace:* + version: link:../../packages/coverage-istanbul + jsdom: + specifier: ^21.0.0 + version: 21.1.2 + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/filters: - specifiers: - vite: ^4.3.9 - vitest: workspace:* devDependencies: - vite: 4.4.3 - vitest: link:../../packages/vitest + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/global-setup: - specifiers: - vitest: workspace:* devDependencies: - vitest: link:../../packages/vitest + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/global-setup-fail: - specifiers: - vitest: workspace:* devDependencies: - vitest: link:../../packages/vitest + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/import-meta: - specifiers: - vitest: workspace:* devDependencies: - vitest: link:../../packages/vitest + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/mixed-pools: - specifiers: - vitest: workspace:* devDependencies: - vitest: link:../../packages/vitest + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/path-resolution: - specifiers: - '@edge-runtime/vm': 1.1.0-beta.26 - '@vitest/test-path-resolution-target': workspace:* - '@vitest/web-worker': workspace:* - vitest: workspace:* devDependencies: - '@edge-runtime/vm': 1.1.0-beta.26 - '@vitest/test-path-resolution-target': link:../path-resolution-target - '@vitest/web-worker': link:../../packages/web-worker - vitest: link:../../packages/vitest - - test/path-resolution-target: - specifiers: {} + '@edge-runtime/vm': + specifier: 1.1.0-beta.26 + version: 1.1.0-beta.26 + '@vitest/test-path-resolution-target': + specifier: workspace:* + version: link:../path-resolution-target + '@vitest/web-worker': + specifier: workspace:* + version: link:../../packages/web-worker + vitest: + specifier: workspace:* + version: link:../../packages/vitest + + test/path-resolution-target: {} test/public-api: - specifiers: - '@vitest/browser': workspace:* - vitest: workspace:* devDependencies: - '@vitest/browser': link:../../packages/browser - vitest: link:../../packages/vitest + '@vitest/browser': + specifier: workspace:* + version: link:../../packages/browser + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/related: - specifiers: - vitest: workspace:* devDependencies: - vitest: link:../../packages/vitest + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/reporters: - specifiers: - flatted: ^3.2.7 - pkg-reporter: ./reportPkg/ - strip-ansi: ^7.0.1 - vitest: workspace:* - vitest-sonar-reporter: 0.3.3 devDependencies: - flatted: 3.2.7 - pkg-reporter: link:reportPkg - strip-ansi: 7.1.0 - vitest: link:../../packages/vitest - vitest-sonar-reporter: 0.3.3_vitest@packages+vitest + flatted: + specifier: ^3.2.7 + version: 3.2.7 + pkg-reporter: + specifier: ./reportPkg/ + version: link:reportPkg + strip-ansi: + specifier: ^7.0.1 + version: 7.1.0 + vitest: + specifier: workspace:* + version: link:../../packages/vitest + vitest-sonar-reporter: + specifier: 0.3.3 + version: 0.3.3(vitest@packages+vitest) test/resolve: - specifiers: - happy-dom: ^9.20.3 - vitest: workspace:* devDependencies: - happy-dom: 9.20.3 - vitest: link:../../packages/vitest + happy-dom: + specifier: ^9.20.3 + version: 9.20.3 + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/run: - specifiers: - vite: ^4.3.9 - vitest: workspace:* devDependencies: - vite: 4.4.3 - vitest: link:../../packages/vitest + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/run-once: - specifiers: - vitest: workspace:* devDependencies: - vitest: link:../../packages/vitest + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/setup: - specifiers: - vitest: workspace:* devDependencies: - vitest: link:../../packages/vitest + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/shard: - specifiers: - vitest: workspace:* devDependencies: - vitest: link:../../packages/vitest + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/single-thread: - specifiers: - vitest: workspace:* devDependencies: - vitest: link:../../packages/vitest + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/snapshots: - specifiers: - vitest: workspace:* dependencies: - vitest: link:../../packages/vitest + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/stacktraces: - specifiers: - vitest: workspace:* devDependencies: - vitest: link:../../packages/vitest + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/test-utils: - specifiers: - execa: ^7.1.1 - strip-ansi: ^7.0.1 - vite: ^4.3.9 - vitest: workspace:* devDependencies: - execa: 7.1.1 - strip-ansi: 7.1.0 - vite: 4.4.3 - vitest: link:../../packages/vitest + execa: + specifier: ^7.1.1 + version: 7.1.1 + strip-ansi: + specifier: ^7.0.1 + version: 7.1.0 + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/typescript: - specifiers: - typescript: ^4.8.4 - vitest: workspace:* - vue-tsc: ^0.40.13 dependencies: - vitest: link:../../packages/vitest + vitest: + specifier: workspace:* + version: link:../../packages/vitest devDependencies: - typescript: 4.9.5 - vue-tsc: 0.40.13_typescript@4.9.5 + typescript: + specifier: ^4.8.4 + version: 4.9.5 + vue-tsc: + specifier: ^0.40.13 + version: 0.40.13(typescript@4.9.5) test/ui: - specifiers: - execa: ^6.1.0 - fs-extra: ^10.1.0 - playwright-chromium: ^1.27.0 - vitest: workspace:* devDependencies: - execa: 6.1.0 - fs-extra: 10.1.0 - playwright-chromium: 1.36.0 - vitest: link:../../packages/vitest + execa: + specifier: ^6.1.0 + version: 6.1.0 + fs-extra: + specifier: ^10.1.0 + version: 10.1.0 + playwright-chromium: + specifier: ^1.27.0 + version: 1.36.0 + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/utils: - specifiers: - '@vitest/utils': workspace:* - vitest: workspace:* devDependencies: - '@vitest/utils': link:../../packages/utils - vitest: link:../../packages/vitest + '@vitest/utils': + specifier: workspace:* + version: link:../../packages/utils + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/vite-config: - specifiers: - pathe: ^1.1.0 - vitest: workspace:* devDependencies: - pathe: 1.1.1 - vitest: link:../../packages/vitest + pathe: + specifier: ^1.1.0 + version: 1.1.1 + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/vite-node: - specifiers: - '@types/inquirer': ^9.0.3 - execa: ^6.1.0 - inquirer: ^9.2.7 - vite-node: workspace:* - vitest: workspace:* devDependencies: - '@types/inquirer': 9.0.3 - execa: 6.1.0 - inquirer: 9.2.7 - vite-node: link:../../packages/vite-node - vitest: link:../../packages/vitest + '@types/inquirer': + specifier: ^9.0.3 + version: 9.0.3 + execa: + specifier: ^6.1.0 + version: 6.1.0 + inquirer: + specifier: ^9.2.7 + version: 9.2.7 + vite-node: + specifier: workspace:* + version: link:../../packages/vite-node + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/watch: - specifiers: - '@vitest/browser': workspace:* - vite: ^4.3.9 - vitest: workspace:* - webdriverio: latest devDependencies: - '@vitest/browser': link:../../packages/browser - vite: 4.4.3 - vitest: link:../../packages/vitest - webdriverio: 8.12.1 + '@vitest/browser': + specifier: workspace:* + version: link:../../packages/browser + vite: + specifier: ^4.3.9 + version: 4.4.3(@types/node@18.16.19) + vitest: + specifier: workspace:* + version: link:../../packages/vitest + webdriverio: + specifier: latest + version: 8.12.1(typescript@5.1.6) test/web-worker: - specifiers: - '@vitest/web-worker': workspace:* - vitest: workspace:* devDependencies: - '@vitest/web-worker': link:../../packages/web-worker - vitest: link:../../packages/vitest + '@vitest/web-worker': + specifier: workspace:* + version: link:../../packages/web-worker + vitest: + specifier: workspace:* + version: link:../../packages/vitest test/workspaces: - specifiers: - '@types/istanbul-lib-coverage': ^2.0.4 - istanbul-lib-coverage: ^3.2.0 - jsdom: latest - vitest: workspace:* devDependencies: - '@types/istanbul-lib-coverage': 2.0.4 - istanbul-lib-coverage: 3.2.0 - jsdom: 22.1.0 - vitest: link:../../packages/vitest + '@types/istanbul-lib-coverage': + specifier: ^2.0.4 + version: 2.0.4 + istanbul-lib-coverage: + specifier: ^3.2.0 + version: 3.2.0 + jsdom: + specifier: latest + version: 22.1.0 + vitest: + specifier: workspace:* + version: link:../../packages/vitest packages: - /@aashutoshrathi/word-wrap/1.2.6: + /@aashutoshrathi/word-wrap@1.2.6: resolution: {integrity: sha512-1Yjs2SvM8TflER/OD3cOjhWWOZb58A2t7wpE2S9XfBYTiIl+XFhQG2bjy4Pu1I+EAlCNUzRDYDdFwFYUKvXcIA==} engines: {node: '>=0.10.0'} dev: true - /@adobe/css-tools/4.2.0: + /@adobe/css-tools@4.2.0: resolution: {integrity: sha512-E09FiIft46CmH5Qnjb0wsW54/YQd69LsxeKUOWawmws1XWvyFGURnAChH0mlr7YPFR1ofwvUQfcL0J3lMxXqPA==} dev: true - /@algolia/autocomplete-core/1.9.3_algoliasearch@4.18.0: + /@algolia/autocomplete-core@1.9.3(algoliasearch@4.18.0)(search-insights@2.7.0): resolution: {integrity: sha512-009HdfugtGCdC4JdXUbVJClA0q0zh24yyePn+KUGk3rP7j8FEe/m5Yo/z65gn6nP/cM39PxpzqKrL7A6fP6PPw==} dependencies: - '@algolia/autocomplete-plugin-algolia-insights': 1.9.3_algoliasearch@4.18.0 - '@algolia/autocomplete-shared': 1.9.3_algoliasearch@4.18.0 + '@algolia/autocomplete-plugin-algolia-insights': 1.9.3(algoliasearch@4.18.0)(search-insights@2.7.0) + '@algolia/autocomplete-shared': 1.9.3(algoliasearch@4.18.0) transitivePeerDependencies: - '@algolia/client-search' - algoliasearch - search-insights dev: true - /@algolia/autocomplete-plugin-algolia-insights/1.9.3_algoliasearch@4.18.0: + /@algolia/autocomplete-plugin-algolia-insights@1.9.3(algoliasearch@4.18.0)(search-insights@2.7.0): resolution: {integrity: sha512-a/yTUkcO/Vyy+JffmAnTWbr4/90cLzw+CC3bRbhnULr/EM0fGNvM13oQQ14f2moLMcVDyAx/leczLlAOovhSZg==} peerDependencies: search-insights: '>= 1 < 3' dependencies: - '@algolia/autocomplete-shared': 1.9.3_algoliasearch@4.18.0 + '@algolia/autocomplete-shared': 1.9.3(algoliasearch@4.18.0) + search-insights: 2.7.0 transitivePeerDependencies: - '@algolia/client-search' - algoliasearch dev: true - /@algolia/autocomplete-preset-algolia/1.9.3_algoliasearch@4.18.0: + /@algolia/autocomplete-preset-algolia@1.9.3(algoliasearch@4.18.0): resolution: {integrity: sha512-d4qlt6YmrLMYy95n5TB52wtNDr6EgAIPH81dvvvW8UmuWRgxEtY0NJiPwl/h95JtG2vmRM804M0DSwMCNZlzRA==} peerDependencies: '@algolia/client-search': '>= 4.9.1 < 6' @@ -1510,11 +1999,11 @@ packages: '@algolia/client-search': optional: true dependencies: - '@algolia/autocomplete-shared': 1.9.3_algoliasearch@4.18.0 + '@algolia/autocomplete-shared': 1.9.3(algoliasearch@4.18.0) algoliasearch: 4.18.0 dev: true - /@algolia/autocomplete-shared/1.9.3_algoliasearch@4.18.0: + /@algolia/autocomplete-shared@1.9.3(algoliasearch@4.18.0): resolution: {integrity: sha512-Wnm9E4Ye6Rl6sTTqjoymD+l8DjSTHsHboVRYrKgEt8Q7UHm9nYbqhN/i0fhUYA3OAEH7WA8x3jfpnmJm3rKvaQ==} peerDependencies: '@algolia/client-search': '>= 4.9.1 < 6' @@ -1526,23 +2015,23 @@ packages: algoliasearch: 4.18.0 dev: true - /@algolia/cache-browser-local-storage/4.18.0: + /@algolia/cache-browser-local-storage@4.18.0: resolution: {integrity: sha512-rUAs49NLlO8LVLgGzM4cLkw8NJLKguQLgvFmBEe3DyzlinoqxzQMHfKZs6TSq4LZfw/z8qHvRo8NcTAAUJQLcw==} dependencies: '@algolia/cache-common': 4.18.0 dev: true - /@algolia/cache-common/4.18.0: + /@algolia/cache-common@4.18.0: resolution: {integrity: sha512-BmxsicMR4doGbeEXQu8yqiGmiyvpNvejYJtQ7rvzttEAMxOPoWEHrWyzBQw4x7LrBY9pMrgv4ZlUaF8PGzewHg==} dev: true - /@algolia/cache-in-memory/4.18.0: + /@algolia/cache-in-memory@4.18.0: resolution: {integrity: sha512-evD4dA1nd5HbFdufBxLqlJoob7E2ozlqJZuV3YlirNx5Na4q1LckIuzjNYZs2ddLzuTc/Xd5O3Ibf7OwPskHxw==} dependencies: '@algolia/cache-common': 4.18.0 dev: true - /@algolia/client-account/4.18.0: + /@algolia/client-account@4.18.0: resolution: {integrity: sha512-XsDnlROr3+Z1yjxBJjUMfMazi1V155kVdte6496atvBgOEtwCzTs3A+qdhfsAnGUvaYfBrBkL0ThnhMIBCGcew==} dependencies: '@algolia/client-common': 4.18.0 @@ -1550,7 +2039,7 @@ packages: '@algolia/transporter': 4.18.0 dev: true - /@algolia/client-analytics/4.18.0: + /@algolia/client-analytics@4.18.0: resolution: {integrity: sha512-chEUSN4ReqU7uRQ1C8kDm0EiPE+eJeAXiWcBwLhEynfNuTfawN9P93rSZktj7gmExz0C8XmkbBU19IQ05wCNrQ==} dependencies: '@algolia/client-common': 4.18.0 @@ -1559,14 +2048,14 @@ packages: '@algolia/transporter': 4.18.0 dev: true - /@algolia/client-common/4.18.0: + /@algolia/client-common@4.18.0: resolution: {integrity: sha512-7N+soJFP4wn8tjTr3MSUT/U+4xVXbz4jmeRfWfVAzdAbxLAQbHa0o/POSdTvQ8/02DjCLelloZ1bb4ZFVKg7Wg==} dependencies: '@algolia/requester-common': 4.18.0 '@algolia/transporter': 4.18.0 dev: true - /@algolia/client-personalization/4.18.0: + /@algolia/client-personalization@4.18.0: resolution: {integrity: sha512-+PeCjODbxtamHcPl+couXMeHEefpUpr7IHftj4Y4Nia1hj8gGq4VlIcqhToAw8YjLeCTfOR7r7xtj3pJcYdP8A==} dependencies: '@algolia/client-common': 4.18.0 @@ -1574,7 +2063,7 @@ packages: '@algolia/transporter': 4.18.0 dev: true - /@algolia/client-search/4.18.0: + /@algolia/client-search@4.18.0: resolution: {integrity: sha512-F9xzQXTjm6UuZtnsLIew6KSraXQ0AzS/Ee+OD+mQbtcA/K1sg89tqb8TkwjtiYZ0oij13u3EapB3gPZwm+1Y6g==} dependencies: '@algolia/client-common': 4.18.0 @@ -1582,33 +2071,33 @@ packages: '@algolia/transporter': 4.18.0 dev: true - /@algolia/logger-common/4.18.0: + /@algolia/logger-common@4.18.0: resolution: {integrity: sha512-46etYgSlkoKepkMSyaoriSn2JDgcrpc/nkOgou/lm0y17GuMl9oYZxwKKTSviLKI5Irk9nSKGwnBTQYwXOYdRg==} dev: true - /@algolia/logger-console/4.18.0: + /@algolia/logger-console@4.18.0: resolution: {integrity: sha512-3P3VUYMl9CyJbi/UU1uUNlf6Z8N2ltW3Oqhq/nR7vH0CjWv32YROq3iGWGxB2xt3aXobdUPXs6P0tHSKRmNA6g==} dependencies: '@algolia/logger-common': 4.18.0 dev: true - /@algolia/requester-browser-xhr/4.18.0: + /@algolia/requester-browser-xhr@4.18.0: resolution: {integrity: sha512-/AcWHOBub2U4TE/bPi4Gz1XfuLK6/7dj4HJG+Z2SfQoS1RjNLshZclU3OoKIkFp8D2NC7+BNsPvr9cPLyW8nyQ==} dependencies: '@algolia/requester-common': 4.18.0 dev: true - /@algolia/requester-common/4.18.0: + /@algolia/requester-common@4.18.0: resolution: {integrity: sha512-xlT8R1qYNRBCi1IYLsx7uhftzdfsLPDGudeQs+xvYB4sQ3ya7+ppolB/8m/a4F2gCkEO6oxpp5AGemM7kD27jA==} dev: true - /@algolia/requester-node-http/4.18.0: + /@algolia/requester-node-http@4.18.0: resolution: {integrity: sha512-TGfwj9aeTVgOUhn5XrqBhwUhUUDnGIKlI0kCBMdR58XfXcfdwomka+CPIgThRbfYw04oQr31A6/95ZH2QVJ9UQ==} dependencies: '@algolia/requester-common': 4.18.0 dev: true - /@algolia/transporter/4.18.0: + /@algolia/transporter@4.18.0: resolution: {integrity: sha512-xbw3YRUGtXQNG1geYFEDDuFLZt4Z8YNKbamHPkzr3rWc6qp4/BqEeXcI2u/P/oMq2yxtXgMxrCxOPA8lyIe5jw==} dependencies: '@algolia/cache-common': 4.18.0 @@ -1616,31 +2105,31 @@ packages: '@algolia/requester-common': 4.18.0 dev: true - /@ampproject/remapping/2.2.1: + /@ampproject/remapping@2.2.1: resolution: {integrity: sha512-lFMjJTrFL3j7L9yBxwYfCq2k6qqwHyzuUl/XBnif78PWTJYyL/dfowQHWE3sp6U6ZzqWiiIZnpTMO96zhkjwtg==} engines: {node: '>=6.0.0'} dependencies: '@jridgewell/gen-mapping': 0.3.3 '@jridgewell/trace-mapping': 0.3.18 - /@antfu/eslint-config-basic/0.39.7_hoiolsckdkz7sxrkgp2zqjnw7y: + /@antfu/eslint-config-basic@0.39.7(@typescript-eslint/eslint-plugin@5.62.0)(@typescript-eslint/parser@5.62.0)(eslint@8.44.0)(typescript@5.1.6): resolution: {integrity: sha512-R7usUebEr+T5EcZ8sMy2/naNU5etpXtzC34wHCEBETlmYVGQpkYcpSztDy67T3B3Ywj95VsgGLDjW77fANW/LQ==} peerDependencies: eslint: '>=7.4.0' dependencies: eslint: 8.44.0 - eslint-plugin-antfu: 0.39.7_iqf7tbmerllfqanu4l3d6aqdn4 - eslint-plugin-eslint-comments: 3.2.0_eslint@8.44.0 + eslint-plugin-antfu: 0.39.7(eslint@8.44.0)(typescript@5.1.6) + eslint-plugin-eslint-comments: 3.2.0(eslint@8.44.0) eslint-plugin-html: 7.1.0 - eslint-plugin-import: /eslint-plugin-i/2.27.5-3_owyyv4y74swggqrdagvp7hd7n4 - eslint-plugin-jsonc: 2.9.0_eslint@8.44.0 - eslint-plugin-markdown: 3.0.0_eslint@8.44.0 - eslint-plugin-n: 16.0.1_eslint@8.44.0 + eslint-plugin-import: /eslint-plugin-i@2.27.5-3(@typescript-eslint/parser@5.62.0)(eslint@8.44.0) + eslint-plugin-jsonc: 2.9.0(eslint@8.44.0) + eslint-plugin-markdown: 3.0.0(eslint@8.44.0) + eslint-plugin-n: 16.0.1(eslint@8.44.0) eslint-plugin-no-only-tests: 3.1.0 - eslint-plugin-promise: 6.1.1_eslint@8.44.0 - eslint-plugin-unicorn: 47.0.0_eslint@8.44.0 - eslint-plugin-unused-imports: 2.0.0_fjgzgq23hjlrbj45h2rdrfisla - eslint-plugin-yml: 1.8.0_eslint@8.44.0 + eslint-plugin-promise: 6.1.1(eslint@8.44.0) + eslint-plugin-unicorn: 47.0.0(eslint@8.44.0) + eslint-plugin-unused-imports: 2.0.0(@typescript-eslint/eslint-plugin@5.62.0)(eslint@8.44.0) + eslint-plugin-yml: 1.8.0(eslint@8.44.0) jsonc-eslint-parser: 2.3.0 yaml-eslint-parser: 1.2.2 transitivePeerDependencies: @@ -1652,17 +2141,17 @@ packages: - typescript dev: true - /@antfu/eslint-config-ts/0.39.7_iqf7tbmerllfqanu4l3d6aqdn4: + /@antfu/eslint-config-ts@0.39.7(eslint@8.44.0)(typescript@5.1.6): resolution: {integrity: sha512-EaeR9VeCGFMNUr4mf8DBJa82UfZNM9o2fc27sVzX3ORDEjf6wtsc2YVVBlKlhAoZBNTj2qtX2DeCNC38N/j+Lg==} peerDependencies: eslint: '>=7.4.0' typescript: '>=3.9' dependencies: - '@antfu/eslint-config-basic': 0.39.7_hoiolsckdkz7sxrkgp2zqjnw7y - '@typescript-eslint/eslint-plugin': 5.62.0_l3h7p4bxv72z3fumgmc6kvfciu - '@typescript-eslint/parser': 5.62.0_iqf7tbmerllfqanu4l3d6aqdn4 + '@antfu/eslint-config-basic': 0.39.7(@typescript-eslint/eslint-plugin@5.62.0)(@typescript-eslint/parser@5.62.0)(eslint@8.44.0)(typescript@5.1.6) + '@typescript-eslint/eslint-plugin': 5.62.0(@typescript-eslint/parser@5.62.0)(eslint@8.44.0)(typescript@5.1.6) + '@typescript-eslint/parser': 5.62.0(eslint@8.44.0)(typescript@5.1.6) eslint: 8.44.0 - eslint-plugin-jest: 27.2.2_qtrczavcy63fstz24hwardykcu + eslint-plugin-jest: 27.2.2(@typescript-eslint/eslint-plugin@5.62.0)(eslint@8.44.0)(typescript@5.1.6) typescript: 5.1.6 transitivePeerDependencies: - eslint-import-resolver-typescript @@ -1671,15 +2160,15 @@ packages: - supports-color dev: true - /@antfu/eslint-config-vue/0.39.7_hoiolsckdkz7sxrkgp2zqjnw7y: + /@antfu/eslint-config-vue@0.39.7(@typescript-eslint/eslint-plugin@5.62.0)(@typescript-eslint/parser@5.62.0)(eslint@8.44.0)(typescript@5.1.6): resolution: {integrity: sha512-YAhU+88cu9c/TFY4VIs4MhOzaxK7ZPiT7DVs+4PpQvTEOOV17dZipp7HGJHfBK/5MtscCm7FGWuo5TamN5gydw==} peerDependencies: eslint: '>=7.4.0' dependencies: - '@antfu/eslint-config-basic': 0.39.7_hoiolsckdkz7sxrkgp2zqjnw7y - '@antfu/eslint-config-ts': 0.39.7_iqf7tbmerllfqanu4l3d6aqdn4 + '@antfu/eslint-config-basic': 0.39.7(@typescript-eslint/eslint-plugin@5.62.0)(@typescript-eslint/parser@5.62.0)(eslint@8.44.0)(typescript@5.1.6) + '@antfu/eslint-config-ts': 0.39.7(eslint@8.44.0)(typescript@5.1.6) eslint: 8.44.0 - eslint-plugin-vue: 9.15.1_eslint@8.44.0 + eslint-plugin-vue: 9.15.1(eslint@8.44.0) local-pkg: 0.4.3 transitivePeerDependencies: - '@typescript-eslint/eslint-plugin' @@ -1691,24 +2180,24 @@ packages: - typescript dev: true - /@antfu/eslint-config/0.39.7_iqf7tbmerllfqanu4l3d6aqdn4: + /@antfu/eslint-config@0.39.7(eslint@8.44.0)(typescript@5.1.6): resolution: {integrity: sha512-xztW6zdjHz+yIaw25kn97e3s6vGtAI43YF6wdooioUJPmOXsjSYY9lRh2k3RaHzQALKbNRUjZO8KdjOOLasg1g==} peerDependencies: eslint: '>=7.4.0' dependencies: - '@antfu/eslint-config-vue': 0.39.7_hoiolsckdkz7sxrkgp2zqjnw7y - '@typescript-eslint/eslint-plugin': 5.62.0_l3h7p4bxv72z3fumgmc6kvfciu - '@typescript-eslint/parser': 5.62.0_iqf7tbmerllfqanu4l3d6aqdn4 + '@antfu/eslint-config-vue': 0.39.7(@typescript-eslint/eslint-plugin@5.62.0)(@typescript-eslint/parser@5.62.0)(eslint@8.44.0)(typescript@5.1.6) + '@typescript-eslint/eslint-plugin': 5.62.0(@typescript-eslint/parser@5.62.0)(eslint@8.44.0)(typescript@5.1.6) + '@typescript-eslint/parser': 5.62.0(eslint@8.44.0)(typescript@5.1.6) eslint: 8.44.0 - eslint-plugin-eslint-comments: 3.2.0_eslint@8.44.0 + eslint-plugin-eslint-comments: 3.2.0(eslint@8.44.0) eslint-plugin-html: 7.1.0 - eslint-plugin-import: /eslint-plugin-i/2.27.5-3_owyyv4y74swggqrdagvp7hd7n4 - eslint-plugin-jsonc: 2.9.0_eslint@8.44.0 - eslint-plugin-n: 16.0.1_eslint@8.44.0 - eslint-plugin-promise: 6.1.1_eslint@8.44.0 - eslint-plugin-unicorn: 47.0.0_eslint@8.44.0 - eslint-plugin-vue: 9.15.1_eslint@8.44.0 - eslint-plugin-yml: 1.8.0_eslint@8.44.0 + eslint-plugin-import: /eslint-plugin-i@2.27.5-3(@typescript-eslint/parser@5.62.0)(eslint@8.44.0) + eslint-plugin-jsonc: 2.9.0(eslint@8.44.0) + eslint-plugin-n: 16.0.1(eslint@8.44.0) + eslint-plugin-promise: 6.1.1(eslint@8.44.0) + eslint-plugin-unicorn: 47.0.0(eslint@8.44.0) + eslint-plugin-vue: 9.15.1(eslint@8.44.0) + eslint-plugin-yml: 1.8.0(eslint@8.44.0) jsonc-eslint-parser: 2.3.0 yaml-eslint-parser: 1.2.2 transitivePeerDependencies: @@ -1719,23 +2208,23 @@ packages: - typescript dev: true - /@antfu/install-pkg/0.1.1: + /@antfu/install-pkg@0.1.1: resolution: {integrity: sha512-LyB/8+bSfa0DFGC06zpCEfs89/XoWZwws5ygEa5D+Xsm3OfI+aXQ86VgVG7Acyef+rSZ5HE7J8rrxzrQeM3PjQ==} dependencies: execa: 5.1.1 find-up: 5.0.0 dev: true - /@antfu/ni/0.21.4: + /@antfu/ni@0.21.4: resolution: {integrity: sha512-O0Uv9LbLDSoEg26fnMDdDRiPwFJnQSoD4WnrflDwKCJm8Cx/0mV4cGxwBLXan5mGIrpK4Dd7vizf4rQm0QCEAA==} hasBin: true dev: true - /@antfu/utils/0.7.5: + /@antfu/utils@0.7.5: resolution: {integrity: sha512-dlR6LdS+0SzOAPx/TPRhnoi7hE251OVeT2Snw0RguNbBSbjUHdWr0l3vcUUDg26rEysT89kCbtw1lVorBXLLCg==} dev: true - /@apideck/better-ajv-errors/0.3.6_ajv@8.12.0: + /@apideck/better-ajv-errors@0.3.6(ajv@8.12.0): resolution: {integrity: sha512-P+ZygBLZtkp0qqOAJJVX4oX/sFo5JR3eBWwwuqHHhK0GIgQOKWrAfiAaWX0aArHkRWHMuggFEgAZNxVPwPZYaA==} engines: {node: '>=10'} peerDependencies: @@ -1747,7 +2236,7 @@ packages: leven: 3.1.0 dev: true - /@apollo/client/3.7.17_sfoxds7t5ydpegc3knd667wn6m: + /@apollo/client@3.7.17(graphql@16.7.1)(react-dom@17.0.2)(react@17.0.2): resolution: {integrity: sha512-0EErSHEtKPNl5wgWikHJbKFAzJ/k11O0WO2QyqZSHpdxdAnw7UWHY4YiLbHCFG7lhrD+NTQ3Z/H9Jn4rcikoJA==} peerDependencies: graphql: ^14.0.0 || ^15.0.0 || ^16.0.0 @@ -1765,16 +2254,17 @@ packages: subscriptions-transport-ws: optional: true dependencies: - '@graphql-typed-document-node/core': 3.2.0 + '@graphql-typed-document-node/core': 3.2.0(graphql@16.7.1) '@wry/context': 0.7.3 '@wry/equality': 0.5.6 '@wry/trie': 0.4.3 - graphql-tag: 2.12.6 + graphql: 16.7.1 + graphql-tag: 2.12.6(graphql@16.7.1) hoist-non-react-statics: 3.3.2 optimism: 0.16.2 prop-types: 15.8.1 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) response-iterator: 0.2.6 symbol-observable: 4.0.0 ts-invariant: 0.10.3 @@ -1782,17 +2272,17 @@ packages: zen-observable-ts: 1.2.5 dev: false - /@babel/code-frame/7.22.5: + /@babel/code-frame@7.22.5: resolution: {integrity: sha512-Xmwn266vad+6DAqEB2A6V/CcZVp62BbwVmcOJc2RPuwih1kw02TjQvWVWlcKGbBPd+8/0V5DEkOcizRGYsspYQ==} engines: {node: '>=6.9.0'} dependencies: '@babel/highlight': 7.22.5 - /@babel/compat-data/7.22.6: + /@babel/compat-data@7.22.6: resolution: {integrity: sha512-29tfsWTq2Ftu7MXmimyC0C5FDZv5DYxOZkh3XD3+QW4V/BYuv/LyEsjj3c0hqedEaDt6DBfDvexMKU8YevdqFg==} engines: {node: '>=6.9.0'} - /@babel/core/7.12.9: + /@babel/core@7.12.9: resolution: {integrity: sha512-gTXYh3M5wb7FRXQy+FErKFAv90BnlOuNn1QkCK2lREoPAjrQCO49+HVSrFoe5uakFAF5eenS75KbO2vQiLrTMQ==} engines: {node: '>=6.9.0'} dependencies: @@ -1805,7 +2295,7 @@ packages: '@babel/traverse': 7.22.8 '@babel/types': 7.22.5 convert-source-map: 1.9.0 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) gensync: 1.0.0-beta.2 json5: 2.2.3 lodash: 4.17.21 @@ -1816,14 +2306,14 @@ packages: - supports-color dev: true - /@babel/core/7.22.8: + /@babel/core@7.22.8: resolution: {integrity: sha512-75+KxFB4CZqYRXjx4NlR4J7yGvKumBuZTmV4NV6v09dVXXkuYVYLT68N6HCzLvfJ+fWCxQsntNzKwwIXL4bHnw==} engines: {node: '>=6.9.0'} dependencies: '@ampproject/remapping': 2.2.1 '@babel/code-frame': 7.22.5 '@babel/generator': 7.22.7 - '@babel/helper-compilation-targets': 7.22.6_@babel+core@7.22.8 + '@babel/helper-compilation-targets': 7.22.6(@babel/core@7.22.8) '@babel/helper-module-transforms': 7.22.5 '@babel/helpers': 7.22.6 '@babel/parser': 7.22.7 @@ -1832,13 +2322,13 @@ packages: '@babel/types': 7.22.5 '@nicolo-ribaudo/semver-v6': 6.3.3 convert-source-map: 1.9.0 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) gensync: 1.0.0-beta.2 json5: 2.2.3 transitivePeerDependencies: - supports-color - /@babel/generator/7.22.7: + /@babel/generator@7.22.7: resolution: {integrity: sha512-p+jPjMG+SI8yvIaxGgeW24u7q9+5+TGpZh8/CuB7RhBKd7RCy8FayNEFNNKrNK/eUcY/4ExQqLmyrvBXKsIcwQ==} engines: {node: '>=6.9.0'} dependencies: @@ -1847,21 +2337,21 @@ packages: '@jridgewell/trace-mapping': 0.3.18 jsesc: 2.5.2 - /@babel/helper-annotate-as-pure/7.22.5: + /@babel/helper-annotate-as-pure@7.22.5: resolution: {integrity: sha512-LvBTxu8bQSQkcyKOU+a1btnNFQ1dMAd0R6PyW3arXes06F6QLWLIrd681bxRPIXlrMGR3XYnW9JyML7dP3qgxg==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 dev: true - /@babel/helper-builder-binary-assignment-operator-visitor/7.22.5: + /@babel/helper-builder-binary-assignment-operator-visitor@7.22.5: resolution: {integrity: sha512-m1EP3lVOPptR+2DwD125gziZNcmoNSHGmJROKoy87loWUQyJaVXDgpmruWqDARZSmtYQ+Dl25okU8+qhVzuykw==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 dev: true - /@babel/helper-compilation-targets/7.22.6_@babel+core@7.22.8: + /@babel/helper-compilation-targets@7.22.6(@babel/core@7.22.8): resolution: {integrity: sha512-534sYEqWD9VfUm3IPn2SLcH4Q3P86XL+QvqdC7ZsFrzyyPF3T4XGiVghF6PTYNdWg6pXuoqXxNQAhbYeEInTzA==} engines: {node: '>=6.9.0'} peerDependencies: @@ -1874,7 +2364,7 @@ packages: browserslist: 4.21.9 lru-cache: 5.1.1 - /@babel/helper-create-class-features-plugin/7.22.6_@babel+core@7.22.8: + /@babel/helper-create-class-features-plugin@7.22.6(@babel/core@7.22.8): resolution: {integrity: sha512-iwdzgtSiBxF6ni6mzVnZCF3xt5qE6cEA0J7nFt8QOAWZ0zjCFceEgpn3vtb2V7WFR6QzP2jmIFOHMTRo7eNJjQ==} engines: {node: '>=6.9.0'} peerDependencies: @@ -1894,7 +2384,7 @@ packages: - supports-color dev: true - /@babel/helper-create-regexp-features-plugin/7.22.6_@babel+core@7.22.8: + /@babel/helper-create-regexp-features-plugin@7.22.6(@babel/core@7.22.8): resolution: {integrity: sha512-nBookhLKxAWo/TUCmhnaEJyLz2dekjQvv5SRpE9epWQBcpedWLKt8aZdsuT9XV5ovzR3fENLjRXVT0GsSlGGhA==} engines: {node: '>=6.9.0'} peerDependencies: @@ -1906,17 +2396,17 @@ packages: regexpu-core: 5.3.2 dev: true - /@babel/helper-define-polyfill-provider/0.1.5_@babel+core@7.22.8: + /@babel/helper-define-polyfill-provider@0.1.5(@babel/core@7.22.8): resolution: {integrity: sha512-nXuzCSwlJ/WKr8qxzW816gwyT6VZgiJG17zR40fou70yfAcqjoNyTLl/DQ+FExw5Hx5KNqshmN8Ldl/r2N7cTg==} peerDependencies: '@babel/core': ^7.4.0-0 dependencies: '@babel/core': 7.22.8 - '@babel/helper-compilation-targets': 7.22.6_@babel+core@7.22.8 + '@babel/helper-compilation-targets': 7.22.6(@babel/core@7.22.8) '@babel/helper-module-imports': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 '@babel/traverse': 7.22.8 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) lodash.debounce: 4.0.8 resolve: 1.22.2 semver: 6.3.1 @@ -1924,59 +2414,59 @@ packages: - supports-color dev: true - /@babel/helper-define-polyfill-provider/0.4.1_@babel+core@7.22.8: + /@babel/helper-define-polyfill-provider@0.4.1(@babel/core@7.22.8): resolution: {integrity: sha512-kX4oXixDxG197yhX+J3Wp+NpL2wuCFjWQAr6yX2jtCnflK9ulMI51ULFGIrWiX1jGfvAxdHp+XQCcP2bZGPs9A==} peerDependencies: '@babel/core': ^7.4.0-0 dependencies: '@babel/core': 7.22.8 - '@babel/helper-compilation-targets': 7.22.6_@babel+core@7.22.8 + '@babel/helper-compilation-targets': 7.22.6(@babel/core@7.22.8) '@babel/helper-plugin-utils': 7.22.5 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) lodash.debounce: 4.0.8 resolve: 1.22.2 transitivePeerDependencies: - supports-color dev: true - /@babel/helper-environment-visitor/7.22.5: + /@babel/helper-environment-visitor@7.22.5: resolution: {integrity: sha512-XGmhECfVA/5sAt+H+xpSg0mfrHq6FzNr9Oxh7PSEBBRUb/mL7Kz3NICXb194rCqAEdxkhPT1a88teizAFyvk8Q==} engines: {node: '>=6.9.0'} - /@babel/helper-function-name/7.22.5: + /@babel/helper-function-name@7.22.5: resolution: {integrity: sha512-wtHSq6jMRE3uF2otvfuD3DIvVhOsSNshQl0Qrd7qC9oQJzHvOL4qQXlQn2916+CXGywIjpGuIkoyZRRxHPiNQQ==} engines: {node: '>=6.9.0'} dependencies: '@babel/template': 7.22.5 '@babel/types': 7.22.5 - /@babel/helper-hoist-variables/7.22.5: + /@babel/helper-hoist-variables@7.22.5: resolution: {integrity: sha512-wGjk9QZVzvknA6yKIUURb8zY3grXCcOZt+/7Wcy8O2uctxhplmUPkOdlgoNhmdVee2c92JXbf1xpMtVNbfoxRw==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 - /@babel/helper-member-expression-to-functions/7.22.5: + /@babel/helper-member-expression-to-functions@7.22.5: resolution: {integrity: sha512-aBiH1NKMG0H2cGZqspNvsaBe6wNGjbJjuLy29aU+eDZjSbbN53BaxlpB02xm9v34pLTZ1nIQPFYn2qMZoa5BQQ==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 dev: true - /@babel/helper-module-imports/7.18.6: + /@babel/helper-module-imports@7.18.6: resolution: {integrity: sha512-0NFvs3VkuSYbFi1x2Vd6tKrywq+z/cLeYC/RJNFrIX/30Bf5aiGYbtvGXolEktzJH8o5E5KJ3tT+nkxuuZFVlA==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 dev: true - /@babel/helper-module-imports/7.22.5: + /@babel/helper-module-imports@7.22.5: resolution: {integrity: sha512-8Dl6+HD/cKifutF5qGd/8ZJi84QeAKh+CEe1sBzz8UayBBGg1dAIJrdHOcOM5b2MpzWL2yuotJTtGjETq0qjXg==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 - /@babel/helper-module-transforms/7.22.5: + /@babel/helper-module-transforms@7.22.5: resolution: {integrity: sha512-+hGKDt/Ze8GFExiVHno/2dvG5IdstpzCq0y4Qc9OJ25D4q3pKfiIP/4Vp3/JvhDkLKsDK2api3q3fpIgiIF5bw==} engines: {node: '>=6.9.0'} dependencies: @@ -1991,23 +2481,23 @@ packages: transitivePeerDependencies: - supports-color - /@babel/helper-optimise-call-expression/7.22.5: + /@babel/helper-optimise-call-expression@7.22.5: resolution: {integrity: sha512-HBwaojN0xFRx4yIvpwGqxiV2tUfl7401jlok564NgB9EHS1y6QT17FmKWm4ztqjeVdXLuC4fSvHc5ePpQjoTbw==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 dev: true - /@babel/helper-plugin-utils/7.10.4: + /@babel/helper-plugin-utils@7.10.4: resolution: {integrity: sha512-O4KCvQA6lLiMU9l2eawBPMf1xPP8xPfB3iEQw150hOVTqj/rfXz0ThTb4HEzqQfs2Bmo5Ay8BzxfzVtBrr9dVg==} dev: true - /@babel/helper-plugin-utils/7.22.5: + /@babel/helper-plugin-utils@7.22.5: resolution: {integrity: sha512-uLls06UVKgFG9QD4OeFYLEGteMIAa5kpTPcFL28yuCIIzsf6ZyKZMllKVOCZFhiZ5ptnwX4mtKdWCBE/uT4amg==} engines: {node: '>=6.9.0'} dev: true - /@babel/helper-remap-async-to-generator/7.22.5_@babel+core@7.22.8: + /@babel/helper-remap-async-to-generator@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-cU0Sq1Rf4Z55fgz7haOakIyM7+x/uCFwXpLPaeRzfoUtAEAuUZjZvFPjL/rk5rW693dIgn2hng1W7xbT7lWT4g==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2022,7 +2512,7 @@ packages: - supports-color dev: true - /@babel/helper-replace-supers/7.22.5: + /@babel/helper-replace-supers@7.22.5: resolution: {integrity: sha512-aLdNM5I3kdI/V9xGNyKSF3X/gTyMUBohTZ+/3QdQKAA9vxIiy12E+8E2HoOP1/DjeqU+g6as35QHJNMDDYpuCg==} engines: {node: '>=6.9.0'} dependencies: @@ -2036,38 +2526,38 @@ packages: - supports-color dev: true - /@babel/helper-simple-access/7.22.5: + /@babel/helper-simple-access@7.22.5: resolution: {integrity: sha512-n0H99E/K+Bika3++WNL17POvo4rKWZ7lZEp1Q+fStVbUi8nxPQEBOlTmCOxW/0JsS56SKKQ+ojAe2pHKJHN35w==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 - /@babel/helper-skip-transparent-expression-wrappers/7.22.5: + /@babel/helper-skip-transparent-expression-wrappers@7.22.5: resolution: {integrity: sha512-tK14r66JZKiC43p8Ki33yLBVJKlQDFoA8GYN67lWCDCqoL6EMMSuM9b+Iff2jHaM/RRFYl7K+iiru7hbRqNx8Q==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 dev: true - /@babel/helper-split-export-declaration/7.22.6: + /@babel/helper-split-export-declaration@7.22.6: resolution: {integrity: sha512-AsUnxuLhRYsisFiaJwvp1QF+I3KjD5FOxut14q/GzovUe6orHLesW2C7d754kRm53h5gqrz6sFl6sxc4BVtE/g==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 - /@babel/helper-string-parser/7.22.5: + /@babel/helper-string-parser@7.22.5: resolution: {integrity: sha512-mM4COjgZox8U+JcXQwPijIZLElkgEpO5rsERVDJTc2qfCDfERyob6k5WegS14SX18IIjv+XD+GrqNumY5JRCDw==} engines: {node: '>=6.9.0'} - /@babel/helper-validator-identifier/7.22.5: + /@babel/helper-validator-identifier@7.22.5: resolution: {integrity: sha512-aJXu+6lErq8ltp+JhkJUfk1MTGyuA4v7f3pA+BJ5HLfNC6nAQ0Cpi9uOquUj8Hehg0aUiHzWQbOVJGao6ztBAQ==} engines: {node: '>=6.9.0'} - /@babel/helper-validator-option/7.22.5: + /@babel/helper-validator-option@7.22.5: resolution: {integrity: sha512-R3oB6xlIVKUnxNUxbmgq7pKjxpru24zlimpE8WK47fACIlM0II/Hm1RS8IaOI7NgCr6LNS+jl5l75m20npAziw==} engines: {node: '>=6.9.0'} - /@babel/helper-wrap-function/7.22.5: + /@babel/helper-wrap-function@7.22.5: resolution: {integrity: sha512-bYqLIBSEshYcYQyfks8ewYA8S30yaGSeRslcvKMvoUk6HHPySbxHq9YRi6ghhzEU+yhQv9bP/jXnygkStOcqZw==} engines: {node: '>=6.9.0'} dependencies: @@ -2079,7 +2569,7 @@ packages: - supports-color dev: true - /@babel/helpers/7.22.6: + /@babel/helpers@7.22.6: resolution: {integrity: sha512-YjDs6y/fVOYFV8hAf1rxd1QvR9wJe1pDBZ2AREKq/SDayfPzgk0PBnVuTCE5X1acEpMMNOVUqoe+OwiZGJ+OaA==} engines: {node: '>=6.9.0'} dependencies: @@ -2089,7 +2579,7 @@ packages: transitivePeerDependencies: - supports-color - /@babel/highlight/7.22.5: + /@babel/highlight@7.22.5: resolution: {integrity: sha512-BSKlD1hgnedS5XRnGOljZawtag7H1yPfQp0tdNJCHoH6AZ+Pcm9VvkrK59/Yy593Ypg0zMxH2BxD1VPYUQ7UIw==} engines: {node: '>=6.9.0'} dependencies: @@ -2097,14 +2587,14 @@ packages: chalk: 2.4.2 js-tokens: 4.0.0 - /@babel/parser/7.22.7: + /@babel/parser@7.22.7: resolution: {integrity: sha512-7NF8pOkHP5o2vpmGgNGcfAeCvOYhGLyA3Z4eBQkT1RJlWu47n63bCs93QfJ2hIAFCil7L5P2IWhs1oToVgrL0Q==} engines: {node: '>=6.0.0'} hasBin: true dependencies: '@babel/types': 7.22.5 - /@babel/plugin-bugfix-safari-id-destructuring-collision-in-function-expression/7.22.5_@babel+core@7.22.8: + /@babel/plugin-bugfix-safari-id-destructuring-collision-in-function-expression@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-NP1M5Rf+u2Gw9qfSO4ihjcTGW5zXTi36ITLd4/EoAcEhIZ0yjMqmftDNl3QC19CX7olhrjpyU454g/2W7X0jvQ==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2114,7 +2604,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-bugfix-v8-spread-parameters-in-optional-chaining/7.22.5_@babel+core@7.22.8: + /@babel/plugin-bugfix-v8-spread-parameters-in-optional-chaining@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-31Bb65aZaUwqCbWMnZPduIZxCBngHFlzyN6Dq6KAJjtx+lx6ohKHubc61OomYi7XwVD4Ol0XCVz4h+pYFR048g==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2123,39 +2613,39 @@ packages: '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 '@babel/helper-skip-transparent-expression-wrappers': 7.22.5 - '@babel/plugin-transform-optional-chaining': 7.22.6_@babel+core@7.22.8 + '@babel/plugin-transform-optional-chaining': 7.22.6(@babel/core@7.22.8) dev: true - /@babel/plugin-proposal-class-properties/7.18.6_@babel+core@7.22.8: + /@babel/plugin-proposal-class-properties@7.18.6(@babel/core@7.22.8): resolution: {integrity: sha512-cumfXOF0+nzZrrN8Rf0t7M+tF6sZc7vhQwYQck9q1/5w2OExlD+b4v4RpMJFaV1Z7WcDRgO6FqvxqxGlwo+RHQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: '@babel/core': 7.22.8 - '@babel/helper-create-class-features-plugin': 7.22.6_@babel+core@7.22.8 + '@babel/helper-create-class-features-plugin': 7.22.6(@babel/core@7.22.8) '@babel/helper-plugin-utils': 7.22.5 transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-proposal-decorators/7.22.7_@babel+core@7.22.8: + /@babel/plugin-proposal-decorators@7.22.7(@babel/core@7.22.8): resolution: {integrity: sha512-omXqPF7Onq4Bb7wHxXjM3jSMSJvUUbvDvmmds7KI5n9Cq6Ln5I05I1W2nRlRof1rGdiUxJrxwe285WF96XlBXQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: '@babel/core': 7.22.8 - '@babel/helper-create-class-features-plugin': 7.22.6_@babel+core@7.22.8 + '@babel/helper-create-class-features-plugin': 7.22.6(@babel/core@7.22.8) '@babel/helper-plugin-utils': 7.22.5 '@babel/helper-replace-supers': 7.22.5 '@babel/helper-split-export-declaration': 7.22.6 - '@babel/plugin-syntax-decorators': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-syntax-decorators': 7.22.5(@babel/core@7.22.8) transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-proposal-export-default-from/7.22.5_@babel+core@7.22.8: + /@babel/plugin-proposal-export-default-from@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-UCe1X/hplyv6A5g2WnQ90tnHRvYL29dabCWww92lO7VdfMVTVReBTRrhiMrKQejHD9oVkdnRdwYuzUZkBVQisg==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2163,10 +2653,10 @@ packages: dependencies: '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-export-default-from': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-syntax-export-default-from': 7.22.5(@babel/core@7.22.8) dev: true - /@babel/plugin-proposal-nullish-coalescing-operator/7.18.6_@babel+core@7.22.8: + /@babel/plugin-proposal-nullish-coalescing-operator@7.18.6(@babel/core@7.22.8): resolution: {integrity: sha512-wQxQzxYeJqHcfppzBDnm1yAY0jSRkUXR2z8RePZYrKwMKgMlE8+Z6LUno+bd6LvbGh8Gltvy74+9pIYkr+XkKA==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2174,21 +2664,21 @@ packages: dependencies: '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-nullish-coalescing-operator': 7.8.3_@babel+core@7.22.8 + '@babel/plugin-syntax-nullish-coalescing-operator': 7.8.3(@babel/core@7.22.8) dev: true - /@babel/plugin-proposal-object-rest-spread/7.12.1_@babel+core@7.12.9: + /@babel/plugin-proposal-object-rest-spread@7.12.1(@babel/core@7.12.9): resolution: {integrity: sha512-s6SowJIjzlhx8o7lsFx5zmY4At6CTtDvgNQDdPzkBQucle58A6b/TTeEBYtyDgmcXjUTM+vE8YOGHZzzbc/ioA==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: '@babel/core': 7.12.9 - '@babel/helper-plugin-utils': 7.10.4 - '@babel/plugin-syntax-object-rest-spread': 7.8.3_@babel+core@7.12.9 - '@babel/plugin-transform-parameters': 7.22.5_@babel+core@7.12.9 + '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-object-rest-spread': 7.8.3(@babel/core@7.12.9) + '@babel/plugin-transform-parameters': 7.22.5(@babel/core@7.12.9) dev: true - /@babel/plugin-proposal-object-rest-spread/7.20.7_@babel+core@7.22.8: + /@babel/plugin-proposal-object-rest-spread@7.20.7(@babel/core@7.22.8): resolution: {integrity: sha512-d2S98yCiLxDVmBmE8UjGcfPvNEUbA1U5q5WxaWFUGRzJSVAZqm5W6MbPct0jxnegUZ0niLeNX+IOzEs7wYg9Dg==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2196,13 +2686,13 @@ packages: dependencies: '@babel/compat-data': 7.22.6 '@babel/core': 7.22.8 - '@babel/helper-compilation-targets': 7.22.6_@babel+core@7.22.8 + '@babel/helper-compilation-targets': 7.22.6(@babel/core@7.22.8) '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-object-rest-spread': 7.8.3_@babel+core@7.22.8 - '@babel/plugin-transform-parameters': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-syntax-object-rest-spread': 7.8.3(@babel/core@7.22.8) + '@babel/plugin-transform-parameters': 7.22.5(@babel/core@7.22.8) dev: true - /@babel/plugin-proposal-optional-chaining/7.21.0_@babel+core@7.22.8: + /@babel/plugin-proposal-optional-chaining@7.21.0(@babel/core@7.22.8): resolution: {integrity: sha512-p4zeefM72gpmEe2fkUr/OnOXpWEf8nAgk7ZYVqqfFiyIG7oFfVZcCrU64hWn5xp4tQ9LkV4bTIa5rD0KANpKNA==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2211,23 +2701,23 @@ packages: '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 '@babel/helper-skip-transparent-expression-wrappers': 7.22.5 - '@babel/plugin-syntax-optional-chaining': 7.8.3_@babel+core@7.22.8 + '@babel/plugin-syntax-optional-chaining': 7.8.3(@babel/core@7.22.8) dev: true - /@babel/plugin-proposal-private-methods/7.18.6_@babel+core@7.22.8: + /@babel/plugin-proposal-private-methods@7.18.6(@babel/core@7.22.8): resolution: {integrity: sha512-nutsvktDItsNn4rpGItSNV2sz1XwS+nfU0Rg8aCx3W3NOKVzdMjJRu0O5OkgDp3ZGICSTbgRpxZoWsxoKRvbeA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: '@babel/core': 7.22.8 - '@babel/helper-create-class-features-plugin': 7.22.6_@babel+core@7.22.8 + '@babel/helper-create-class-features-plugin': 7.22.6(@babel/core@7.22.8) '@babel/helper-plugin-utils': 7.22.5 transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-proposal-private-property-in-object/7.21.0-placeholder-for-preset-env.2_@babel+core@7.22.8: + /@babel/plugin-proposal-private-property-in-object@7.21.0-placeholder-for-preset-env.2(@babel/core@7.22.8): resolution: {integrity: sha512-SOSkfJDddaM7mak6cPEpswyTRnuRltl429hMraQEglW+OkovnCzsiszTmsrlY//qLFjCpQDFRvjdm2wA5pPm9w==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2236,7 +2726,7 @@ packages: '@babel/core': 7.22.8 dev: true - /@babel/plugin-proposal-private-property-in-object/7.21.11_@babel+core@7.22.8: + /@babel/plugin-proposal-private-property-in-object@7.21.11(@babel/core@7.22.8): resolution: {integrity: sha512-0QZ8qP/3RLDVBwBFoWAwCtgcDZJVwA5LUJRZU8x2YFfKNuFq161wK3cuGrALu5yiPu+vzwTAg/sMWVNeWeNyaw==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2244,25 +2734,25 @@ packages: dependencies: '@babel/core': 7.22.8 '@babel/helper-annotate-as-pure': 7.22.5 - '@babel/helper-create-class-features-plugin': 7.22.6_@babel+core@7.22.8 + '@babel/helper-create-class-features-plugin': 7.22.6(@babel/core@7.22.8) '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-private-property-in-object': 7.14.5_@babel+core@7.22.8 + '@babel/plugin-syntax-private-property-in-object': 7.14.5(@babel/core@7.22.8) transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-proposal-unicode-property-regex/7.18.6_@babel+core@7.22.8: + /@babel/plugin-proposal-unicode-property-regex@7.18.6(@babel/core@7.22.8): resolution: {integrity: sha512-2BShG/d5yoZyXZfVePH91urL5wTG6ASZU9M4o03lKK8u8UW1y08OMttBSOADTcJrnPMpvDXRG3G8fyLh4ovs8w==} engines: {node: '>=4'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: '@babel/core': 7.22.8 - '@babel/helper-create-regexp-features-plugin': 7.22.6_@babel+core@7.22.8 + '@babel/helper-create-regexp-features-plugin': 7.22.6(@babel/core@7.22.8) '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-async-generators/7.8.4_@babel+core@7.22.8: + /@babel/plugin-syntax-async-generators@7.8.4(@babel/core@7.22.8): resolution: {integrity: sha512-tycmZxkGfZaxhMRbXlPXuVFpdWlXpir2W4AMhSJgRKzk/eDlIXOhb2LHWoLpDF7TEHylV5zNhykX6KAgHJmTNw==} peerDependencies: '@babel/core': ^7.0.0-0 @@ -2271,7 +2761,16 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-class-properties/7.12.13_@babel+core@7.22.8: + /@babel/plugin-syntax-bigint@7.8.3(@babel/core@7.22.8): + resolution: {integrity: sha512-wnTnFlG+YxQm3vDxpGE57Pj0srRU4sHE/mDkt1qv2YJJSeUAec2ma4WLUnUPeKjyrfntVwe/N6dCXpU+zL3Npg==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.8 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-class-properties@7.12.13(@babel/core@7.22.8): resolution: {integrity: sha512-fm4idjKla0YahUNgFNLCB0qySdsoPiZP3iQE3rky0mBUtMZ23yDJ9SJdg6dXTSDnulOVqiF3Hgr9nbXvXTQZYA==} peerDependencies: '@babel/core': ^7.0.0-0 @@ -2280,7 +2779,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-class-static-block/7.14.5_@babel+core@7.22.8: + /@babel/plugin-syntax-class-static-block@7.14.5(@babel/core@7.22.8): resolution: {integrity: sha512-b+YyPmr6ldyNnM6sqYeMWE+bgJcJpO6yS4QD7ymxgH34GBPNDM/THBh8iunyvKIZztiwLH4CJZ0RxTk9emgpjw==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2290,7 +2789,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-decorators/7.22.5_@babel+core@7.22.8: + /@babel/plugin-syntax-decorators@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-avpUOBS7IU6al8MmF1XpAyj9QYeLPuSDJI5D4pVMSMdL7xQokKqJPYQC67RCT0aCTashUXPiGwMJ0DEXXCEmMA==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2300,7 +2799,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-dynamic-import/7.8.3_@babel+core@7.22.8: + /@babel/plugin-syntax-dynamic-import@7.8.3(@babel/core@7.22.8): resolution: {integrity: sha512-5gdGbFon+PszYzqs83S3E5mpi7/y/8M9eC90MRTZfduQOYW76ig6SOSPNe41IG5LoP3FGBn2N0RjVDSQiS94kQ==} peerDependencies: '@babel/core': ^7.0.0-0 @@ -2309,7 +2808,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-export-default-from/7.22.5_@babel+core@7.22.8: + /@babel/plugin-syntax-export-default-from@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-ODAqWWXB/yReh/jVQDag/3/tl6lgBueQkk/TcfW/59Oykm4c8a55XloX0CTk2k2VJiFWMgHby9xNX29IbCv9dQ==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2319,7 +2818,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-export-namespace-from/7.8.3_@babel+core@7.22.8: + /@babel/plugin-syntax-export-namespace-from@7.8.3(@babel/core@7.22.8): resolution: {integrity: sha512-MXf5laXo6c1IbEbegDmzGPwGNTsHZmEy6QGznu5Sh2UCWvueywb2ee+CCE4zQiZstxU9BMoQO9i6zUFSY0Kj0Q==} peerDependencies: '@babel/core': ^7.0.0-0 @@ -2328,7 +2827,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-flow/7.22.5_@babel+core@7.22.8: + /@babel/plugin-syntax-flow@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-9RdCl0i+q0QExayk2nOS7853w08yLucnnPML6EN9S8fgMPVtdLDCdx/cOQ/i44Lb9UeQX9A35yaqBBOMMZxPxQ==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2338,7 +2837,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-import-assertions/7.22.5_@babel+core@7.22.8: + /@babel/plugin-syntax-import-assertions@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-rdV97N7KqsRzeNGoWUOK6yUsWarLjE5Su/Snk9IYPU9CwkWHs4t+rTGOvffTR8XGkJMTAdLfO0xVnXm8wugIJg==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2348,7 +2847,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-import-attributes/7.22.5_@babel+core@7.22.8: + /@babel/plugin-syntax-import-attributes@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-KwvoWDeNKPETmozyFE0P2rOLqh39EoQHNjqizrI5B8Vt0ZNS7M56s7dAiAqbYfiAYOuIzIh96z3iR2ktgu3tEg==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2358,7 +2857,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-import-meta/7.10.4_@babel+core@7.22.8: + /@babel/plugin-syntax-import-meta@7.10.4(@babel/core@7.22.8): resolution: {integrity: sha512-Yqfm+XDx0+Prh3VSeEQCPU81yC+JWZ2pDPFSS4ZdpfZhp4MkFMaDC1UqseovEKwSUpnIL7+vK+Clp7bfh0iD7g==} peerDependencies: '@babel/core': ^7.0.0-0 @@ -2367,7 +2866,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-json-strings/7.8.3_@babel+core@7.22.8: + /@babel/plugin-syntax-json-strings@7.8.3(@babel/core@7.22.8): resolution: {integrity: sha512-lY6kdGpWHvjoe2vk4WrAapEuBR69EMxZl+RoGRhrFGNYVK8mOPAW8VfbT/ZgrFbXlDNiiaxQnAtgVCZ6jv30EA==} peerDependencies: '@babel/core': ^7.0.0-0 @@ -2376,7 +2875,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-jsx/7.12.1_@babel+core@7.12.9: + /@babel/plugin-syntax-jsx@7.12.1(@babel/core@7.12.9): resolution: {integrity: sha512-1yRi7yAtB0ETgxdY9ti/p2TivUxJkTdhu/ZbF9MshVGqOx1TdB3b7xCXs49Fupgg50N45KcAsRP/ZqWjs9SRjg==} peerDependencies: '@babel/core': ^7.0.0-0 @@ -2385,7 +2884,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-jsx/7.22.5_@babel+core@7.22.8: + /@babel/plugin-syntax-jsx@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-gvyP4hZrgrs/wWMaocvxZ44Hw0b3W8Pe+cMxc8V1ULQ07oh8VNbIRaoD1LRZVTvD+0nieDKjfgKg89sD7rrKrg==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2395,7 +2894,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-logical-assignment-operators/7.10.4_@babel+core@7.22.8: + /@babel/plugin-syntax-logical-assignment-operators@7.10.4(@babel/core@7.22.8): resolution: {integrity: sha512-d8waShlpFDinQ5MtvGU9xDAOzKH47+FFoney2baFIoMr952hKOLp1HR7VszoZvOsV/4+RRszNY7D17ba0te0ig==} peerDependencies: '@babel/core': ^7.0.0-0 @@ -2404,7 +2903,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-nullish-coalescing-operator/7.8.3_@babel+core@7.22.8: + /@babel/plugin-syntax-nullish-coalescing-operator@7.8.3(@babel/core@7.22.8): resolution: {integrity: sha512-aSff4zPII1u2QD7y+F8oDsz19ew4IGEJg9SVW+bqwpwtfFleiQDMdzA/R+UlWDzfnHFCxxleFT0PMIrR36XLNQ==} peerDependencies: '@babel/core': ^7.0.0-0 @@ -2413,7 +2912,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-numeric-separator/7.10.4_@babel+core@7.22.8: + /@babel/plugin-syntax-numeric-separator@7.10.4(@babel/core@7.22.8): resolution: {integrity: sha512-9H6YdfkcK/uOnY/K7/aA2xpzaAgkQn37yzWUMRK7OaPOqOpGS1+n0H5hxT9AUw9EsSjPW8SVyMJwYRtWs3X3ug==} peerDependencies: '@babel/core': ^7.0.0-0 @@ -2422,7 +2921,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-object-rest-spread/7.8.3_@babel+core@7.12.9: + /@babel/plugin-syntax-object-rest-spread@7.8.3(@babel/core@7.12.9): resolution: {integrity: sha512-XoqMijGZb9y3y2XskN+P1wUGiVwWZ5JmoDRwx5+3GmEplNyVM2s2Dg8ILFQm8rWM48orGy5YpI5Bl8U1y7ydlA==} peerDependencies: '@babel/core': ^7.0.0-0 @@ -2431,7 +2930,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-object-rest-spread/7.8.3_@babel+core@7.22.8: + /@babel/plugin-syntax-object-rest-spread@7.8.3(@babel/core@7.22.8): resolution: {integrity: sha512-XoqMijGZb9y3y2XskN+P1wUGiVwWZ5JmoDRwx5+3GmEplNyVM2s2Dg8ILFQm8rWM48orGy5YpI5Bl8U1y7ydlA==} peerDependencies: '@babel/core': ^7.0.0-0 @@ -2440,7 +2939,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-optional-catch-binding/7.8.3_@babel+core@7.22.8: + /@babel/plugin-syntax-optional-catch-binding@7.8.3(@babel/core@7.22.8): resolution: {integrity: sha512-6VPD0Pc1lpTqw0aKoeRTMiB+kWhAoT24PA+ksWSBrFtl5SIRVpZlwN3NNPQjehA2E/91FV3RjLWoVTglWcSV3Q==} peerDependencies: '@babel/core': ^7.0.0-0 @@ -2449,7 +2948,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-optional-chaining/7.8.3_@babel+core@7.22.8: + /@babel/plugin-syntax-optional-chaining@7.8.3(@babel/core@7.22.8): resolution: {integrity: sha512-KoK9ErH1MBlCPxV0VANkXW2/dw4vlbGDrFgz8bmUsBGYkFRcbRwMh6cIJubdPrkxRwuGdtCk0v/wPTKbQgBjkg==} peerDependencies: '@babel/core': ^7.0.0-0 @@ -2458,7 +2957,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-private-property-in-object/7.14.5_@babel+core@7.22.8: + /@babel/plugin-syntax-private-property-in-object@7.14.5(@babel/core@7.22.8): resolution: {integrity: sha512-0wVnp9dxJ72ZUJDV27ZfbSj6iHLoytYZmh3rFcxNnvsJF3ktkzLDZPy/mA17HGsaQT3/DQsWYX1f1QGWkCoVUg==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2468,7 +2967,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-top-level-await/7.14.5_@babel+core@7.22.8: + /@babel/plugin-syntax-top-level-await@7.14.5(@babel/core@7.22.8): resolution: {integrity: sha512-hx++upLv5U1rgYfwe1xBQUhRmU41NEvpUvrp8jkrSCdvGSnM5/qdRMtylJ6PG5OFkBaHkbTAKTnd3/YyESRHFw==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2478,7 +2977,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-typescript/7.22.5_@babel+core@7.22.8: + /@babel/plugin-syntax-typescript@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-1mS2o03i7t1c6VzH6fdQ3OA8tcEIxwG18zIPRp+UY1Ihv6W+XZzBCVxExF9upussPXJ0xE9XRHwMoNs1ep/nRQ==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2488,18 +2987,18 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-unicode-sets-regex/7.18.6_@babel+core@7.22.8: + /@babel/plugin-syntax-unicode-sets-regex@7.18.6(@babel/core@7.22.8): resolution: {integrity: sha512-727YkEAPwSIQTv5im8QHz3upqp92JTWhidIC81Tdx4VJYIte/VndKf1qKrfnnhPLiPghStWfvC/iFaMCQu7Nqg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0 dependencies: '@babel/core': 7.22.8 - '@babel/helper-create-regexp-features-plugin': 7.22.6_@babel+core@7.22.8 + '@babel/helper-create-regexp-features-plugin': 7.22.6(@babel/core@7.22.8) '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-arrow-functions/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-arrow-functions@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-26lTNXoVRdAnsaDXPpvCNUq+OVWEVC6bx7Vvz9rC53F2bagUWW4u4ii2+h8Fejfh7RYqPxn+libeFBBck9muEw==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2509,7 +3008,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-async-generator-functions/7.22.7_@babel+core@7.22.8: + /@babel/plugin-transform-async-generator-functions@7.22.7(@babel/core@7.22.8): resolution: {integrity: sha512-7HmE7pk/Fmke45TODvxvkxRMV9RazV+ZZzhOL9AG8G29TLrr3jkjwF7uJfxZ30EoXpO+LJkq4oA8NjO2DTnEDg==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2518,13 +3017,13 @@ packages: '@babel/core': 7.22.8 '@babel/helper-environment-visitor': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-remap-async-to-generator': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-syntax-async-generators': 7.8.4_@babel+core@7.22.8 + '@babel/helper-remap-async-to-generator': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-syntax-async-generators': 7.8.4(@babel/core@7.22.8) transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-transform-async-to-generator/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-async-to-generator@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-b1A8D8ZzE/VhNDoV1MSJTnpKkCG5bJo+19R4o4oy03zM7ws8yEMK755j61Dc3EyvdysbqH5BOOTquJ7ZX9C6vQ==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2533,12 +3032,12 @@ packages: '@babel/core': 7.22.8 '@babel/helper-module-imports': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-remap-async-to-generator': 7.22.5_@babel+core@7.22.8 + '@babel/helper-remap-async-to-generator': 7.22.5(@babel/core@7.22.8) transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-transform-block-scoped-functions/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-block-scoped-functions@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-tdXZ2UdknEKQWKJP1KMNmuF5Lx3MymtMN/pvA+p/VEkhK8jVcQ1fzSy8KM9qRYhAf2/lV33hoMPKI/xaI9sADA==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2548,7 +3047,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-block-scoping/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-block-scoping@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-EcACl1i5fSQ6bt+YGuU/XGCeZKStLmyVGytWkpyhCLeQVA0eu6Wtiw92V+I1T/hnezUv7j74dA/Ro69gWcU+hg==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2558,34 +3057,34 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-class-properties/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-class-properties@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-nDkQ0NfkOhPTq8YCLiWNxp1+f9fCobEjCb0n8WdbNUBc4IB5V7P1QnX9IjpSoquKrXF5SKojHleVNs2vGeHCHQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: '@babel/core': 7.22.8 - '@babel/helper-create-class-features-plugin': 7.22.6_@babel+core@7.22.8 + '@babel/helper-create-class-features-plugin': 7.22.6(@babel/core@7.22.8) '@babel/helper-plugin-utils': 7.22.5 transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-transform-class-static-block/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-class-static-block@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-SPToJ5eYZLxlnp1UzdARpOGeC2GbHvr9d/UV0EukuVx8atktg194oe+C5BqQ8jRTkgLRVOPYeXRSBg1IlMoVRA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.12.0 dependencies: '@babel/core': 7.22.8 - '@babel/helper-create-class-features-plugin': 7.22.6_@babel+core@7.22.8 + '@babel/helper-create-class-features-plugin': 7.22.6(@babel/core@7.22.8) '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-class-static-block': 7.14.5_@babel+core@7.22.8 + '@babel/plugin-syntax-class-static-block': 7.14.5(@babel/core@7.22.8) transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-transform-classes/7.22.6_@babel+core@7.22.8: + /@babel/plugin-transform-classes@7.22.6(@babel/core@7.22.8): resolution: {integrity: sha512-58EgM6nuPNG6Py4Z3zSuu0xWu2VfodiMi72Jt5Kj2FECmaYk1RrTXA45z6KBFsu9tRgwQDwIiY4FXTt+YsSFAQ==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2593,7 +3092,7 @@ packages: dependencies: '@babel/core': 7.22.8 '@babel/helper-annotate-as-pure': 7.22.5 - '@babel/helper-compilation-targets': 7.22.6_@babel+core@7.22.8 + '@babel/helper-compilation-targets': 7.22.6(@babel/core@7.22.8) '@babel/helper-environment-visitor': 7.22.5 '@babel/helper-function-name': 7.22.5 '@babel/helper-optimise-call-expression': 7.22.5 @@ -2605,7 +3104,7 @@ packages: - supports-color dev: true - /@babel/plugin-transform-computed-properties/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-computed-properties@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-4GHWBgRf0krxPX+AaPtgBAlTgTeZmqDynokHOX7aqqAB4tHs3U2Y02zH6ETFdLZGcg9UQSD1WCmkVrE9ErHeOg==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2616,7 +3115,7 @@ packages: '@babel/template': 7.22.5 dev: true - /@babel/plugin-transform-destructuring/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-destructuring@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-GfqcFuGW8vnEqTUBM7UtPd5A4q797LTvvwKxXTgRsFjoqaJiEg9deBG6kWeQYkVEL569NpnmpC0Pkr/8BLKGnQ==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2626,18 +3125,18 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-dotall-regex/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-dotall-regex@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-5/Yk9QxCQCl+sOIB1WelKnVRxTJDSAIxtJLL2/pqL14ZVlbH0fUQUZa/T5/UnQtBNgghR7mfB8ERBKyKPCi7Vw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: '@babel/core': 7.22.8 - '@babel/helper-create-regexp-features-plugin': 7.22.6_@babel+core@7.22.8 + '@babel/helper-create-regexp-features-plugin': 7.22.6(@babel/core@7.22.8) '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-duplicate-keys/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-duplicate-keys@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-dEnYD+9BBgld5VBXHnF/DbYGp3fqGMsyxKbtD1mDyIA7AkTSpKXFhCVuj/oQVOoALfBs77DudA0BE4d5mcpmqw==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2647,7 +3146,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-dynamic-import/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-dynamic-import@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-0MC3ppTB1AMxd8fXjSrbPa7LT9hrImt+/fcj+Pg5YMD7UQyWp/02+JWpdnCymmsXwIx5Z+sYn1bwCn4ZJNvhqQ==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2655,10 +3154,10 @@ packages: dependencies: '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-dynamic-import': 7.8.3_@babel+core@7.22.8 + '@babel/plugin-syntax-dynamic-import': 7.8.3(@babel/core@7.22.8) dev: true - /@babel/plugin-transform-exponentiation-operator/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-exponentiation-operator@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-vIpJFNM/FjZ4rh1myqIya9jXwrwwgFRHPjT3DkUA9ZLHuzox8jiXkOLvwm1H+PQIP3CqfC++WPKeuDi0Sjdj1g==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2669,7 +3168,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-export-namespace-from/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-export-namespace-from@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-X4hhm7FRnPgd4nDA4b/5V280xCx6oL7Oob5+9qVS5C13Zq4bh1qq7LU0GgRU6b5dBWBvhGaXYVB4AcN6+ol6vg==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2677,10 +3176,10 @@ packages: dependencies: '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-export-namespace-from': 7.8.3_@babel+core@7.22.8 + '@babel/plugin-syntax-export-namespace-from': 7.8.3(@babel/core@7.22.8) dev: true - /@babel/plugin-transform-flow-strip-types/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-flow-strip-types@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-tujNbZdxdG0/54g/oua8ISToaXTFBf8EnSb5PgQSciIXWOWKX3S4+JR7ZE9ol8FZwf9kxitzkGQ+QWeov/mCiA==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2688,10 +3187,10 @@ packages: dependencies: '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-flow': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-syntax-flow': 7.22.5(@babel/core@7.22.8) dev: true - /@babel/plugin-transform-for-of/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-for-of@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-3kxQjX1dU9uudwSshyLeEipvrLjBCVthCgeTp6CzE/9JYrlAIaeekVxRpCWsDDfYTfRZRoCeZatCQvwo+wvK8A==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2701,19 +3200,19 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-function-name/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-function-name@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-UIzQNMS0p0HHiQm3oelztj+ECwFnj+ZRV4KnguvlsD2of1whUeM6o7wGNj6oLwcDoAXQ8gEqfgC24D+VdIcevg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: '@babel/core': 7.22.8 - '@babel/helper-compilation-targets': 7.22.6_@babel+core@7.22.8 + '@babel/helper-compilation-targets': 7.22.6(@babel/core@7.22.8) '@babel/helper-function-name': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-json-strings/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-json-strings@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-DuCRB7fu8MyTLbEQd1ew3R85nx/88yMoqo2uPSjevMj3yoN7CDM8jkgrY0wmVxfJZyJ/B9fE1iq7EQppWQmR5A==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2721,10 +3220,10 @@ packages: dependencies: '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-json-strings': 7.8.3_@babel+core@7.22.8 + '@babel/plugin-syntax-json-strings': 7.8.3(@babel/core@7.22.8) dev: true - /@babel/plugin-transform-literals/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-literals@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-fTLj4D79M+mepcw3dgFBTIDYpbcB9Sm0bpm4ppXPaO+U+PKFFyV9MGRvS0gvGw62sd10kT5lRMKXAADb9pWy8g==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2734,7 +3233,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-logical-assignment-operators/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-logical-assignment-operators@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-MQQOUW1KL8X0cDWfbwYP+TbVbZm16QmQXJQ+vndPtH/BoO0lOKpVoEDMI7+PskYxH+IiE0tS8xZye0qr1lGzSA==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2742,10 +3241,10 @@ packages: dependencies: '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-logical-assignment-operators': 7.10.4_@babel+core@7.22.8 + '@babel/plugin-syntax-logical-assignment-operators': 7.10.4(@babel/core@7.22.8) dev: true - /@babel/plugin-transform-member-expression-literals/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-member-expression-literals@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-RZEdkNtzzYCFl9SE9ATaUMTj2hqMb4StarOJLrZRbqqU4HSBE7UlBw9WBWQiDzrJZJdUWiMTVDI6Gv/8DPvfew==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2755,7 +3254,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-modules-amd/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-modules-amd@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-R+PTfLTcYEmb1+kK7FNkhQ1gP4KgjpSO6HfH9+f8/yfp2Nt3ggBjiVpRwmwTlfqZLafYKJACy36yDXlEmI9HjQ==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2768,7 +3267,7 @@ packages: - supports-color dev: true - /@babel/plugin-transform-modules-commonjs/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-modules-commonjs@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-B4pzOXj+ONRmuaQTg05b3y/4DuFz3WcCNAXPLb2Q0GT0TrGKGxNKV4jwsXts+StaM0LQczZbOpj8o1DLPDJIiA==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2782,7 +3281,7 @@ packages: - supports-color dev: true - /@babel/plugin-transform-modules-systemjs/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-modules-systemjs@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-emtEpoaTMsOs6Tzz+nbmcePl6AKVtS1yC4YNAeMun9U8YCsgadPNxnOPQ8GhHFB2qdx+LZu9LgoC0Lthuu05DQ==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2797,7 +3296,7 @@ packages: - supports-color dev: true - /@babel/plugin-transform-modules-umd/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-modules-umd@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-+S6kzefN/E1vkSsKx8kmQuqeQsvCKCd1fraCM7zXm4SFoggI099Tr4G8U81+5gtMdUeMQ4ipdQffbKLX0/7dBQ==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2810,18 +3309,18 @@ packages: - supports-color dev: true - /@babel/plugin-transform-named-capturing-groups-regex/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-named-capturing-groups-regex@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-YgLLKmS3aUBhHaxp5hi1WJTgOUb/NCuDHzGT9z9WTt3YG+CPRhJs6nprbStx6DnWM4dh6gt7SU3sZodbZ08adQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0 dependencies: '@babel/core': 7.22.8 - '@babel/helper-create-regexp-features-plugin': 7.22.6_@babel+core@7.22.8 + '@babel/helper-create-regexp-features-plugin': 7.22.6(@babel/core@7.22.8) '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-new-target/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-new-target@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-AsF7K0Fx/cNKVyk3a+DW0JLo+Ua598/NxMRvxDnkpCIGFh43+h/v2xyhRUYf6oD8gE4QtL83C7zZVghMjHd+iw==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2831,7 +3330,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-nullish-coalescing-operator/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-nullish-coalescing-operator@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-6CF8g6z1dNYZ/VXok5uYkkBBICHZPiGEl7oDnAx2Mt1hlHVHOSIKWJaXHjQJA5VB43KZnXZDIexMchY4y2PGdA==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2839,10 +3338,10 @@ packages: dependencies: '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-nullish-coalescing-operator': 7.8.3_@babel+core@7.22.8 + '@babel/plugin-syntax-nullish-coalescing-operator': 7.8.3(@babel/core@7.22.8) dev: true - /@babel/plugin-transform-numeric-separator/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-numeric-separator@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-NbslED1/6M+sXiwwtcAB/nieypGw02Ejf4KtDeMkCEpP6gWFMX1wI9WKYua+4oBneCCEmulOkRpwywypVZzs/g==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2850,10 +3349,10 @@ packages: dependencies: '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-numeric-separator': 7.10.4_@babel+core@7.22.8 + '@babel/plugin-syntax-numeric-separator': 7.10.4(@babel/core@7.22.8) dev: true - /@babel/plugin-transform-object-rest-spread/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-object-rest-spread@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-Kk3lyDmEslH9DnvCDA1s1kkd3YWQITiBOHngOtDL9Pt6BZjzqb6hiOlb8VfjiiQJ2unmegBqZu0rx5RxJb5vmQ==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2861,13 +3360,13 @@ packages: dependencies: '@babel/compat-data': 7.22.6 '@babel/core': 7.22.8 - '@babel/helper-compilation-targets': 7.22.6_@babel+core@7.22.8 + '@babel/helper-compilation-targets': 7.22.6(@babel/core@7.22.8) '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-object-rest-spread': 7.8.3_@babel+core@7.22.8 - '@babel/plugin-transform-parameters': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-syntax-object-rest-spread': 7.8.3(@babel/core@7.22.8) + '@babel/plugin-transform-parameters': 7.22.5(@babel/core@7.22.8) dev: true - /@babel/plugin-transform-object-super/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-object-super@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-klXqyaT9trSjIUrcsYIfETAzmOEZL3cBYqOYLJxBHfMFFggmXOv+NYSX/Jbs9mzMVESw/WycLFPRx8ba/b2Ipw==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2880,7 +3379,7 @@ packages: - supports-color dev: true - /@babel/plugin-transform-optional-catch-binding/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-optional-catch-binding@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-pH8orJahy+hzZje5b8e2QIlBWQvGpelS76C63Z+jhZKsmzfNaPQ+LaW6dcJ9bxTpo1mtXbgHwy765Ro3jftmUg==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2888,10 +3387,10 @@ packages: dependencies: '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-optional-catch-binding': 7.8.3_@babel+core@7.22.8 + '@babel/plugin-syntax-optional-catch-binding': 7.8.3(@babel/core@7.22.8) dev: true - /@babel/plugin-transform-optional-chaining/7.22.6_@babel+core@7.22.8: + /@babel/plugin-transform-optional-chaining@7.22.6(@babel/core@7.22.8): resolution: {integrity: sha512-Vd5HiWml0mDVtcLHIoEU5sw6HOUW/Zk0acLs/SAeuLzkGNOPc9DB4nkUajemhCmTIz3eiaKREZn2hQQqF79YTg==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2900,10 +3399,10 @@ packages: '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 '@babel/helper-skip-transparent-expression-wrappers': 7.22.5 - '@babel/plugin-syntax-optional-chaining': 7.8.3_@babel+core@7.22.8 + '@babel/plugin-syntax-optional-chaining': 7.8.3(@babel/core@7.22.8) dev: true - /@babel/plugin-transform-parameters/7.22.5_@babel+core@7.12.9: + /@babel/plugin-transform-parameters@7.22.5(@babel/core@7.12.9): resolution: {integrity: sha512-AVkFUBurORBREOmHRKo06FjHYgjrabpdqRSwq6+C7R5iTCZOsM4QbcB27St0a4U6fffyAOqh3s/qEfybAhfivg==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2913,7 +3412,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-parameters/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-parameters@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-AVkFUBurORBREOmHRKo06FjHYgjrabpdqRSwq6+C7R5iTCZOsM4QbcB27St0a4U6fffyAOqh3s/qEfybAhfivg==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2923,20 +3422,20 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-private-methods/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-private-methods@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-PPjh4gyrQnGe97JTalgRGMuU4icsZFnWkzicB/fUtzlKUqvsWBKEpPPfr5a2JiyirZkHxnAqkQMO5Z5B2kK3fA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: '@babel/core': 7.22.8 - '@babel/helper-create-class-features-plugin': 7.22.6_@babel+core@7.22.8 + '@babel/helper-create-class-features-plugin': 7.22.6(@babel/core@7.22.8) '@babel/helper-plugin-utils': 7.22.5 transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-transform-private-property-in-object/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-private-property-in-object@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-/9xnaTTJcVoBtSSmrVyhtSvO3kbqS2ODoh2juEU72c3aYonNF0OMGiaz2gjukyKM2wBBYJP38S4JiE0Wfb5VMQ==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2944,14 +3443,14 @@ packages: dependencies: '@babel/core': 7.22.8 '@babel/helper-annotate-as-pure': 7.22.5 - '@babel/helper-create-class-features-plugin': 7.22.6_@babel+core@7.22.8 + '@babel/helper-create-class-features-plugin': 7.22.6(@babel/core@7.22.8) '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-private-property-in-object': 7.14.5_@babel+core@7.22.8 + '@babel/plugin-syntax-private-property-in-object': 7.14.5(@babel/core@7.22.8) transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-transform-property-literals/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-property-literals@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-TiOArgddK3mK/x1Qwf5hay2pxI6wCZnvQqrFSqbtg1GLl2JcNMitVH/YnqjP+M31pLUeTfzY1HAXFDnUBV30rQ==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2961,7 +3460,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-react-display-name/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-react-display-name@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-PVk3WPYudRF5z4GKMEYUrLjPl38fJSKNaEOkFuoprioowGuWN6w2RKznuFNSlJx7pzzXXStPUnNSOEO0jL5EVw==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2971,17 +3470,17 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-react-jsx-development/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-react-jsx-development@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-bDhuzwWMuInwCYeDeMzyi7TaBgRQei6DqxhbyniL7/VG4RSS7HtSL2QbY4eESy1KJqlWt8g3xeEBGPuo+XqC8A==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: '@babel/core': 7.22.8 - '@babel/plugin-transform-react-jsx': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-react-jsx': 7.22.5(@babel/core@7.22.8) dev: true - /@babel/plugin-transform-react-jsx-self/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-react-jsx-self@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-nTh2ogNUtxbiSbxaT4Ds6aXnXEipHweN9YRgOX/oNXdf0cCrGn/+2LozFa3lnPV5D90MkjhgckCPBrsoSc1a7g==} engines: {node: '>=6.9.0'} peerDependencies: @@ -2991,7 +3490,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-react-jsx-source/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-react-jsx-source@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-yIiRO6yobeEIaI0RTbIr8iAK9FcBHLtZq0S89ZPjDLQXBA4xvghaKqI0etp/tF3htTM0sazJKKLz9oEiGRtu7w==} engines: {node: '>=6.9.0'} peerDependencies: @@ -3001,7 +3500,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-react-jsx/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-react-jsx@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-rog5gZaVbUip5iWDMTYbVM15XQq+RkUKhET/IHR6oizR+JEoN6CAfTTuHcK4vwUyzca30qqHqEpzBOnaRMWYMA==} engines: {node: '>=6.9.0'} peerDependencies: @@ -3011,11 +3510,11 @@ packages: '@babel/helper-annotate-as-pure': 7.22.5 '@babel/helper-module-imports': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-jsx': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-syntax-jsx': 7.22.5(@babel/core@7.22.8) '@babel/types': 7.22.5 dev: true - /@babel/plugin-transform-react-pure-annotations/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-react-pure-annotations@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-gP4k85wx09q+brArVinTXhWiyzLl9UpmGva0+mWyKxk6JZequ05x3eUcIUE+FyttPKJFRRVtAvQaJ6YF9h1ZpA==} engines: {node: '>=6.9.0'} peerDependencies: @@ -3026,7 +3525,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-regenerator/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-regenerator@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-rR7KePOE7gfEtNTh9Qw+iO3Q/e4DEsoQ+hdvM6QUDH7JRJ5qxq5AA52ZzBWbI5i9lfNuvySgOGP8ZN7LAmaiPw==} engines: {node: '>=6.9.0'} peerDependencies: @@ -3037,7 +3536,7 @@ packages: regenerator-transform: 0.15.1 dev: true - /@babel/plugin-transform-reserved-words/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-reserved-words@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-DTtGKFRQUDm8svigJzZHzb/2xatPc6TzNvAIJ5GqOKDsGFYgAskjRulbR/vGsPKq3OPqtexnz327qYpP57RFyA==} engines: {node: '>=6.9.0'} peerDependencies: @@ -3047,7 +3546,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-shorthand-properties/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-shorthand-properties@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-vM4fq9IXHscXVKzDv5itkO1X52SmdFBFcMIBZ2FRn2nqVYqw6dBexUgMvAjHW+KXpPPViD/Yo3GrDEBaRC0QYA==} engines: {node: '>=6.9.0'} peerDependencies: @@ -3057,7 +3556,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-spread/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-spread@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-5ZzDQIGyvN4w8+dMmpohL6MBo+l2G7tfC/O2Dg7/hjpgeWvUx8FzfeOKxGog9IimPa4YekaQ9PlDqTLOljkcxg==} engines: {node: '>=6.9.0'} peerDependencies: @@ -3068,7 +3567,7 @@ packages: '@babel/helper-skip-transparent-expression-wrappers': 7.22.5 dev: true - /@babel/plugin-transform-sticky-regex/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-sticky-regex@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-zf7LuNpHG0iEeiyCNwX4j3gDg1jgt1k3ZdXBKbZSoA3BbGQGvMiSvfbZRR3Dr3aeJe3ooWFZxOOG3IRStYp2Bw==} engines: {node: '>=6.9.0'} peerDependencies: @@ -3078,7 +3577,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-template-literals/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-template-literals@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-5ciOehRNf+EyUeewo8NkbQiUs4d6ZxiHo6BcBcnFlgiJfu16q0bQUw9Jvo0b0gBKFG1SMhDSjeKXSYuJLeFSMA==} engines: {node: '>=6.9.0'} peerDependencies: @@ -3088,7 +3587,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-typeof-symbol/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-typeof-symbol@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-bYkI5lMzL4kPii4HHEEChkD0rkc+nvnlR6+o/qdqR6zrm0Sv/nodmyLhlq2DO0YKLUNd2VePmPRjJXSBh9OIdA==} engines: {node: '>=6.9.0'} peerDependencies: @@ -3098,7 +3597,7 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-typescript/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-typescript@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-SMubA9S7Cb5sGSFFUlqxyClTA9zWJ8qGQrppNUm05LtFuN1ELRFNndkix4zUJrC9F+YivWwa1dHMSyo0e0N9dA==} engines: {node: '>=6.9.0'} peerDependencies: @@ -3106,14 +3605,14 @@ packages: dependencies: '@babel/core': 7.22.8 '@babel/helper-annotate-as-pure': 7.22.5 - '@babel/helper-create-class-features-plugin': 7.22.6_@babel+core@7.22.8 + '@babel/helper-create-class-features-plugin': 7.22.6(@babel/core@7.22.8) '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-typescript': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-syntax-typescript': 7.22.5(@babel/core@7.22.8) transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-transform-unicode-escapes/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-unicode-escapes@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-biEmVg1IYB/raUO5wT1tgfacCef15Fbzhkx493D3urBI++6hpJ+RFG4SrWMn0NEZLfvilqKf3QDrRVZHo08FYg==} engines: {node: '>=6.9.0'} peerDependencies: @@ -3123,40 +3622,40 @@ packages: '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-unicode-property-regex/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-unicode-property-regex@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-HCCIb+CbJIAE6sXn5CjFQXMwkCClcOfPCzTlilJ8cUatfzwHlWQkbtV0zD338u9dZskwvuOYTuuaMaA8J5EI5A==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: '@babel/core': 7.22.8 - '@babel/helper-create-regexp-features-plugin': 7.22.6_@babel+core@7.22.8 + '@babel/helper-create-regexp-features-plugin': 7.22.6(@babel/core@7.22.8) '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-unicode-regex/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-unicode-regex@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-028laaOKptN5vHJf9/Arr/HiJekMd41hOEZYvNsrsXqJ7YPYuX2bQxh31fkZzGmq3YqHRJzYFFAVYvKfMPKqyg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: '@babel/core': 7.22.8 - '@babel/helper-create-regexp-features-plugin': 7.22.6_@babel+core@7.22.8 + '@babel/helper-create-regexp-features-plugin': 7.22.6(@babel/core@7.22.8) '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-unicode-sets-regex/7.22.5_@babel+core@7.22.8: + /@babel/plugin-transform-unicode-sets-regex@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-lhMfi4FC15j13eKrh3DnYHjpGj6UKQHtNKTbtc1igvAhRy4+kLhV07OpLcsN0VgDEw/MjAvJO4BdMJsHwMhzCg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0 dependencies: '@babel/core': 7.22.8 - '@babel/helper-create-regexp-features-plugin': 7.22.6_@babel+core@7.22.8 + '@babel/helper-create-regexp-features-plugin': 7.22.6(@babel/core@7.22.8) '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/preset-env/7.22.7_@babel+core@7.22.8: + /@babel/preset-env@7.22.7(@babel/core@7.22.8): resolution: {integrity: sha512-1whfDtW+CzhETuzYXfcgZAh8/GFMeEbz0V5dVgya8YeJyCU6Y/P2Gnx4Qb3MylK68Zu9UiwUvbPMPTpFAOJ+sQ==} engines: {node: '>=6.9.0'} peerDependencies: @@ -3164,90 +3663,90 @@ packages: dependencies: '@babel/compat-data': 7.22.6 '@babel/core': 7.22.8 - '@babel/helper-compilation-targets': 7.22.6_@babel+core@7.22.8 + '@babel/helper-compilation-targets': 7.22.6(@babel/core@7.22.8) '@babel/helper-plugin-utils': 7.22.5 '@babel/helper-validator-option': 7.22.5 - '@babel/plugin-bugfix-safari-id-destructuring-collision-in-function-expression': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-bugfix-v8-spread-parameters-in-optional-chaining': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-proposal-private-property-in-object': 7.21.0-placeholder-for-preset-env.2_@babel+core@7.22.8 - '@babel/plugin-syntax-async-generators': 7.8.4_@babel+core@7.22.8 - '@babel/plugin-syntax-class-properties': 7.12.13_@babel+core@7.22.8 - '@babel/plugin-syntax-class-static-block': 7.14.5_@babel+core@7.22.8 - '@babel/plugin-syntax-dynamic-import': 7.8.3_@babel+core@7.22.8 - '@babel/plugin-syntax-export-namespace-from': 7.8.3_@babel+core@7.22.8 - '@babel/plugin-syntax-import-assertions': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-syntax-import-attributes': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-syntax-import-meta': 7.10.4_@babel+core@7.22.8 - '@babel/plugin-syntax-json-strings': 7.8.3_@babel+core@7.22.8 - '@babel/plugin-syntax-logical-assignment-operators': 7.10.4_@babel+core@7.22.8 - '@babel/plugin-syntax-nullish-coalescing-operator': 7.8.3_@babel+core@7.22.8 - '@babel/plugin-syntax-numeric-separator': 7.10.4_@babel+core@7.22.8 - '@babel/plugin-syntax-object-rest-spread': 7.8.3_@babel+core@7.22.8 - '@babel/plugin-syntax-optional-catch-binding': 7.8.3_@babel+core@7.22.8 - '@babel/plugin-syntax-optional-chaining': 7.8.3_@babel+core@7.22.8 - '@babel/plugin-syntax-private-property-in-object': 7.14.5_@babel+core@7.22.8 - '@babel/plugin-syntax-top-level-await': 7.14.5_@babel+core@7.22.8 - '@babel/plugin-syntax-unicode-sets-regex': 7.18.6_@babel+core@7.22.8 - '@babel/plugin-transform-arrow-functions': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-async-generator-functions': 7.22.7_@babel+core@7.22.8 - '@babel/plugin-transform-async-to-generator': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-block-scoped-functions': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-block-scoping': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-class-properties': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-class-static-block': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-classes': 7.22.6_@babel+core@7.22.8 - '@babel/plugin-transform-computed-properties': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-destructuring': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-dotall-regex': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-duplicate-keys': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-dynamic-import': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-exponentiation-operator': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-export-namespace-from': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-for-of': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-function-name': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-json-strings': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-literals': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-logical-assignment-operators': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-member-expression-literals': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-modules-amd': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-modules-commonjs': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-modules-systemjs': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-modules-umd': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-named-capturing-groups-regex': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-new-target': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-nullish-coalescing-operator': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-numeric-separator': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-object-rest-spread': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-object-super': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-optional-catch-binding': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-optional-chaining': 7.22.6_@babel+core@7.22.8 - '@babel/plugin-transform-parameters': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-private-methods': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-private-property-in-object': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-property-literals': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-regenerator': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-reserved-words': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-shorthand-properties': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-spread': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-sticky-regex': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-template-literals': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-typeof-symbol': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-unicode-escapes': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-unicode-property-regex': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-unicode-regex': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-unicode-sets-regex': 7.22.5_@babel+core@7.22.8 - '@babel/preset-modules': 0.1.5_@babel+core@7.22.8 + '@babel/plugin-bugfix-safari-id-destructuring-collision-in-function-expression': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-bugfix-v8-spread-parameters-in-optional-chaining': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-proposal-private-property-in-object': 7.21.0-placeholder-for-preset-env.2(@babel/core@7.22.8) + '@babel/plugin-syntax-async-generators': 7.8.4(@babel/core@7.22.8) + '@babel/plugin-syntax-class-properties': 7.12.13(@babel/core@7.22.8) + '@babel/plugin-syntax-class-static-block': 7.14.5(@babel/core@7.22.8) + '@babel/plugin-syntax-dynamic-import': 7.8.3(@babel/core@7.22.8) + '@babel/plugin-syntax-export-namespace-from': 7.8.3(@babel/core@7.22.8) + '@babel/plugin-syntax-import-assertions': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-syntax-import-attributes': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-syntax-import-meta': 7.10.4(@babel/core@7.22.8) + '@babel/plugin-syntax-json-strings': 7.8.3(@babel/core@7.22.8) + '@babel/plugin-syntax-logical-assignment-operators': 7.10.4(@babel/core@7.22.8) + '@babel/plugin-syntax-nullish-coalescing-operator': 7.8.3(@babel/core@7.22.8) + '@babel/plugin-syntax-numeric-separator': 7.10.4(@babel/core@7.22.8) + '@babel/plugin-syntax-object-rest-spread': 7.8.3(@babel/core@7.22.8) + '@babel/plugin-syntax-optional-catch-binding': 7.8.3(@babel/core@7.22.8) + '@babel/plugin-syntax-optional-chaining': 7.8.3(@babel/core@7.22.8) + '@babel/plugin-syntax-private-property-in-object': 7.14.5(@babel/core@7.22.8) + '@babel/plugin-syntax-top-level-await': 7.14.5(@babel/core@7.22.8) + '@babel/plugin-syntax-unicode-sets-regex': 7.18.6(@babel/core@7.22.8) + '@babel/plugin-transform-arrow-functions': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-async-generator-functions': 7.22.7(@babel/core@7.22.8) + '@babel/plugin-transform-async-to-generator': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-block-scoped-functions': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-block-scoping': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-class-properties': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-class-static-block': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-classes': 7.22.6(@babel/core@7.22.8) + '@babel/plugin-transform-computed-properties': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-destructuring': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-dotall-regex': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-duplicate-keys': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-dynamic-import': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-exponentiation-operator': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-export-namespace-from': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-for-of': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-function-name': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-json-strings': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-literals': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-logical-assignment-operators': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-member-expression-literals': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-modules-amd': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-modules-commonjs': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-modules-systemjs': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-modules-umd': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-named-capturing-groups-regex': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-new-target': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-nullish-coalescing-operator': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-numeric-separator': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-object-rest-spread': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-object-super': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-optional-catch-binding': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-optional-chaining': 7.22.6(@babel/core@7.22.8) + '@babel/plugin-transform-parameters': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-private-methods': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-private-property-in-object': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-property-literals': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-regenerator': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-reserved-words': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-shorthand-properties': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-spread': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-sticky-regex': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-template-literals': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-typeof-symbol': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-unicode-escapes': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-unicode-property-regex': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-unicode-regex': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-unicode-sets-regex': 7.22.5(@babel/core@7.22.8) + '@babel/preset-modules': 0.1.5(@babel/core@7.22.8) '@babel/types': 7.22.5 '@nicolo-ribaudo/semver-v6': 6.3.3 - babel-plugin-polyfill-corejs2: 0.4.4_@babel+core@7.22.8 - babel-plugin-polyfill-corejs3: 0.8.2_@babel+core@7.22.8 - babel-plugin-polyfill-regenerator: 0.5.1_@babel+core@7.22.8 + babel-plugin-polyfill-corejs2: 0.4.4(@babel/core@7.22.8) + babel-plugin-polyfill-corejs3: 0.8.2(@babel/core@7.22.8) + babel-plugin-polyfill-regenerator: 0.5.1(@babel/core@7.22.8) core-js-compat: 3.31.1 transitivePeerDependencies: - supports-color dev: true - /@babel/preset-flow/7.22.5_@babel+core@7.22.8: + /@babel/preset-flow@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-ta2qZ+LSiGCrP5pgcGt8xMnnkXQrq8Sa4Ulhy06BOlF5QbLw9q5hIx7bn5MrsvyTGAfh6kTOo07Q+Pfld/8Y5Q==} engines: {node: '>=6.9.0'} peerDependencies: @@ -3256,23 +3755,23 @@ packages: '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 '@babel/helper-validator-option': 7.22.5 - '@babel/plugin-transform-flow-strip-types': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-flow-strip-types': 7.22.5(@babel/core@7.22.8) dev: true - /@babel/preset-modules/0.1.5_@babel+core@7.22.8: + /@babel/preset-modules@0.1.5(@babel/core@7.22.8): resolution: {integrity: sha512-A57th6YRG7oR3cq/yt/Y84MvGgE0eJG2F1JLhKuyG+jFxEgrd/HAMJatiFtmOiZurz+0DkrvbheCLaV5f2JfjA==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-proposal-unicode-property-regex': 7.18.6_@babel+core@7.22.8 - '@babel/plugin-transform-dotall-regex': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-proposal-unicode-property-regex': 7.18.6(@babel/core@7.22.8) + '@babel/plugin-transform-dotall-regex': 7.22.5(@babel/core@7.22.8) '@babel/types': 7.22.5 esutils: 2.0.3 dev: true - /@babel/preset-react/7.22.5_@babel+core@7.22.8: + /@babel/preset-react@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-M+Is3WikOpEJHgR385HbuCITPTaPRaNkibTEa9oiofmJvIsrceb4yp9RL9Kb+TE8LznmeyZqpP+Lopwcx59xPQ==} engines: {node: '>=6.9.0'} peerDependencies: @@ -3281,13 +3780,13 @@ packages: '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 '@babel/helper-validator-option': 7.22.5 - '@babel/plugin-transform-react-display-name': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-react-jsx': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-react-jsx-development': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-react-pure-annotations': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-react-display-name': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-react-jsx': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-react-jsx-development': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-react-pure-annotations': 7.22.5(@babel/core@7.22.8) dev: true - /@babel/preset-typescript/7.22.5_@babel+core@7.22.8: + /@babel/preset-typescript@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-YbPaal9LxztSGhmndR46FmAbkJ/1fAsw293tSU+I5E5h+cnJ3d4GTwyUgGYmOXJYdGA+uNePle4qbaRzj2NISQ==} engines: {node: '>=6.9.0'} peerDependencies: @@ -3296,14 +3795,14 @@ packages: '@babel/core': 7.22.8 '@babel/helper-plugin-utils': 7.22.5 '@babel/helper-validator-option': 7.22.5 - '@babel/plugin-syntax-jsx': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-modules-commonjs': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-typescript': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-syntax-jsx': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-modules-commonjs': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-typescript': 7.22.5(@babel/core@7.22.8) transitivePeerDependencies: - supports-color dev: true - /@babel/register/7.22.5_@babel+core@7.22.8: + /@babel/register@7.22.5(@babel/core@7.22.8): resolution: {integrity: sha512-vV6pm/4CijSQ8Y47RH5SopXzursN35RQINfGJkmOlcpAtGuf94miFvIPhCKGQN7WGIcsgG1BHEX2KVdTYwTwUQ==} engines: {node: '>=6.9.0'} peerDependencies: @@ -3317,17 +3816,17 @@ packages: source-map-support: 0.5.21 dev: true - /@babel/regjsgen/0.8.0: + /@babel/regjsgen@0.8.0: resolution: {integrity: sha512-x/rqGMdzj+fWZvCOYForTghzbtqPDZ5gPwaoNGHdgDfF2QA/XZbCBp4Moo5scrkAMPhB7z26XM/AaHuIJdgauA==} dev: true - /@babel/runtime/7.22.6: + /@babel/runtime@7.22.6: resolution: {integrity: sha512-wDb5pWm4WDdF6LFUde3Jl8WzPA+3ZbxYqkC6xAXuD3irdEHN1k0NfTRrJD8ZD378SJ61miMLCqIOXYhd8x+AJQ==} engines: {node: '>=6.9.0'} dependencies: regenerator-runtime: 0.13.11 - /@babel/template/7.22.5: + /@babel/template@7.22.5: resolution: {integrity: sha512-X7yV7eiwAxdj9k94NEylvbVHLiVG1nvzCV2EAowhxLTwODV1jl9UzZ48leOC0sH7OnuHrIkllaBgneUykIcZaw==} engines: {node: '>=6.9.0'} dependencies: @@ -3335,7 +3834,7 @@ packages: '@babel/parser': 7.22.7 '@babel/types': 7.22.5 - /@babel/traverse/7.22.8: + /@babel/traverse@7.22.8: resolution: {integrity: sha512-y6LPR+wpM2I3qJrsheCTwhIinzkETbplIgPBbwvqPKc+uljeA5gP+3nP8irdYt1mjQaDnlIcG+dw8OjAco4GXw==} engines: {node: '>=6.9.0'} dependencies: @@ -3347,12 +3846,12 @@ packages: '@babel/helper-split-export-declaration': 7.22.6 '@babel/parser': 7.22.7 '@babel/types': 7.22.5 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) globals: 11.12.0 transitivePeerDependencies: - supports-color - /@babel/types/7.22.5: + /@babel/types@7.22.5: resolution: {integrity: sha512-zo3MIHGOkPOfoRXitsgHLjEXmlDaD/5KU1Uzuc9GNiZPhSqVxVRtxuPaSBZDsYZ9qV88AjtMtWW7ww98loJ9KA==} engines: {node: '>=6.9.0'} dependencies: @@ -3360,18 +3859,18 @@ packages: '@babel/helper-validator-identifier': 7.22.5 to-fast-properties: 2.0.0 - /@base2/pretty-print-object/1.0.1: + /@base2/pretty-print-object@1.0.1: resolution: {integrity: sha512-4iri8i1AqYHJE2DstZYkyEprg6Pq6sKx3xn5FpySk9sNhH7qN2LLlHJCfDTZRILNwQNPD7mATWM0TBui7uC1pA==} dev: true - /@bcoe/v8-coverage/0.2.3: + /@bcoe/v8-coverage@0.2.3: resolution: {integrity: sha512-0hYQ8SB4Db5zvZB4axdMHGwEaQjkZzFjQiN9LVYvIFB2nSUHW9tYpxWriPrWDASIxiaXax83REcLxuSdnGPZtw==} - /@canvas/image-data/1.0.0: + /@canvas/image-data@1.0.0: resolution: {integrity: sha512-BxOqI5LgsIQP1odU5KMwV9yoijleOPzHL18/YvNqF9KFSGF2K/DLlYAbDQsWqd/1nbaFuSkYD/191dpMtNh4vw==} dev: true - /@cnakazawa/watch/1.0.4: + /@cnakazawa/watch@1.0.4: resolution: {integrity: sha512-v9kIhKwjeZThiWrLmj0y17CWoyddASLj9O2yvbZkbvw/N3rWOYy9zkV66ursAoVr0mV15bL8g0c4QZUE6cdDoQ==} engines: {node: '>=0.1.95'} hasBin: true @@ -3380,21 +3879,21 @@ packages: minimist: 1.2.8 dev: true - /@colors/colors/1.5.0: + /@colors/colors@1.5.0: resolution: {integrity: sha512-ooWCrlZP11i8GImSjTHYHLkvFDP48nS4+204nGb1RiX/WXYHmJA2III9/e2DWVabCESdW7hBAEzHRqUn9OUVvQ==} engines: {node: '>=0.1.90'} requiresBuild: true dev: true optional: true - /@cspotcode/source-map-support/0.8.1: + /@cspotcode/source-map-support@0.8.1: resolution: {integrity: sha512-IchNf6dN4tHoMFIn/7OE8LWZ19Y6q/67Bmf6vnGREv8RSbBVb9LPJxEcnwrcwX6ixSvaiGoomAUvu4YSxXrVgw==} engines: {node: '>=12'} dependencies: '@jridgewell/trace-mapping': 0.3.9 dev: true - /@cypress/request/2.88.11: + /@cypress/request@2.88.11: resolution: {integrity: sha512-M83/wfQ1EkspjkE2lNWNV5ui2Cv7UCv1swW1DqljahbzLVWltcsexQh8jYtuS/vzFXP+HySntGM83ZXA9fn17w==} engines: {node: '>= 6'} dependencies: @@ -3418,20 +3917,20 @@ packages: uuid: 8.3.2 dev: true - /@cypress/xvfb/1.2.4_supports-color@8.1.1: + /@cypress/xvfb@1.2.4(supports-color@8.1.1): resolution: {integrity: sha512-skbBzPggOVYCbnGgV+0dmBdW/s77ZkAOXIC1knS8NagwDjBrNC1LuXtQJeiN6l+m7lzmHtaoUw/ctJKdqkG57Q==} dependencies: - debug: 3.2.7_supports-color@8.1.1 + debug: 3.2.7(supports-color@8.1.1) lodash.once: 4.1.1 transitivePeerDependencies: - supports-color dev: true - /@date-io/core/2.16.0: + /@date-io/core@2.16.0: resolution: {integrity: sha512-DYmSzkr+jToahwWrsiRA2/pzMEtz9Bq1euJwoOuYwuwIYXnZFtHajY2E6a1VNVDc9jP8YUXK1BvnZH9mmT19Zg==} dev: false - /@date-io/date-fns/2.16.0_date-fns@2.30.0: + /@date-io/date-fns@2.16.0(date-fns@2.30.0): resolution: {integrity: sha512-bfm5FJjucqlrnQcXDVU5RD+nlGmL3iWgkHTq3uAZWVIuBu6dDmGa3m8a6zo2VQQpu8ambq9H22UyUpn7590joA==} peerDependencies: date-fns: ^2.0.0 @@ -3443,7 +3942,7 @@ packages: date-fns: 2.30.0 dev: false - /@date-io/dayjs/2.16.0: + /@date-io/dayjs@2.16.0: resolution: {integrity: sha512-y5qKyX2j/HG3zMvIxTobYZRGnd1FUW2olZLS0vTj7bEkBQkjd2RO7/FEwDY03Z1geVGlXKnzIATEVBVaGzV4Iw==} peerDependencies: dayjs: ^1.8.17 @@ -3454,7 +3953,7 @@ packages: '@date-io/core': 2.16.0 dev: false - /@date-io/luxon/2.16.1: + /@date-io/luxon@2.16.1: resolution: {integrity: sha512-aeYp5K9PSHV28946pC+9UKUi/xMMYoaGelrpDibZSgHu2VWHXrr7zWLEr+pMPThSs5vt8Ei365PO+84pCm37WQ==} peerDependencies: luxon: ^1.21.3 || ^2.x || ^3.x @@ -3465,7 +3964,7 @@ packages: '@date-io/core': 2.16.0 dev: false - /@date-io/moment/2.16.1: + /@date-io/moment@2.16.1: resolution: {integrity: sha512-JkxldQxUqZBfZtsaCcCMkm/dmytdyq5pS1RxshCQ4fHhsvP5A7gSqPD22QbVXMcJydi3d3v1Y8BQdUKEuGACZQ==} peerDependencies: moment: ^2.24.0 @@ -3476,19 +3975,19 @@ packages: '@date-io/core': 2.16.0 dev: false - /@discoveryjs/json-ext/0.5.7: + /@discoveryjs/json-ext@0.5.7: resolution: {integrity: sha512-dBVuXR082gk3jsFp7Rd/JI4kytwGHecnCoTtXFb7DB6CNHp4rg5k1bhg0nWdLGLnOV71lmDzGQaLMy8iPLY0pw==} engines: {node: '>=10.0.0'} dev: true - /@docsearch/css/3.5.1: + /@docsearch/css@3.5.1: resolution: {integrity: sha512-2Pu9HDg/uP/IT10rbQ+4OrTQuxIWdKVUEdcw9/w7kZJv9NeHS6skJx1xuRiFyoGKwAzcHXnLp7csE99sj+O1YA==} dev: true - /@docsearch/js/3.5.1: + /@docsearch/js@3.5.1(search-insights@2.7.0): resolution: {integrity: sha512-EXi8de5njxgP6TV3N9ytnGRLG9zmBNTEZjR4VzwPcpPLbZxxTLG2gaFyJyKiFVQxHW/DPlMrDJA3qoRRGEkgZw==} dependencies: - '@docsearch/react': 3.5.1 + '@docsearch/react': 3.5.1(search-insights@2.7.0) preact: 10.16.0 transitivePeerDependencies: - '@algolia/client-search' @@ -3498,7 +3997,7 @@ packages: - search-insights dev: true - /@docsearch/react/3.5.1: + /@docsearch/react@3.5.1(search-insights@2.7.0): resolution: {integrity: sha512-t5mEODdLzZq4PTFAm/dvqcvZFdPDMdfPE5rJS5SC8OUq9mPzxEy6b+9THIqNM9P0ocCb4UC5jqBrxKclnuIbzQ==} peerDependencies: '@types/react': '>= 16.8.0 < 19.0.0' @@ -3512,8 +4011,8 @@ packages: react-dom: optional: true dependencies: - '@algolia/autocomplete-core': 1.9.3_algoliasearch@4.18.0 - '@algolia/autocomplete-preset-algolia': 1.9.3_algoliasearch@4.18.0 + '@algolia/autocomplete-core': 1.9.3(algoliasearch@4.18.0)(search-insights@2.7.0) + '@algolia/autocomplete-preset-algolia': 1.9.3(algoliasearch@4.18.0) '@docsearch/css': 3.5.1 algoliasearch: 4.18.0 transitivePeerDependencies: @@ -3521,29 +4020,29 @@ packages: - search-insights dev: true - /@edge-runtime/primitives/1.1.0: + /@edge-runtime/primitives@1.1.0: resolution: {integrity: sha512-MpL5fKlOs9mz5DMRuFchLe3Il84t7XpfbPq4qtaEK37uNMCRx1MzA3d7A4aTsR/guXSZvV/AtEbKVqBWjuSThA==} dev: true - /@edge-runtime/primitives/3.0.3: + /@edge-runtime/primitives@3.0.3: resolution: {integrity: sha512-YnfMWMRQABAH8IsnFMJWMW+SyB4ZeYBPnR7V0aqdnew7Pq60cbH5DyFjS/FhiLwvHQk9wBREmXD7PP0HooEQ1A==} engines: {node: '>=14'} dev: true - /@edge-runtime/vm/1.1.0-beta.26: + /@edge-runtime/vm@1.1.0-beta.26: resolution: {integrity: sha512-hxWtmuO13zgNkM3zHvRENfMeavM+PAKSoHhvzt+sHjSothxGlA06XXN38t/NT6LD4ND8p8FmPJ70+fTptL4a/A==} dependencies: '@edge-runtime/primitives': 1.1.0 dev: true - /@edge-runtime/vm/3.0.3: + /@edge-runtime/vm@3.0.3: resolution: {integrity: sha512-SPfI1JeIRNs/4EEE2Oc0X6gG3RqjD1TnKu2lwmwFXq0435xgZGKhc3UiKkYAdoMn2dNFD73nlabMKHBRoMRpxg==} engines: {node: '>=14'} dependencies: '@edge-runtime/primitives': 3.0.3 dev: true - /@emotion/babel-plugin/11.11.0: + /@emotion/babel-plugin@11.11.0: resolution: {integrity: sha512-m4HEDZleaaCH+XgDDsPF15Ht6wTLsgDTeR3WYj9Q/k76JtWhrJjcP4+/XlG8LGT/Rol9qUfOIztXeA84ATpqPQ==} dependencies: '@babel/helper-module-imports': 7.22.5 @@ -3559,7 +4058,7 @@ packages: stylis: 4.2.0 dev: false - /@emotion/cache/11.11.0: + /@emotion/cache@11.11.0: resolution: {integrity: sha512-P34z9ssTCBi3e9EI1ZsWpNHcfY1r09ZO0rZbRO2ob3ZQMnFI35jB536qoXbkdesr5EUhYi22anuEJuyxifaqAQ==} dependencies: '@emotion/memoize': 0.8.1 @@ -3569,21 +4068,21 @@ packages: stylis: 4.2.0 dev: false - /@emotion/hash/0.9.1: + /@emotion/hash@0.9.1: resolution: {integrity: sha512-gJB6HLm5rYwSLI6PQa+X1t5CFGrv1J1TWG+sOyMCeKz2ojaj6Fnl/rZEspogG+cvqbt4AE/2eIyD2QfLKTBNlQ==} dev: false - /@emotion/is-prop-valid/1.2.1: + /@emotion/is-prop-valid@1.2.1: resolution: {integrity: sha512-61Mf7Ufx4aDxx1xlDeOm8aFFigGHE4z+0sKCa+IHCeZKiyP9RLD0Mmx7m8b9/Cf37f7NAvQOOJAbQQGVr5uERw==} dependencies: '@emotion/memoize': 0.8.1 dev: false - /@emotion/memoize/0.8.1: + /@emotion/memoize@0.8.1: resolution: {integrity: sha512-W2P2c/VRW1/1tLox0mVUalvnWXxavmv/Oum2aPsRcoDJuob75FC3Y8FbpfLwUegRcxINtGUMPq0tFCvYNTBXNA==} dev: false - /@emotion/react/11.11.1_react@18.2.0: + /@emotion/react@11.11.1(react@18.2.0): resolution: {integrity: sha512-5mlW1DquU5HaxjLkfkGN1GA/fvVGdyHURRiX/0FHl2cfIfRxSOfmxEH5YS43edp0OldZrZ+dkBKbngxcNCdZvA==} peerDependencies: '@types/react': '*' @@ -3596,14 +4095,14 @@ packages: '@emotion/babel-plugin': 11.11.0 '@emotion/cache': 11.11.0 '@emotion/serialize': 1.1.2 - '@emotion/use-insertion-effect-with-fallbacks': 1.0.1_react@18.2.0 + '@emotion/use-insertion-effect-with-fallbacks': 1.0.1(react@18.2.0) '@emotion/utils': 1.2.1 '@emotion/weak-memoize': 0.3.1 hoist-non-react-statics: 3.3.2 react: 18.2.0 dev: false - /@emotion/serialize/1.1.2: + /@emotion/serialize@1.1.2: resolution: {integrity: sha512-zR6a/fkFP4EAcCMQtLOhIgpprZOwNmCldtpaISpvz348+DP4Mz8ZoKaGGCQpbzepNIUWbq4w6hNZkwDyKoS+HA==} dependencies: '@emotion/hash': 0.9.1 @@ -3613,11 +4112,11 @@ packages: csstype: 3.1.2 dev: false - /@emotion/sheet/1.2.2: + /@emotion/sheet@1.2.2: resolution: {integrity: sha512-0QBtGvaqtWi+nx6doRwDdBIzhNdZrXUppvTM4dtZZWEGTXL/XE/yJxLMGlDT1Gt+UHH5IX1n+jkXyytE/av7OA==} dev: false - /@emotion/styled/11.11.0_xo5t6f4ryb2nvjgwj2cxjowrye: + /@emotion/styled@11.11.0(@emotion/react@11.11.1)(react@18.2.0): resolution: {integrity: sha512-hM5Nnvu9P3midq5aaXj4I+lnSfNi7Pmd4EWk1fOZ3pxookaQTNew6bp4JaCBYM4HVFZF9g7UjJmsUmC2JlxOng==} peerDependencies: '@emotion/react': ^11.0.0-rc.0 @@ -3630,18 +4129,18 @@ packages: '@babel/runtime': 7.22.6 '@emotion/babel-plugin': 11.11.0 '@emotion/is-prop-valid': 1.2.1 - '@emotion/react': 11.11.1_react@18.2.0 + '@emotion/react': 11.11.1(react@18.2.0) '@emotion/serialize': 1.1.2 - '@emotion/use-insertion-effect-with-fallbacks': 1.0.1_react@18.2.0 + '@emotion/use-insertion-effect-with-fallbacks': 1.0.1(react@18.2.0) '@emotion/utils': 1.2.1 react: 18.2.0 dev: false - /@emotion/unitless/0.8.1: + /@emotion/unitless@0.8.1: resolution: {integrity: sha512-KOEGMu6dmJZtpadb476IsZBclKvILjopjUii3V+7MnXIQCYh8W3NgNcgwo21n9LXZX6EDIKvqfjYxXebDwxKmQ==} dev: false - /@emotion/use-insertion-effect-with-fallbacks/1.0.1_react@18.2.0: + /@emotion/use-insertion-effect-with-fallbacks@1.0.1(react@18.2.0): resolution: {integrity: sha512-jT/qyKZ9rzLErtrjGgdkMBn2OP8wl0G3sQlBb3YPryvKHsjvINUhVaPFfP+fpBcOkmrVOVEEHQFJ7nbj2TH2gw==} peerDependencies: react: '>=16.8.0' @@ -3649,70 +4148,70 @@ packages: react: 18.2.0 dev: false - /@emotion/utils/1.2.1: + /@emotion/utils@1.2.1: resolution: {integrity: sha512-Y2tGf3I+XVnajdItskUCn6LX+VUDmP6lTL4fcqsXAv43dnlbZiuW4MWQW38rW/BVWSE7Q/7+XQocmpnRYILUmg==} dev: false - /@emotion/weak-memoize/0.3.1: + /@emotion/weak-memoize@0.3.1: resolution: {integrity: sha512-EsBwpc7hBUJWAsNPBmJy4hxWx12v6bshQsldrVmjxJoc3isbxhOrF2IcCpaXxfvq03NwkI7sbsOLXbYuqF/8Ww==} dev: false - /@esbuild-kit/cjs-loader/2.4.2: + /@esbuild-kit/cjs-loader@2.4.2: resolution: {integrity: sha512-BDXFbYOJzT/NBEtp71cvsrGPwGAMGRB/349rwKuoxNSiKjPraNNnlK6MIIabViCjqZugu6j+xeMDlEkWdHHJSg==} dependencies: '@esbuild-kit/core-utils': 3.1.0 get-tsconfig: 4.6.2 dev: true - /@esbuild-kit/core-utils/3.1.0: + /@esbuild-kit/core-utils@3.1.0: resolution: {integrity: sha512-Uuk8RpCg/7fdHSceR1M6XbSZFSuMrxcePFuGgyvsBn+u339dk5OeL4jv2EojwTN2st/unJGsVm4qHWjWNmJ/tw==} dependencies: esbuild: 0.17.19 source-map-support: 0.5.21 dev: true - /@esbuild-kit/esm-loader/2.5.5: + /@esbuild-kit/esm-loader@2.5.5: resolution: {integrity: sha512-Qwfvj/qoPbClxCRNuac1Du01r9gvNOT+pMYtJDapfB1eoGN1YlJ1BixLyL9WVENRx5RXgNLdfYdx/CuswlGhMw==} dependencies: '@esbuild-kit/core-utils': 3.1.0 get-tsconfig: 4.6.2 dev: true - /@esbuild/android-arm/0.17.19: - resolution: {integrity: sha512-rIKddzqhmav7MSmoFCmDIb6e2W57geRsM94gV2l38fzhXMwq7hZoClug9USI2pFRGL06f4IOPHHpFNOkWieR8A==} + /@esbuild/android-arm64@0.17.19: + resolution: {integrity: sha512-KBMWvEZooR7+kzY0BtbTQn0OAYY7CsiydT63pVEaPtVYF0hXbUaOyZog37DKxK7NF3XacBJOpYT4adIJh+avxA==} engines: {node: '>=12'} - cpu: [arm] + cpu: [arm64] os: [android] requiresBuild: true dev: true optional: true - /@esbuild/android-arm/0.18.11: - resolution: {integrity: sha512-q4qlUf5ucwbUJZXF5tEQ8LF7y0Nk4P58hOsGk3ucY0oCwgQqAnqXVbUuahCddVHfrxmpyewRpiTHwVHIETYu7Q==} + /@esbuild/android-arm64@0.18.11: + resolution: {integrity: sha512-snieiq75Z1z5LJX9cduSAjUr7vEI1OdlzFPMw0HH5YI7qQHDd3qs+WZoMrWYDsfRJSq36lIA6mfZBkvL46KoIw==} engines: {node: '>=12'} - cpu: [arm] + cpu: [arm64] os: [android] requiresBuild: true optional: true - /@esbuild/android-arm64/0.17.19: - resolution: {integrity: sha512-KBMWvEZooR7+kzY0BtbTQn0OAYY7CsiydT63pVEaPtVYF0hXbUaOyZog37DKxK7NF3XacBJOpYT4adIJh+avxA==} + /@esbuild/android-arm@0.17.19: + resolution: {integrity: sha512-rIKddzqhmav7MSmoFCmDIb6e2W57geRsM94gV2l38fzhXMwq7hZoClug9USI2pFRGL06f4IOPHHpFNOkWieR8A==} engines: {node: '>=12'} - cpu: [arm64] + cpu: [arm] os: [android] requiresBuild: true dev: true optional: true - /@esbuild/android-arm64/0.18.11: - resolution: {integrity: sha512-snieiq75Z1z5LJX9cduSAjUr7vEI1OdlzFPMw0HH5YI7qQHDd3qs+WZoMrWYDsfRJSq36lIA6mfZBkvL46KoIw==} + /@esbuild/android-arm@0.18.11: + resolution: {integrity: sha512-q4qlUf5ucwbUJZXF5tEQ8LF7y0Nk4P58hOsGk3ucY0oCwgQqAnqXVbUuahCddVHfrxmpyewRpiTHwVHIETYu7Q==} engines: {node: '>=12'} - cpu: [arm64] + cpu: [arm] os: [android] requiresBuild: true optional: true - /@esbuild/android-x64/0.17.19: + /@esbuild/android-x64@0.17.19: resolution: {integrity: sha512-uUTTc4xGNDT7YSArp/zbtmbhO0uEEK9/ETW29Wk1thYUJBz3IVnvgEiEwEa9IeLyvnpKrWK64Utw2bgUmDveww==} engines: {node: '>=12'} cpu: [x64] @@ -3721,7 +4220,7 @@ packages: dev: true optional: true - /@esbuild/android-x64/0.18.11: + /@esbuild/android-x64@0.18.11: resolution: {integrity: sha512-iPuoxQEV34+hTF6FT7om+Qwziv1U519lEOvekXO9zaMMlT9+XneAhKL32DW3H7okrCOBQ44BMihE8dclbZtTuw==} engines: {node: '>=12'} cpu: [x64] @@ -3729,7 +4228,7 @@ packages: requiresBuild: true optional: true - /@esbuild/darwin-arm64/0.17.19: + /@esbuild/darwin-arm64@0.17.19: resolution: {integrity: sha512-80wEoCfF/hFKM6WE1FyBHc9SfUblloAWx6FJkFWTWiCoht9Mc0ARGEM47e67W9rI09YoUxJL68WHfDRYEAvOhg==} engines: {node: '>=12'} cpu: [arm64] @@ -3738,7 +4237,7 @@ packages: dev: true optional: true - /@esbuild/darwin-arm64/0.18.11: + /@esbuild/darwin-arm64@0.18.11: resolution: {integrity: sha512-Gm0QkI3k402OpfMKyQEEMG0RuW2LQsSmI6OeO4El2ojJMoF5NLYb3qMIjvbG/lbMeLOGiW6ooU8xqc+S0fgz2w==} engines: {node: '>=12'} cpu: [arm64] @@ -3746,7 +4245,7 @@ packages: requiresBuild: true optional: true - /@esbuild/darwin-x64/0.17.19: + /@esbuild/darwin-x64@0.17.19: resolution: {integrity: sha512-IJM4JJsLhRYr9xdtLytPLSH9k/oxR3boaUIYiHkAawtwNOXKE8KoU8tMvryogdcT8AU+Bflmh81Xn6Q0vTZbQw==} engines: {node: '>=12'} cpu: [x64] @@ -3755,7 +4254,7 @@ packages: dev: true optional: true - /@esbuild/darwin-x64/0.18.11: + /@esbuild/darwin-x64@0.18.11: resolution: {integrity: sha512-N15Vzy0YNHu6cfyDOjiyfJlRJCB/ngKOAvoBf1qybG3eOq0SL2Lutzz9N7DYUbb7Q23XtHPn6lMDF6uWbGv9Fw==} engines: {node: '>=12'} cpu: [x64] @@ -3763,7 +4262,7 @@ packages: requiresBuild: true optional: true - /@esbuild/freebsd-arm64/0.17.19: + /@esbuild/freebsd-arm64@0.17.19: resolution: {integrity: sha512-pBwbc7DufluUeGdjSU5Si+P3SoMF5DQ/F/UmTSb8HXO80ZEAJmrykPyzo1IfNbAoaqw48YRpv8shwd1NoI0jcQ==} engines: {node: '>=12'} cpu: [arm64] @@ -3772,7 +4271,7 @@ packages: dev: true optional: true - /@esbuild/freebsd-arm64/0.18.11: + /@esbuild/freebsd-arm64@0.18.11: resolution: {integrity: sha512-atEyuq6a3omEY5qAh5jIORWk8MzFnCpSTUruBgeyN9jZq1K/QI9uke0ATi3MHu4L8c59CnIi4+1jDKMuqmR71A==} engines: {node: '>=12'} cpu: [arm64] @@ -3780,7 +4279,7 @@ packages: requiresBuild: true optional: true - /@esbuild/freebsd-x64/0.17.19: + /@esbuild/freebsd-x64@0.17.19: resolution: {integrity: sha512-4lu+n8Wk0XlajEhbEffdy2xy53dpR06SlzvhGByyg36qJw6Kpfk7cp45DR/62aPH9mtJRmIyrXAS5UWBrJT6TQ==} engines: {node: '>=12'} cpu: [x64] @@ -3789,7 +4288,7 @@ packages: dev: true optional: true - /@esbuild/freebsd-x64/0.18.11: + /@esbuild/freebsd-x64@0.18.11: resolution: {integrity: sha512-XtuPrEfBj/YYYnAAB7KcorzzpGTvOr/dTtXPGesRfmflqhA4LMF0Gh/n5+a9JBzPuJ+CGk17CA++Hmr1F/gI0Q==} engines: {node: '>=12'} cpu: [x64] @@ -3797,41 +4296,41 @@ packages: requiresBuild: true optional: true - /@esbuild/linux-arm/0.17.19: - resolution: {integrity: sha512-cdmT3KxjlOQ/gZ2cjfrQOtmhG4HJs6hhvm3mWSRDPtZ/lP5oe8FWceS10JaSJC13GBd4eH/haHnqf7hhGNLerA==} + /@esbuild/linux-arm64@0.17.19: + resolution: {integrity: sha512-ct1Tg3WGwd3P+oZYqic+YZF4snNl2bsnMKRkb3ozHmnM0dGWuxcPTTntAF6bOP0Sp4x0PjSF+4uHQ1xvxfRKqg==} engines: {node: '>=12'} - cpu: [arm] + cpu: [arm64] os: [linux] requiresBuild: true dev: true optional: true - /@esbuild/linux-arm/0.18.11: - resolution: {integrity: sha512-Idipz+Taso/toi2ETugShXjQ3S59b6m62KmLHkJlSq/cBejixmIydqrtM2XTvNCywFl3VC7SreSf6NV0i6sRyg==} + /@esbuild/linux-arm64@0.18.11: + resolution: {integrity: sha512-c6Vh2WS9VFKxKZ2TvJdA7gdy0n6eSy+yunBvv4aqNCEhSWVor1TU43wNRp2YLO9Vng2G+W94aRz+ILDSwAiYog==} engines: {node: '>=12'} - cpu: [arm] + cpu: [arm64] os: [linux] requiresBuild: true optional: true - /@esbuild/linux-arm64/0.17.19: - resolution: {integrity: sha512-ct1Tg3WGwd3P+oZYqic+YZF4snNl2bsnMKRkb3ozHmnM0dGWuxcPTTntAF6bOP0Sp4x0PjSF+4uHQ1xvxfRKqg==} + /@esbuild/linux-arm@0.17.19: + resolution: {integrity: sha512-cdmT3KxjlOQ/gZ2cjfrQOtmhG4HJs6hhvm3mWSRDPtZ/lP5oe8FWceS10JaSJC13GBd4eH/haHnqf7hhGNLerA==} engines: {node: '>=12'} - cpu: [arm64] + cpu: [arm] os: [linux] requiresBuild: true dev: true optional: true - /@esbuild/linux-arm64/0.18.11: - resolution: {integrity: sha512-c6Vh2WS9VFKxKZ2TvJdA7gdy0n6eSy+yunBvv4aqNCEhSWVor1TU43wNRp2YLO9Vng2G+W94aRz+ILDSwAiYog==} + /@esbuild/linux-arm@0.18.11: + resolution: {integrity: sha512-Idipz+Taso/toi2ETugShXjQ3S59b6m62KmLHkJlSq/cBejixmIydqrtM2XTvNCywFl3VC7SreSf6NV0i6sRyg==} engines: {node: '>=12'} - cpu: [arm64] + cpu: [arm] os: [linux] requiresBuild: true optional: true - /@esbuild/linux-ia32/0.17.19: + /@esbuild/linux-ia32@0.17.19: resolution: {integrity: sha512-w4IRhSy1VbsNxHRQpeGCHEmibqdTUx61Vc38APcsRbuVgK0OPEnQ0YD39Brymn96mOx48Y2laBQGqgZ0j9w6SQ==} engines: {node: '>=12'} cpu: [ia32] @@ -3840,7 +4339,7 @@ packages: dev: true optional: true - /@esbuild/linux-ia32/0.18.11: + /@esbuild/linux-ia32@0.18.11: resolution: {integrity: sha512-S3hkIF6KUqRh9n1Q0dSyYcWmcVa9Cg+mSoZEfFuzoYXXsk6196qndrM+ZiHNwpZKi3XOXpShZZ+9dfN5ykqjjw==} engines: {node: '>=12'} cpu: [ia32] @@ -3848,7 +4347,7 @@ packages: requiresBuild: true optional: true - /@esbuild/linux-loong64/0.14.54: + /@esbuild/linux-loong64@0.14.54: resolution: {integrity: sha512-bZBrLAIX1kpWelV0XemxBZllyRmM6vgFQQG2GdNb+r3Fkp0FOh1NJSvekXDs7jq70k4euu1cryLMfU+mTXlEpw==} engines: {node: '>=12'} cpu: [loong64] @@ -3857,7 +4356,7 @@ packages: dev: false optional: true - /@esbuild/linux-loong64/0.17.19: + /@esbuild/linux-loong64@0.17.19: resolution: {integrity: sha512-2iAngUbBPMq439a+z//gE+9WBldoMp1s5GWsUSgqHLzLJ9WoZLZhpwWuym0u0u/4XmZ3gpHmzV84PonE+9IIdQ==} engines: {node: '>=12'} cpu: [loong64] @@ -3866,7 +4365,7 @@ packages: dev: true optional: true - /@esbuild/linux-loong64/0.18.11: + /@esbuild/linux-loong64@0.18.11: resolution: {integrity: sha512-MRESANOoObQINBA+RMZW+Z0TJWpibtE7cPFnahzyQHDCA9X9LOmGh68MVimZlM9J8n5Ia8lU773te6O3ILW8kw==} engines: {node: '>=12'} cpu: [loong64] @@ -3874,7 +4373,7 @@ packages: requiresBuild: true optional: true - /@esbuild/linux-mips64el/0.17.19: + /@esbuild/linux-mips64el@0.17.19: resolution: {integrity: sha512-LKJltc4LVdMKHsrFe4MGNPp0hqDFA1Wpt3jE1gEyM3nKUvOiO//9PheZZHfYRfYl6AwdTH4aTcXSqBerX0ml4A==} engines: {node: '>=12'} cpu: [mips64el] @@ -3883,7 +4382,7 @@ packages: dev: true optional: true - /@esbuild/linux-mips64el/0.18.11: + /@esbuild/linux-mips64el@0.18.11: resolution: {integrity: sha512-qVyPIZrXNMOLYegtD1u8EBccCrBVshxMrn5MkuFc3mEVsw7CCQHaqZ4jm9hbn4gWY95XFnb7i4SsT3eflxZsUg==} engines: {node: '>=12'} cpu: [mips64el] @@ -3891,7 +4390,7 @@ packages: requiresBuild: true optional: true - /@esbuild/linux-ppc64/0.17.19: + /@esbuild/linux-ppc64@0.17.19: resolution: {integrity: sha512-/c/DGybs95WXNS8y3Ti/ytqETiW7EU44MEKuCAcpPto3YjQbyK3IQVKfF6nbghD7EcLUGl0NbiL5Rt5DMhn5tg==} engines: {node: '>=12'} cpu: [ppc64] @@ -3900,7 +4399,7 @@ packages: dev: true optional: true - /@esbuild/linux-ppc64/0.18.11: + /@esbuild/linux-ppc64@0.18.11: resolution: {integrity: sha512-T3yd8vJXfPirZaUOoA9D2ZjxZX4Gr3QuC3GztBJA6PklLotc/7sXTOuuRkhE9W/5JvJP/K9b99ayPNAD+R+4qQ==} engines: {node: '>=12'} cpu: [ppc64] @@ -3908,7 +4407,7 @@ packages: requiresBuild: true optional: true - /@esbuild/linux-riscv64/0.17.19: + /@esbuild/linux-riscv64@0.17.19: resolution: {integrity: sha512-FC3nUAWhvFoutlhAkgHf8f5HwFWUL6bYdvLc/TTuxKlvLi3+pPzdZiFKSWz/PF30TB1K19SuCxDTI5KcqASJqA==} engines: {node: '>=12'} cpu: [riscv64] @@ -3917,7 +4416,7 @@ packages: dev: true optional: true - /@esbuild/linux-riscv64/0.18.11: + /@esbuild/linux-riscv64@0.18.11: resolution: {integrity: sha512-evUoRPWiwuFk++snjH9e2cAjF5VVSTj+Dnf+rkO/Q20tRqv+644279TZlPK8nUGunjPAtQRCj1jQkDAvL6rm2w==} engines: {node: '>=12'} cpu: [riscv64] @@ -3925,7 +4424,7 @@ packages: requiresBuild: true optional: true - /@esbuild/linux-s390x/0.17.19: + /@esbuild/linux-s390x@0.17.19: resolution: {integrity: sha512-IbFsFbxMWLuKEbH+7sTkKzL6NJmG2vRyy6K7JJo55w+8xDk7RElYn6xvXtDW8HCfoKBFK69f3pgBJSUSQPr+4Q==} engines: {node: '>=12'} cpu: [s390x] @@ -3934,7 +4433,7 @@ packages: dev: true optional: true - /@esbuild/linux-s390x/0.18.11: + /@esbuild/linux-s390x@0.18.11: resolution: {integrity: sha512-/SlRJ15XR6i93gRWquRxYCfhTeC5PdqEapKoLbX63PLCmAkXZHY2uQm2l9bN0oPHBsOw2IswRZctMYS0MijFcg==} engines: {node: '>=12'} cpu: [s390x] @@ -3942,7 +4441,7 @@ packages: requiresBuild: true optional: true - /@esbuild/linux-x64/0.17.19: + /@esbuild/linux-x64@0.17.19: resolution: {integrity: sha512-68ngA9lg2H6zkZcyp22tsVt38mlhWde8l3eJLWkyLrp4HwMUr3c1s/M2t7+kHIhvMjglIBrFpncX1SzMckomGw==} engines: {node: '>=12'} cpu: [x64] @@ -3951,7 +4450,7 @@ packages: dev: true optional: true - /@esbuild/linux-x64/0.18.11: + /@esbuild/linux-x64@0.18.11: resolution: {integrity: sha512-xcncej+wF16WEmIwPtCHi0qmx1FweBqgsRtEL1mSHLFR6/mb3GEZfLQnx+pUDfRDEM4DQF8dpXIW7eDOZl1IbA==} engines: {node: '>=12'} cpu: [x64] @@ -3959,7 +4458,7 @@ packages: requiresBuild: true optional: true - /@esbuild/netbsd-x64/0.17.19: + /@esbuild/netbsd-x64@0.17.19: resolution: {integrity: sha512-CwFq42rXCR8TYIjIfpXCbRX0rp1jo6cPIUPSaWwzbVI4aOfX96OXY8M6KNmtPcg7QjYeDmN+DD0Wp3LaBOLf4Q==} engines: {node: '>=12'} cpu: [x64] @@ -3968,7 +4467,7 @@ packages: dev: true optional: true - /@esbuild/netbsd-x64/0.18.11: + /@esbuild/netbsd-x64@0.18.11: resolution: {integrity: sha512-aSjMHj/F7BuS1CptSXNg6S3M4F3bLp5wfFPIJM+Km2NfIVfFKhdmfHF9frhiCLIGVzDziggqWll0B+9AUbud/Q==} engines: {node: '>=12'} cpu: [x64] @@ -3976,7 +4475,7 @@ packages: requiresBuild: true optional: true - /@esbuild/openbsd-x64/0.17.19: + /@esbuild/openbsd-x64@0.17.19: resolution: {integrity: sha512-cnq5brJYrSZ2CF6c35eCmviIN3k3RczmHz8eYaVlNasVqsNY+JKohZU5MKmaOI+KkllCdzOKKdPs762VCPC20g==} engines: {node: '>=12'} cpu: [x64] @@ -3985,7 +4484,7 @@ packages: dev: true optional: true - /@esbuild/openbsd-x64/0.18.11: + /@esbuild/openbsd-x64@0.18.11: resolution: {integrity: sha512-tNBq+6XIBZtht0xJGv7IBB5XaSyvYPCm1PxJ33zLQONdZoLVM0bgGqUrXnJyiEguD9LU4AHiu+GCXy/Hm9LsdQ==} engines: {node: '>=12'} cpu: [x64] @@ -3993,7 +4492,7 @@ packages: requiresBuild: true optional: true - /@esbuild/sunos-x64/0.17.19: + /@esbuild/sunos-x64@0.17.19: resolution: {integrity: sha512-vCRT7yP3zX+bKWFeP/zdS6SqdWB8OIpaRq/mbXQxTGHnIxspRtigpkUcDMlSCOejlHowLqII7K2JKevwyRP2rg==} engines: {node: '>=12'} cpu: [x64] @@ -4002,7 +4501,7 @@ packages: dev: true optional: true - /@esbuild/sunos-x64/0.18.11: + /@esbuild/sunos-x64@0.18.11: resolution: {integrity: sha512-kxfbDOrH4dHuAAOhr7D7EqaYf+W45LsAOOhAet99EyuxxQmjbk8M9N4ezHcEiCYPaiW8Dj3K26Z2V17Gt6p3ng==} engines: {node: '>=12'} cpu: [x64] @@ -4010,7 +4509,7 @@ packages: requiresBuild: true optional: true - /@esbuild/win32-arm64/0.17.19: + /@esbuild/win32-arm64@0.17.19: resolution: {integrity: sha512-yYx+8jwowUstVdorcMdNlzklLYhPxjniHWFKgRqH7IFlUEa0Umu3KuYplf1HUZZ422e3NU9F4LGb+4O0Kdcaag==} engines: {node: '>=12'} cpu: [arm64] @@ -4019,7 +4518,7 @@ packages: dev: true optional: true - /@esbuild/win32-arm64/0.18.11: + /@esbuild/win32-arm64@0.18.11: resolution: {integrity: sha512-Sh0dDRyk1Xi348idbal7lZyfSkjhJsdFeuC13zqdipsvMetlGiFQNdO+Yfp6f6B4FbyQm7qsk16yaZk25LChzg==} engines: {node: '>=12'} cpu: [arm64] @@ -4027,7 +4526,7 @@ packages: requiresBuild: true optional: true - /@esbuild/win32-ia32/0.17.19: + /@esbuild/win32-ia32@0.17.19: resolution: {integrity: sha512-eggDKanJszUtCdlVs0RB+h35wNlb5v4TWEkq4vZcmVt5u/HiDZrTXe2bWFQUez3RgNHwx/x4sk5++4NSSicKkw==} engines: {node: '>=12'} cpu: [ia32] @@ -4036,7 +4535,7 @@ packages: dev: true optional: true - /@esbuild/win32-ia32/0.18.11: + /@esbuild/win32-ia32@0.18.11: resolution: {integrity: sha512-o9JUIKF1j0rqJTFbIoF4bXj6rvrTZYOrfRcGyL0Vm5uJ/j5CkBD/51tpdxe9lXEDouhRgdr/BYzUrDOvrWwJpg==} engines: {node: '>=12'} cpu: [ia32] @@ -4044,7 +4543,7 @@ packages: requiresBuild: true optional: true - /@esbuild/win32-x64/0.17.19: + /@esbuild/win32-x64@0.17.19: resolution: {integrity: sha512-lAhycmKnVOuRYNtRtatQR1LPQf2oYCkRGkSFnseDAKPl8lu5SOsK/e1sXe5a0Pc5kHIHe6P2I/ilntNv2xf3cA==} engines: {node: '>=12'} cpu: [x64] @@ -4053,7 +4552,7 @@ packages: dev: true optional: true - /@esbuild/win32-x64/0.18.11: + /@esbuild/win32-x64@0.18.11: resolution: {integrity: sha512-rQI4cjLHd2hGsM1LqgDI7oOCYbQ6IBOVsX9ejuRMSze0GqXUG2ekwiKkiBU1pRGSeCqFFHxTrcEydB2Hyoz9CA==} engines: {node: '>=12'} cpu: [x64] @@ -4061,7 +4560,7 @@ packages: requiresBuild: true optional: true - /@eslint-community/eslint-utils/4.4.0_eslint@8.44.0: + /@eslint-community/eslint-utils@4.4.0(eslint@8.44.0): resolution: {integrity: sha512-1/sA4dwrzBAyeUoQ6oxahHKmrZvsnLCg4RfxW3ZFGGmQkSNQPFNLV9CUEFQP1x9EYXHTo5p6xdhZM1Ne9p/AfA==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: @@ -4071,17 +4570,17 @@ packages: eslint-visitor-keys: 3.4.1 dev: true - /@eslint-community/regexpp/4.5.1: + /@eslint-community/regexpp@4.5.1: resolution: {integrity: sha512-Z5ba73P98O1KUYCCJTUeVpja9RcGoMdncZ6T49FCUl2lN38JtCJ+3WgIDBv0AuY4WChU5PmtJmOCTlN6FZTFKQ==} engines: {node: ^12.0.0 || ^14.0.0 || >=16.0.0} dev: true - /@eslint/eslintrc/1.4.1: + /@eslint/eslintrc@1.4.1: resolution: {integrity: sha512-XXrH9Uarn0stsyldqDYq8r++mROmWRI1xKMXa640Bb//SY1+ECYX6VzT6Lcx5frD0V30XieqJ0oX9I2Xj5aoMA==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dependencies: ajv: 6.12.6 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) espree: 9.6.0 globals: 13.20.0 ignore: 5.2.4 @@ -4093,12 +4592,12 @@ packages: - supports-color dev: true - /@eslint/eslintrc/2.1.0: + /@eslint/eslintrc@2.1.0: resolution: {integrity: sha512-Lj7DECXqIVCqnqjjHMPna4vn6GJcMgul/wuS0je9OZ9gsL0zzDpKPVtcG1HaDVc+9y+qgXneTeUMbCqXJNpH1A==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dependencies: ajv: 6.12.6 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) espree: 9.6.0 globals: 13.20.0 ignore: 5.2.4 @@ -4110,125 +4609,127 @@ packages: - supports-color dev: true - /@eslint/js/8.44.0: + /@eslint/js@8.44.0: resolution: {integrity: sha512-Ag+9YM4ocKQx9AarydN0KY2j0ErMHNIocPDrVo8zAE44xLTjEtz81OdR68/cydGtk6m6jDb5Za3r2useMzYmSw==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dev: true - /@faker-js/faker/8.0.2: + /@faker-js/faker@8.0.2: resolution: {integrity: sha512-Uo3pGspElQW91PCvKSIAXoEgAUlRnH29sX2/p89kg7sP1m2PzCufHINd0FhTXQf6DYGiUlVncdSPa2F9wxed2A==} engines: {node: ^14.17.0 || ^16.13.0 || >=18.0.0, npm: '>=6.14.13'} dev: true - /@fastify/ajv-compiler/3.5.0: + /@fastify/ajv-compiler@3.5.0: resolution: {integrity: sha512-ebbEtlI7dxXF5ziNdr05mOY8NnDiPB1XvAlLHctRt/Rc+C3LCOVW5imUVX+mhvUhnNzmPBHewUkOFgGlCxgdAA==} dependencies: ajv: 8.12.0 - ajv-formats: 2.1.1 + ajv-formats: 2.1.1(ajv@8.12.0) fast-uri: 2.2.0 dev: true - /@fastify/deepmerge/1.3.0: + /@fastify/deepmerge@1.3.0: resolution: {integrity: sha512-J8TOSBq3SoZbDhM9+R/u77hP93gz/rajSA+K2kGyijPpORPWUXHUpTaleoj+92As0S9uPRP7Oi8IqMf0u+ro6A==} dev: true - /@fastify/error/3.3.0: + /@fastify/error@3.3.0: resolution: {integrity: sha512-dj7vjIn1Ar8sVXj2yAXiMNCJDmS9MQ9XMlIecX2dIzzhjSHCyKo4DdXjXMs7wKW2kj6yvVRSpuQjOZ3YLrh56w==} dev: true - /@fastify/fast-json-stringify-compiler/4.3.0: + /@fastify/fast-json-stringify-compiler@4.3.0: resolution: {integrity: sha512-aZAXGYo6m22Fk1zZzEUKBvut/CIIQe/BapEORnxiD5Qr0kPHqqI69NtEMCme74h+at72sPhbkb4ZrLd1W3KRLA==} dependencies: fast-json-stringify: 5.7.0 dev: true - /@floating-ui/core/0.3.1: + /@floating-ui/core@0.3.1: resolution: {integrity: sha512-ensKY7Ub59u16qsVIFEo2hwTCqZ/r9oZZFh51ivcLGHfUwTn8l1Xzng8RJUe91H/UP8PeqeBronAGx0qmzwk2g==} dev: true - /@floating-ui/dom/0.1.10: + /@floating-ui/dom@0.1.10: resolution: {integrity: sha512-4kAVoogvQm2N0XE0G6APQJuCNuErjOfPW8Ux7DFxh8+AfugWflwVJ5LDlHOwrwut7z/30NUvdtHzQ3zSip4EzQ==} dependencies: '@floating-ui/core': 0.3.1 dev: true - /@gar/promisify/1.1.3: + /@gar/promisify@1.1.3: resolution: {integrity: sha512-k2Ty1JcVojjJFwrg/ThKi2ujJ7XNLYaFGNB/bWT9wGR+oSMJHMa5w+CUq6p/pVrKeNNgA7pCqEcjSnHVoqJQFw==} dev: true - /@graphql-typed-document-node/core/3.2.0: + /@graphql-typed-document-node/core@3.2.0(graphql@16.7.1): resolution: {integrity: sha512-mB9oAsNCm9aM3/SOv4YtBMqZbYj10R7dkq8byBqxGY/ncFwhf2oQzMV+LCRlWoDSEBJ3COiR1yeDvMtsoOsuFQ==} peerDependencies: graphql: ^0.8.0 || ^0.9.0 || ^0.10.0 || ^0.11.0 || ^0.12.0 || ^0.13.0 || ^14.0.0 || ^15.0.0 || ^16.0.0 || ^17.0.0 + dependencies: + graphql: 16.7.1 dev: false - /@humanwhocodes/config-array/0.11.10: + /@humanwhocodes/config-array@0.11.10: resolution: {integrity: sha512-KVVjQmNUepDVGXNuoRRdmmEjruj0KfiGSbS8LVc12LMsWDQzRXJ0qdhN8L8uUigKpfEHRhlaQFY0ib1tnUbNeQ==} engines: {node: '>=10.10.0'} dependencies: '@humanwhocodes/object-schema': 1.2.1 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) minimatch: 3.1.2 transitivePeerDependencies: - supports-color dev: true - /@humanwhocodes/config-array/0.9.5: + /@humanwhocodes/config-array@0.9.5: resolution: {integrity: sha512-ObyMyWxZiCu/yTisA7uzx81s40xR2fD5Cg/2Kq7G02ajkNubJf6BopgDTmDyc3U7sXpNKM8cYOw7s7Tyr+DnCw==} engines: {node: '>=10.10.0'} dependencies: '@humanwhocodes/object-schema': 1.2.1 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) minimatch: 3.1.2 transitivePeerDependencies: - supports-color dev: true - /@humanwhocodes/module-importer/1.0.1: + /@humanwhocodes/module-importer@1.0.1: resolution: {integrity: sha512-bxveV4V8v5Yb4ncFTT3rPSgZBOpCkjfK0y4oVVVJwIuDVBRMDXrPyXRL988i5ap9m9bnyEEjWfm5WkBmtffLfA==} engines: {node: '>=12.22'} dev: true - /@humanwhocodes/object-schema/1.2.1: + /@humanwhocodes/object-schema@1.2.1: resolution: {integrity: sha512-ZnQMnLV4e7hDlUvw8H+U8ASL02SS2Gn6+9Ac3wGGLIe7+je2AeAOxPY+izIPJDfFDb7eDjev0Us8MO1iFRN8hA==} dev: true - /@iconify-json/carbon/1.1.18: + /@iconify-json/carbon@1.1.18: resolution: {integrity: sha512-RbKET6KS9xUMeYVq1FUH3UUA7AYNcnApkHt2AccCwTWTQQs/O58ji4Of6z6PhRajGlbfvrJzT/Uqh19OKECRvA==} dependencies: '@iconify/types': 2.0.0 dev: true - /@iconify/types/2.0.0: + /@iconify/types@2.0.0: resolution: {integrity: sha512-+wluvCrRhXrhyOmRDJ3q8mux9JkKy5SJ/v8ol2tu4FVjyYvtEzkc/3pK15ET6RKg4b4w4BmTk1+gsCUhf21Ykg==} dev: true - /@iconify/utils/2.1.7: + /@iconify/utils@2.1.7: resolution: {integrity: sha512-P8S3z/L1LcV4Qem9AoCfVAaTFGySEMzFEY4CHZLkfRj0Fv9LiR+AwjDgrDrzyI93U2L2mg9JHsbTJ52mF8suNw==} dependencies: '@antfu/install-pkg': 0.1.1 '@antfu/utils': 0.7.5 '@iconify/types': 2.0.0 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) kolorist: 1.8.0 local-pkg: 0.4.3 transitivePeerDependencies: - supports-color dev: true - /@isaacs/cliui/8.0.2: + /@isaacs/cliui@8.0.2: resolution: {integrity: sha512-O8jcjabXaleOG9DQ0+ARXWZBTfnP4WNAqzuiJK7ll44AmxGKv/J2M4TPjxjY3znBCfvBXFzucm1twdyFybFqEA==} engines: {node: '>=12'} dependencies: string-width: 5.1.2 - string-width-cjs: /string-width/4.2.3 + string-width-cjs: /string-width@4.2.3 strip-ansi: 7.1.0 - strip-ansi-cjs: /strip-ansi/6.0.1 + strip-ansi-cjs: /strip-ansi@6.0.1 wrap-ansi: 8.1.0 - wrap-ansi-cjs: /wrap-ansi/7.0.0 + wrap-ansi-cjs: /wrap-ansi@7.0.0 dev: true - /@istanbuljs/load-nyc-config/1.1.0: + /@istanbuljs/load-nyc-config@1.1.0: resolution: {integrity: sha512-VjeHSlIzpv/NyD3N0YuHfXOPDIixcA1q2ZV98wsMqcYlPmv2n3Yb2lYP9XMElnaFVXg5A7YLTeLu6V84uQDjmQ==} engines: {node: '>=8'} dependencies: @@ -4239,24 +4740,181 @@ packages: resolve-from: 5.0.0 dev: true - /@istanbuljs/schema/0.1.3: + /@istanbuljs/schema@0.1.3: resolution: {integrity: sha512-ZXRY4jNvVgSVQ8DL3LTcakaAtXwTVUxE81hslsyD2AtoXW/wVob10HkOJ1X/pAlcI7D+2YoZKg5do8G/w6RYgA==} engines: {node: '>=8'} - /@jest/expect-utils/29.6.1: + /@jest/console@27.5.1: + resolution: {integrity: sha512-kZ/tNpS3NXn0mlXXXPNuDZnb4c0oZ20r4K5eemM2k30ZC3G0T02nXUvyhf5YdbXWHPEJLc9qGLxEZ216MdL+Zg==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@jest/types': 27.5.1 + '@types/node': 20.4.1 + chalk: 4.1.2 + jest-message-util: 27.5.1 + jest-util: 27.5.1 + slash: 3.0.0 + dev: true + + /@jest/core@27.5.1(ts-node@10.9.1): + resolution: {integrity: sha512-AK6/UTrvQD0Cd24NSqmIA6rKsu0tKIxfiCducZvqxYdmMisOYAsdItspT+fQDQYARPf8XgjAFZi0ogW2agH5nQ==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + peerDependencies: + node-notifier: ^8.0.1 || ^9.0.0 || ^10.0.0 + peerDependenciesMeta: + node-notifier: + optional: true + dependencies: + '@jest/console': 27.5.1 + '@jest/reporters': 27.5.1 + '@jest/test-result': 27.5.1 + '@jest/transform': 27.5.1 + '@jest/types': 27.5.1 + '@types/node': 20.4.1 + ansi-escapes: 4.3.2 + chalk: 4.1.2 + emittery: 0.8.1 + exit: 0.1.2 + graceful-fs: 4.2.11 + jest-changed-files: 27.5.1 + jest-config: 27.5.1(ts-node@10.9.1) + jest-haste-map: 27.5.1 + jest-message-util: 27.5.1 + jest-regex-util: 27.5.1 + jest-resolve: 27.5.1 + jest-resolve-dependencies: 27.5.1 + jest-runner: 27.5.1 + jest-runtime: 27.5.1 + jest-snapshot: 27.5.1 + jest-util: 27.5.1 + jest-validate: 27.5.1 + jest-watcher: 27.5.1 + micromatch: 4.0.5 + rimraf: 3.0.2 + slash: 3.0.0 + strip-ansi: 6.0.1 + transitivePeerDependencies: + - bufferutil + - canvas + - supports-color + - ts-node + - utf-8-validate + dev: true + + /@jest/environment@27.5.1: + resolution: {integrity: sha512-/WQjhPJe3/ghaol/4Bq480JKXV/Rfw8nQdN7f41fM8VDHLcxKXou6QyXAh3EFr9/bVG3x74z1NWDkP87EiY8gA==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@jest/fake-timers': 27.5.1 + '@jest/types': 27.5.1 + '@types/node': 20.4.1 + jest-mock: 27.5.1 + dev: true + + /@jest/expect-utils@29.6.1: resolution: {integrity: sha512-o319vIf5pEMx0LmzSxxkYYxo4wrRLKHq9dP1yJU7FoPTB0LfAKSz8SWD6D/6U3v/O52t9cF5t+MeJiRsfk7zMw==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: jest-get-type: 29.4.3 dev: true - /@jest/schemas/29.6.0: + /@jest/fake-timers@27.5.1: + resolution: {integrity: sha512-/aPowoolwa07k7/oM3aASneNeBGCmGQsc3ugN4u6s4C/+s5M64MFo/+djTdiwcbQlRfFElGuDXWzaWj6QgKObQ==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@jest/types': 27.5.1 + '@sinonjs/fake-timers': 8.1.0 + '@types/node': 20.4.1 + jest-message-util: 27.5.1 + jest-mock: 27.5.1 + jest-util: 27.5.1 + dev: true + + /@jest/globals@27.5.1: + resolution: {integrity: sha512-ZEJNB41OBQQgGzgyInAv0UUfDDj3upmHydjieSxFvTRuZElrx7tXg/uVQ5hYVEwiXs3+aMsAeEc9X7xiSKCm4Q==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@jest/environment': 27.5.1 + '@jest/types': 27.5.1 + expect: 27.5.1 + dev: true + + /@jest/reporters@27.5.1: + resolution: {integrity: sha512-cPXh9hWIlVJMQkVk84aIvXuBB4uQQmFqZiacloFuGiP3ah1sbCxCosidXFDfqG8+6fO1oR2dTJTlsOy4VFmUfw==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + peerDependencies: + node-notifier: ^8.0.1 || ^9.0.0 || ^10.0.0 + peerDependenciesMeta: + node-notifier: + optional: true + dependencies: + '@bcoe/v8-coverage': 0.2.3 + '@jest/console': 27.5.1 + '@jest/test-result': 27.5.1 + '@jest/transform': 27.5.1 + '@jest/types': 27.5.1 + '@types/node': 20.4.1 + chalk: 4.1.2 + collect-v8-coverage: 1.0.2 + exit: 0.1.2 + glob: 7.2.3 + graceful-fs: 4.2.11 + istanbul-lib-coverage: 3.2.0 + istanbul-lib-instrument: 5.2.1 + istanbul-lib-report: 3.0.0 + istanbul-lib-source-maps: 4.0.1 + istanbul-reports: 3.1.5 + jest-haste-map: 27.5.1 + jest-resolve: 27.5.1 + jest-util: 27.5.1 + jest-worker: 27.5.1 + slash: 3.0.0 + source-map: 0.6.1 + string-length: 4.0.2 + terminal-link: 2.1.1 + v8-to-istanbul: 8.1.1 + transitivePeerDependencies: + - supports-color + dev: true + + /@jest/schemas@29.6.0: resolution: {integrity: sha512-rxLjXyJBTL4LQeJW3aKo0M/+GkCOXsO+8i9Iu7eDb6KwtP65ayoDsitrdPBtujxQ88k4wI2FNYfa6TOGwSn6cQ==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: '@sinclair/typebox': 0.27.8 - /@jest/transform/26.6.2: + /@jest/source-map@27.5.1: + resolution: {integrity: sha512-y9NIHUYF3PJRlHk98NdC/N1gl88BL08aQQgu4k4ZopQkCw9t9cV8mtl3TV8b/YCB8XaVTFrmUTAJvjsntDireg==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + callsites: 3.1.0 + graceful-fs: 4.2.11 + source-map: 0.6.1 + dev: true + + /@jest/test-result@27.5.1: + resolution: {integrity: sha512-EW35l2RYFUcUQxFJz5Cv5MTOxlJIQs4I7gxzi2zVU7PJhOwfYq1MdC5nhSmYjX1gmMmLPvB3sIaC+BkcHRBfag==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@jest/console': 27.5.1 + '@jest/types': 27.5.1 + '@types/istanbul-lib-coverage': 2.0.4 + collect-v8-coverage: 1.0.2 + dev: true + + /@jest/test-sequencer@27.5.1: + resolution: {integrity: sha512-LCheJF7WB2+9JuCS7VB/EmGIdQuhtqjRNI9A43idHv3E4KltCTsPsLxvdaubFHSYwY/fNjMWjl6vNRhDiN7vpQ==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@jest/test-result': 27.5.1 + graceful-fs: 4.2.11 + jest-haste-map: 27.5.1 + jest-runtime: 27.5.1 + transitivePeerDependencies: + - supports-color + dev: true + + /@jest/transform@26.6.2: resolution: {integrity: sha512-E9JjhUgNzvuQ+vVAL21vlyfy12gP0GhazGgJC4h6qUt1jSdUXGWJ1wfu/X7Sd8etSgxV4ovT1pb9v5D6QW4XgA==} engines: {node: '>= 10.14.2'} dependencies: @@ -4279,7 +4937,30 @@ packages: - supports-color dev: true - /@jest/types/26.6.2: + /@jest/transform@27.5.1: + resolution: {integrity: sha512-ipON6WtYgl/1329g5AIJVbUuEh0wZVbdpGwC99Jw4LwuoBNS95MVphU6zOeD9pDkon+LLbFL7lOQRapbB8SCHw==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@babel/core': 7.22.8 + '@jest/types': 27.5.1 + babel-plugin-istanbul: 6.1.1 + chalk: 4.1.2 + convert-source-map: 1.9.0 + fast-json-stable-stringify: 2.1.0 + graceful-fs: 4.2.11 + jest-haste-map: 27.5.1 + jest-regex-util: 27.5.1 + jest-util: 27.5.1 + micromatch: 4.0.5 + pirates: 4.0.6 + slash: 3.0.0 + source-map: 0.6.1 + write-file-atomic: 3.0.3 + transitivePeerDependencies: + - supports-color + dev: true + + /@jest/types@26.6.2: resolution: {integrity: sha512-fC6QCp7Sc5sX6g8Tvbmj4XUTbyrik0akgRy03yjXbQaBWWNWGE7SGtJk98m0N8nzegD/7SggrUlivxo5ax4KWQ==} engines: {node: '>= 10.14.2'} dependencies: @@ -4290,7 +4971,18 @@ packages: chalk: 4.1.2 dev: true - /@jest/types/29.6.1: + /@jest/types@27.5.1: + resolution: {integrity: sha512-Cx46iJ9QpwQTjIdq5VJu2QTMMs3QlEjI0x1QbBP5W1+nMzyc2XmimiRR/CbX9TO0cPTeUlxWMOu8mslYsJ8DEw==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@types/istanbul-lib-coverage': 2.0.4 + '@types/istanbul-reports': 3.0.1 + '@types/node': 20.4.1 + '@types/yargs': 16.0.5 + chalk: 4.1.2 + dev: true + + /@jest/types@29.6.1: resolution: {integrity: sha512-tPKQNMPuXgvdOn2/Lg9HNfUvjYVGolt04Hp03f5hAk878uwOLikN+JzeLY0HcVgKgFl9Hs3EIqpu3WX27XNhnw==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: @@ -4302,21 +4994,21 @@ packages: chalk: 4.1.2 dev: true - /@joshwooding/vite-plugin-react-docgen-typescript/0.0.4_ilntetca2wlekmurdwyomywvbi: + /@joshwooding/vite-plugin-react-docgen-typescript@0.0.4(typescript@4.9.5)(vite@4.4.3): resolution: {integrity: sha512-ezL7SU//1OV4Oyt/zQ3CsX8uLujVEYUHuULkqgcW6wOuQfRnvgkn99HZtLWwS257GmZVwszGQzhL7VE3PbMAYw==} peerDependencies: typescript: '>= 4.3.x' vite: '>2.0.0-0' dependencies: glob: 7.2.3 - glob-promise: 4.2.2_glob@7.2.3 + glob-promise: 4.2.2(glob@7.2.3) magic-string: 0.26.7 - react-docgen-typescript: 2.2.2_typescript@4.9.5 + react-docgen-typescript: 2.2.2(typescript@4.9.5) typescript: 4.9.5 - vite: 4.4.3 + vite: 4.4.3(@types/node@18.16.19) dev: true - /@jridgewell/gen-mapping/0.3.3: + /@jridgewell/gen-mapping@0.3.3: resolution: {integrity: sha512-HLhSWOLRi875zjjMG/r+Nv0oCW8umGb0BgEhyX3dDX3egwZtB8PqLnjz3yedt8R5StBrzcg4aBpnh8UA9D1BoQ==} engines: {node: '>=6.0.0'} dependencies: @@ -4324,46 +5016,46 @@ packages: '@jridgewell/sourcemap-codec': 1.4.15 '@jridgewell/trace-mapping': 0.3.18 - /@jridgewell/resolve-uri/3.1.0: + /@jridgewell/resolve-uri@3.1.0: resolution: {integrity: sha512-F2msla3tad+Mfht5cJq7LSXcdudKTWCVYUgw6pLFOOHSTtZlj6SWNYAp+AhuqLmWdBO2X5hPrLcu8cVP8fy28w==} engines: {node: '>=6.0.0'} - /@jridgewell/resolve-uri/3.1.1: + /@jridgewell/resolve-uri@3.1.1: resolution: {integrity: sha512-dSYZh7HhCDtCKm4QakX0xFpsRDqjjtZf/kjI/v3T3Nwt5r8/qz/M19F9ySyOqU94SXBmeG9ttTul+YnR4LOxFA==} engines: {node: '>=6.0.0'} dev: true - /@jridgewell/set-array/1.1.2: + /@jridgewell/set-array@1.1.2: resolution: {integrity: sha512-xnkseuNADM0gt2bs+BvhO0p78Mk762YnZdsuzFV018NoG1Sj1SCQvpSqa7XUaTam5vAGasABV9qXASMKnFMwMw==} engines: {node: '>=6.0.0'} - /@jridgewell/source-map/0.3.5: + /@jridgewell/source-map@0.3.5: resolution: {integrity: sha512-UTYAUj/wviwdsMfzoSJspJxbkH5o1snzwX0//0ENX1u/55kkZZkcTZP6u9bwKGkv+dkk9at4m1Cpt0uY80kcpQ==} dependencies: '@jridgewell/gen-mapping': 0.3.3 '@jridgewell/trace-mapping': 0.3.18 dev: true - /@jridgewell/sourcemap-codec/1.4.14: + /@jridgewell/sourcemap-codec@1.4.14: resolution: {integrity: sha512-XPSJHWmi394fuUuzDnGz1wiKqWfo1yXecHQMRf2l6hztTO+nPru658AyDngaBe7isIxEkRsPR3FZh+s7iVa4Uw==} - /@jridgewell/sourcemap-codec/1.4.15: + /@jridgewell/sourcemap-codec@1.4.15: resolution: {integrity: sha512-eF2rxCRulEKXHTRiDrDy6erMYWqNw4LPdQ8UQA4huuxaQsVeRPFl2oM8oDGxMFhJUWZf9McpLtJasDDZb/Bpeg==} - /@jridgewell/trace-mapping/0.3.18: + /@jridgewell/trace-mapping@0.3.18: resolution: {integrity: sha512-w+niJYzMHdd7USdiH2U6869nqhD2nbfZXND5Yp93qIbEmnDNk7PD48o+YchRVpzMU7M6jVCbenTR7PA1FLQ9pA==} dependencies: '@jridgewell/resolve-uri': 3.1.0 '@jridgewell/sourcemap-codec': 1.4.14 - /@jridgewell/trace-mapping/0.3.9: + /@jridgewell/trace-mapping@0.3.9: resolution: {integrity: sha512-3Belt6tdc8bPgAtbcmdtNJlirVoTmEb5e2gC94PnkwEW9jI6CAHUeoG85tjWP5WquqfavoMtMwiG4P926ZKKuQ==} dependencies: '@jridgewell/resolve-uri': 3.1.1 '@jridgewell/sourcemap-codec': 1.4.15 dev: true - /@jsdevtools/ez-spawn/3.0.4: + /@jsdevtools/ez-spawn@3.0.4: resolution: {integrity: sha512-f5DRIOZf7wxogefH03RjMPMdBF7ADTWUMoOs9kaJo06EfwF+aFhMZMDZxHg/Xe12hptN9xoZjGso2fdjapBRIA==} engines: {node: '>=10'} dependencies: @@ -4373,28 +5065,28 @@ packages: type-detect: 4.0.8 dev: true - /@jspm/core/2.0.0-beta.24: + /@jspm/core@2.0.0-beta.24: resolution: {integrity: sha512-a4Bo/80Z6CoJNor5ldgs6002utmmbttP4JYd/FJ0Ob2fVdf6O6ha5SORBCqrnDnBvMc1TlrHY7dCfat5+H0a6A==} dev: false - /@lit-labs/ssr-dom-shim/1.1.1: + /@lit-labs/ssr-dom-shim@1.1.1: resolution: {integrity: sha512-kXOeFbfCm4fFf2A3WwVEeQj55tMZa8c8/f9AKHMobQMkzNUfUj+antR3fRPaZJawsa1aZiP/Da3ndpZrwEe4rQ==} dev: false - /@lit/reactive-element/1.6.2: + /@lit/reactive-element@1.6.2: resolution: {integrity: sha512-rDfl+QnCYjuIGf5xI2sVJWdYIi56CTCwWa+nidKYX6oIuBYwUbT/vX4qbUDlHiZKJ/3FRNQ/tWJui44p6/stSA==} dependencies: '@lit-labs/ssr-dom-shim': 1.1.1 dev: false - /@mdx-js/mdx/1.6.22: + /@mdx-js/mdx@1.6.22: resolution: {integrity: sha512-AMxuLxPz2j5/6TpF/XSdKpQP1NlG0z11dFOlq+2IP/lSgl11GY8ji6S/rgsViN/L0BDvHvUMruRb7ub+24LUYA==} dependencies: '@babel/core': 7.12.9 - '@babel/plugin-syntax-jsx': 7.12.1_@babel+core@7.12.9 - '@babel/plugin-syntax-object-rest-spread': 7.8.3_@babel+core@7.12.9 + '@babel/plugin-syntax-jsx': 7.12.1(@babel/core@7.12.9) + '@babel/plugin-syntax-object-rest-spread': 7.8.3(@babel/core@7.12.9) '@mdx-js/util': 1.6.22 - babel-plugin-apply-mdx-type-prop: 1.6.22_@babel+core@7.12.9 + babel-plugin-apply-mdx-type-prop: 1.6.22(@babel/core@7.12.9) babel-plugin-extract-import-names: 1.6.22 camelcase-css: 2.0.1 detab: 2.0.4 @@ -4413,7 +5105,7 @@ packages: - supports-color dev: true - /@mdx-js/react/1.6.22_react@17.0.2: + /@mdx-js/react@1.6.22(react@17.0.2): resolution: {integrity: sha512-TDoPum4SHdfPiGSAaRBw7ECyI8VaHpK8GJugbJIJuqyh6kzw9ZLJZW3HGL3NNrJGxcAixUvqROm+YuQOo5eXtg==} peerDependencies: react: ^16.13.1 || ^17.0.0 @@ -4421,11 +5113,11 @@ packages: react: 17.0.2 dev: true - /@mdx-js/util/1.6.22: + /@mdx-js/util@1.6.22: resolution: {integrity: sha512-H1rQc1ZOHANWBvPcW+JpGwr+juXSxM8Q8YCkm3GhZd8REu1fHR3z99CErO1p9pkcfcxZnMdIZdIsXkOHY0NilA==} dev: true - /@mrmlnc/readdir-enhanced/2.2.1: + /@mrmlnc/readdir-enhanced@2.2.1: resolution: {integrity: sha512-bPHp6Ji8b41szTOcaP63VlnbbO5Ny6dwAATtY6JTjh5N2OLrb5Qk/Th5cRkRQhkWCt+EJsYrNB0MiL+Gpn6e3g==} engines: {node: '>=4'} dependencies: @@ -4433,7 +5125,7 @@ packages: glob-to-regexp: 0.3.0 dev: true - /@mswjs/cookies/0.2.2: + /@mswjs/cookies@0.2.2: resolution: {integrity: sha512-mlN83YSrcFgk7Dm1Mys40DLssI1KdJji2CMKN8eOlBqsTADYzj2+jWzsANsUTFbxDMWPD5e9bfA1RGqBpS3O1g==} engines: {node: '>=14'} dependencies: @@ -4441,14 +5133,14 @@ packages: set-cookie-parser: 2.6.0 dev: true - /@mswjs/interceptors/0.17.9: + /@mswjs/interceptors@0.17.9: resolution: {integrity: sha512-4LVGt03RobMH/7ZrbHqRxQrS9cc2uh+iNKSj8UWr8M26A2i793ju+csaB5zaqYltqJmA2jUq4VeYfKmVqvsXQg==} engines: {node: '>=14'} dependencies: '@open-draft/until': 1.0.3 '@types/debug': 4.1.8 '@xmldom/xmldom': 0.8.8 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) headers-polyfill: 3.1.2 outvariant: 1.4.0 strict-event-emitter: 0.2.8 @@ -4457,7 +5149,7 @@ packages: - supports-color dev: true - /@mui/base/5.0.0-beta.7_biqbaboplfbrettd7655fr4n2y: + /@mui/base@5.0.0-beta.7(react-dom@18.2.0)(react@18.2.0): resolution: {integrity: sha512-Pjbwm6gjiS96kOMF7E5fjEJsenc0tZBesrLQ4rrdi3eT/c/yhSWnPbCUkHSz8bnS0l3/VQ8bA+oERSGSV2PK6A==} engines: {node: '>=12.0.0'} peerDependencies: @@ -4471,20 +5163,20 @@ packages: '@babel/runtime': 7.22.6 '@emotion/is-prop-valid': 1.2.1 '@mui/types': 7.2.4 - '@mui/utils': 5.13.7_react@18.2.0 + '@mui/utils': 5.13.7(react@18.2.0) '@popperjs/core': 2.11.8 clsx: 1.2.1 prop-types: 15.8.1 react: 18.2.0 - react-dom: 18.2.0_react@18.2.0 + react-dom: 18.2.0(react@18.2.0) react-is: 18.2.0 dev: false - /@mui/core-downloads-tracker/5.14.0: + /@mui/core-downloads-tracker@5.14.0: resolution: {integrity: sha512-SYBOVCatVDUf/lbrLGah09bHhX5WfUXg7kSskfLILr6SvKRni0NLp0aonxQ0SMALVVK3Qwa6cW4CdWuwS0gC1w==} dev: false - /@mui/material/5.14.0_vizhjgize6w4e5tnsjmztd65da: + /@mui/material@5.14.0(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(react-dom@18.2.0)(react@18.2.0): resolution: {integrity: sha512-HP7CP71NhMkui2HUIEKl2/JfuHMuoarSUWAKlNw6s17bl/Num9rN61EM6uUzc2A2zHjj/00A66GnvDnmixEJEw==} engines: {node: '>=12.0.0'} peerDependencies: @@ -4502,24 +5194,24 @@ packages: optional: true dependencies: '@babel/runtime': 7.22.6 - '@emotion/react': 11.11.1_react@18.2.0 - '@emotion/styled': 11.11.0_xo5t6f4ryb2nvjgwj2cxjowrye - '@mui/base': 5.0.0-beta.7_biqbaboplfbrettd7655fr4n2y + '@emotion/react': 11.11.1(react@18.2.0) + '@emotion/styled': 11.11.0(@emotion/react@11.11.1)(react@18.2.0) + '@mui/base': 5.0.0-beta.7(react-dom@18.2.0)(react@18.2.0) '@mui/core-downloads-tracker': 5.14.0 - '@mui/system': 5.14.0_5uavjbr3lmuxf4a3t6dmknaeea + '@mui/system': 5.14.0(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(react@18.2.0) '@mui/types': 7.2.4 - '@mui/utils': 5.13.7_react@18.2.0 + '@mui/utils': 5.13.7(react@18.2.0) '@types/react-transition-group': 4.4.6 clsx: 1.2.1 csstype: 3.1.2 prop-types: 15.8.1 react: 18.2.0 - react-dom: 18.2.0_react@18.2.0 + react-dom: 18.2.0(react@18.2.0) react-is: 18.2.0 - react-transition-group: 4.4.5_biqbaboplfbrettd7655fr4n2y + react-transition-group: 4.4.5(react-dom@18.2.0)(react@18.2.0) dev: false - /@mui/private-theming/5.13.7_react@18.2.0: + /@mui/private-theming@5.13.7(react@18.2.0): resolution: {integrity: sha512-qbSr+udcij5F9dKhGX7fEdx2drXchq7htLNr2Qg2Ma+WJ6q0ERlEqGSBiPiVDJkptcjeVL4DGmcf1wl5+vD4EA==} engines: {node: '>=12.0.0'} peerDependencies: @@ -4530,12 +5222,12 @@ packages: optional: true dependencies: '@babel/runtime': 7.22.6 - '@mui/utils': 5.13.7_react@18.2.0 + '@mui/utils': 5.13.7(react@18.2.0) prop-types: 15.8.1 react: 18.2.0 dev: false - /@mui/styled-engine/5.13.2_5uavjbr3lmuxf4a3t6dmknaeea: + /@mui/styled-engine@5.13.2(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(react@18.2.0): resolution: {integrity: sha512-VCYCU6xVtXOrIN8lcbuPmoG+u7FYuOERG++fpY74hPpEWkyFQG97F+/XfTQVYzlR2m7nPjnwVUgATcTCMEaMvw==} engines: {node: '>=12.0.0'} peerDependencies: @@ -4550,14 +5242,14 @@ packages: dependencies: '@babel/runtime': 7.22.6 '@emotion/cache': 11.11.0 - '@emotion/react': 11.11.1_react@18.2.0 - '@emotion/styled': 11.11.0_xo5t6f4ryb2nvjgwj2cxjowrye + '@emotion/react': 11.11.1(react@18.2.0) + '@emotion/styled': 11.11.0(@emotion/react@11.11.1)(react@18.2.0) csstype: 3.1.2 prop-types: 15.8.1 react: 18.2.0 dev: false - /@mui/system/5.14.0_5uavjbr3lmuxf4a3t6dmknaeea: + /@mui/system@5.14.0(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(react@18.2.0): resolution: {integrity: sha512-0HZGkX8miJbiNw+rjlZ9l0Cfkz1bSqfSHQH0EH9J+nx0aAm5cBleg9piOlLdCNIWGgecCqsw4x62erGrGjjcJg==} engines: {node: '>=12.0.0'} peerDependencies: @@ -4574,19 +5266,19 @@ packages: optional: true dependencies: '@babel/runtime': 7.22.6 - '@emotion/react': 11.11.1_react@18.2.0 - '@emotion/styled': 11.11.0_xo5t6f4ryb2nvjgwj2cxjowrye - '@mui/private-theming': 5.13.7_react@18.2.0 - '@mui/styled-engine': 5.13.2_5uavjbr3lmuxf4a3t6dmknaeea + '@emotion/react': 11.11.1(react@18.2.0) + '@emotion/styled': 11.11.0(@emotion/react@11.11.1)(react@18.2.0) + '@mui/private-theming': 5.13.7(react@18.2.0) + '@mui/styled-engine': 5.13.2(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(react@18.2.0) '@mui/types': 7.2.4 - '@mui/utils': 5.13.7_react@18.2.0 + '@mui/utils': 5.13.7(react@18.2.0) clsx: 1.2.1 csstype: 3.1.2 prop-types: 15.8.1 react: 18.2.0 dev: false - /@mui/types/7.2.4: + /@mui/types@7.2.4: resolution: {integrity: sha512-LBcwa8rN84bKF+f5sDyku42w1NTxaPgPyYKODsh01U1fVstTClbUoSA96oyRBnSNyEiAVjKm6Gwx9vjR+xyqHA==} peerDependencies: '@types/react': '*' @@ -4595,7 +5287,7 @@ packages: optional: true dev: false - /@mui/utils/5.13.7_react@18.2.0: + /@mui/utils@5.13.7(react@18.2.0): resolution: {integrity: sha512-/3BLptG/q0u36eYED7Nhf4fKXmcKb6LjjT7ZMwhZIZSdSxVqDqSTmATW3a56n3KEPQUXCU9TpxAfCBQhs6brVA==} engines: {node: '>=12.0.0'} peerDependencies: @@ -4609,7 +5301,7 @@ packages: react-is: 18.2.0 dev: false - /@mui/x-date-pickers/5.0.0-beta.0_dc6gge3gqnljarlkhzo67xqsla: + /@mui/x-date-pickers@5.0.0-beta.0(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(@mui/material@5.14.0)(@mui/system@5.14.0)(date-fns@2.30.0)(react-dom@18.2.0)(react@18.2.0): resolution: {integrity: sha512-WfcYe+5j3xbGO9d+uMFem06b9q+9yIcFj0dP3PKCa1zb6m3Tbkigig6vlCuHLKLSXe1P6IQCt+BNVVbU1rfh7A==} engines: {node: '>=12.0.0'} peerDependencies: @@ -4638,30 +5330,31 @@ packages: dependencies: '@babel/runtime': 7.22.6 '@date-io/core': 2.16.0 - '@date-io/date-fns': 2.16.0_date-fns@2.30.0 + '@date-io/date-fns': 2.16.0(date-fns@2.30.0) '@date-io/dayjs': 2.16.0 '@date-io/luxon': 2.16.1 '@date-io/moment': 2.16.1 - '@emotion/react': 11.11.1_react@18.2.0 - '@emotion/styled': 11.11.0_xo5t6f4ryb2nvjgwj2cxjowrye - '@mui/material': 5.14.0_vizhjgize6w4e5tnsjmztd65da - '@mui/utils': 5.13.7_react@18.2.0 + '@emotion/react': 11.11.1(react@18.2.0) + '@emotion/styled': 11.11.0(@emotion/react@11.11.1)(react@18.2.0) + '@mui/material': 5.14.0(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(react-dom@18.2.0)(react@18.2.0) + '@mui/system': 5.14.0(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(react@18.2.0) + '@mui/utils': 5.13.7(react@18.2.0) '@types/react-transition-group': 4.4.6 clsx: 1.2.1 date-fns: 2.30.0 prop-types: 15.8.1 react: 18.2.0 - react-transition-group: 4.4.5_biqbaboplfbrettd7655fr4n2y - rifm: 0.12.1_react@18.2.0 + react-transition-group: 4.4.5(react-dom@18.2.0)(react@18.2.0) + rifm: 0.12.1(react@18.2.0) transitivePeerDependencies: - react-dom dev: false - /@next/env/12.1.5: + /@next/env@12.1.5: resolution: {integrity: sha512-+34yUJslfJi7Lyx6ELuN8nWcOzi27izfYnZIC1Dqv7kmmfiBVxgzR3BXhlvEMTKC2IRJhXVs2FkMY+buQe3k7Q==} dev: false - /@next/swc-android-arm-eabi/12.1.5: + /@next/swc-android-arm-eabi@12.1.5: resolution: {integrity: sha512-SKnGTdYcoN04Y2DvE0/Y7/MjkA+ltsmbuH/y/hR7Ob7tsj+8ZdOYuk+YvW1B8dY20nDPHP58XgDTSm2nA8BzzA==} engines: {node: '>= 10'} cpu: [arm] @@ -4670,7 +5363,7 @@ packages: dev: false optional: true - /@next/swc-android-arm64/12.1.5: + /@next/swc-android-arm64@12.1.5: resolution: {integrity: sha512-YXiqgQ/9Rxg1dXp6brXbeQM1JDx9SwUY/36JiE+36FXqYEmDYbxld9qkX6GEzkc5rbwJ+RCitargnzEtwGW0mw==} engines: {node: '>= 10'} cpu: [arm64] @@ -4679,7 +5372,7 @@ packages: dev: false optional: true - /@next/swc-darwin-arm64/12.1.5: + /@next/swc-darwin-arm64@12.1.5: resolution: {integrity: sha512-y8mhldb/WFZ6lFeowkGfi0cO/lBdiBqDk4T4LZLvCpoQp4Or/NzUN6P5NzBQZ5/b4oUHM/wQICEM+1wKA4qIVw==} engines: {node: '>= 10'} cpu: [arm64] @@ -4688,7 +5381,7 @@ packages: dev: false optional: true - /@next/swc-darwin-x64/12.1.5: + /@next/swc-darwin-x64@12.1.5: resolution: {integrity: sha512-wqJ3X7WQdTwSGi0kIDEmzw34QHISRIQ5uvC+VXmsIlCPFcMA+zM5723uh8NfuKGquDMiEMS31a83QgkuHMYbwQ==} engines: {node: '>= 10'} cpu: [x64] @@ -4697,7 +5390,7 @@ packages: dev: false optional: true - /@next/swc-linux-arm-gnueabihf/12.1.5: + /@next/swc-linux-arm-gnueabihf@12.1.5: resolution: {integrity: sha512-WnhdM5duONMvt2CncAl+9pim0wBxDS2lHoo7ub/o/i1bRbs11UTzosKzEXVaTDCUkCX2c32lIDi1WcN2ZPkcdw==} engines: {node: '>= 10'} cpu: [arm] @@ -4706,7 +5399,7 @@ packages: dev: false optional: true - /@next/swc-linux-arm64-gnu/12.1.5: + /@next/swc-linux-arm64-gnu@12.1.5: resolution: {integrity: sha512-Jq2H68yQ4bLUhR/XQnbw3LDW0GMQn355qx6rU36BthDLeGue7YV7MqNPa8GKvrpPocEMW77nWx/1yI6w6J07gw==} engines: {node: '>= 10'} cpu: [arm64] @@ -4715,7 +5408,7 @@ packages: dev: false optional: true - /@next/swc-linux-arm64-musl/12.1.5: + /@next/swc-linux-arm64-musl@12.1.5: resolution: {integrity: sha512-KgPjwdbhDqXI7ghNN8V/WAiLquc9Ebe8KBrNNEL0NQr+yd9CyKJ6KqjayVkmX+hbHzbyvbui/5wh/p3CZQ9xcQ==} engines: {node: '>= 10'} cpu: [arm64] @@ -4724,7 +5417,7 @@ packages: dev: false optional: true - /@next/swc-linux-x64-gnu/12.1.5: + /@next/swc-linux-x64-gnu@12.1.5: resolution: {integrity: sha512-O2ErUTvCJ6DkNTSr9pbu1n3tcqykqE/ebty1rwClzIYdOgpB3T2MfEPP+K7GhUR87wmN/hlihO9ch7qpVFDGKw==} engines: {node: '>= 10'} cpu: [x64] @@ -4733,7 +5426,7 @@ packages: dev: false optional: true - /@next/swc-linux-x64-musl/12.1.5: + /@next/swc-linux-x64-musl@12.1.5: resolution: {integrity: sha512-1eIlZmlO/VRjxxzUBcVosf54AFU3ltAzHi+BJA+9U/lPxCYIsT+R4uO3QksRzRjKWhVQMRjEnlXyyq5SKJm7BA==} engines: {node: '>= 10'} cpu: [x64] @@ -4742,7 +5435,7 @@ packages: dev: false optional: true - /@next/swc-win32-arm64-msvc/12.1.5: + /@next/swc-win32-arm64-msvc@12.1.5: resolution: {integrity: sha512-oromsfokbEuVb0CBLLE7R9qX3KGXucZpsojLpzUh1QJjuy1QkrPJncwr8xmWQnwgtQ6ecMWXgXPB+qtvizT9Tw==} engines: {node: '>= 10'} cpu: [arm64] @@ -4751,7 +5444,7 @@ packages: dev: false optional: true - /@next/swc-win32-ia32-msvc/12.1.5: + /@next/swc-win32-ia32-msvc@12.1.5: resolution: {integrity: sha512-a/51L5KzBpeZSW9LbekMo3I3Cwul+V+QKwbEIMA+Qwb2qrlcn1L9h3lt8cHqNTFt2y72ce6aTwDTw1lyi5oIRA==} engines: {node: '>= 10'} cpu: [ia32] @@ -4760,7 +5453,7 @@ packages: dev: false optional: true - /@next/swc-win32-x64-msvc/12.1.5: + /@next/swc-win32-x64-msvc@12.1.5: resolution: {integrity: sha512-/SoXW1Ntpmpw3AXAzfDRaQidnd8kbZ2oSni8u5z0yw6t4RwJvmdZy1eOaAADRThWKV+2oU90++LSnXJIwBRWYQ==} engines: {node: '>= 10'} cpu: [x64] @@ -4769,41 +5462,41 @@ packages: dev: false optional: true - /@nicolo-ribaudo/semver-v6/6.3.3: + /@nicolo-ribaudo/semver-v6@6.3.3: resolution: {integrity: sha512-3Yc1fUTs69MG/uZbJlLSI3JISMn2UV2rg+1D/vROUqZyh3l6iYHCs7GMp+M40ZD7yOdDbYjJcU1oTJhrc+dGKg==} hasBin: true - /@nodelib/fs.scandir/2.1.5: + /@nodelib/fs.scandir@2.1.5: resolution: {integrity: sha512-vq24Bq3ym5HEQm2NKCr3yXDwjc7vTsEThRDnkp2DK9p1uqLR+DHurm/NOTo0KG7HYHU7eppKZj3MyqYuMBf62g==} engines: {node: '>= 8'} dependencies: '@nodelib/fs.stat': 2.0.5 run-parallel: 1.2.0 - /@nodelib/fs.stat/1.1.3: + /@nodelib/fs.stat@1.1.3: resolution: {integrity: sha512-shAmDyaQC4H92APFoIaVDHCx5bStIocgvbwQyxPRrbUY20V1EYTbSDchWbuwlMG3V17cprZhA6+78JfB+3DTPw==} engines: {node: '>= 6'} dev: true - /@nodelib/fs.stat/2.0.5: + /@nodelib/fs.stat@2.0.5: resolution: {integrity: sha512-RkhPPp2zrqDAQA/2jNhnztcPAlv64XdhIp7a7454A5ovI7Bukxgt7MX7udwAu3zg1DcpPU0rz3VV1SeaqvY4+A==} engines: {node: '>= 8'} - /@nodelib/fs.walk/1.2.8: + /@nodelib/fs.walk@1.2.8: resolution: {integrity: sha512-oGB+UxlgWcgQkgwo8GcEGwemoTFt3FIO9ababBmaGwXIoBKZ+GTy0pP185beGg7Llih/NSHSV2XAs1lnznocSg==} engines: {node: '>= 8'} dependencies: '@nodelib/fs.scandir': 2.1.5 fastq: 1.15.0 - /@npmcli/fs/1.1.1: + /@npmcli/fs@1.1.1: resolution: {integrity: sha512-8KG5RD0GVP4ydEzRn/I4BNDuxDtqVbOdm8675T49OIG/NGhaK0pjPX7ZcDlvKYbA+ulvVK3ztfcF4uBdOxuJbQ==} dependencies: '@gar/promisify': 1.1.3 semver: 7.5.4 dev: true - /@npmcli/move-file/1.1.2: + /@npmcli/move-file@1.1.2: resolution: {integrity: sha512-1SUf/Cg2GzGDyaf15aR9St9TWlb+XvbZXWpDx8YKs7MLzMH/BCeopv+y9vzrzgkfykCGuWOlSu3mZhj2+FQcrg==} engines: {node: '>=10'} deprecated: This functionality has been moved to @npmcli/fs @@ -4812,18 +5505,18 @@ packages: rimraf: 3.0.2 dev: true - /@open-draft/until/1.0.3: + /@open-draft/until@1.0.3: resolution: {integrity: sha512-Aq58f5HiWdyDlFffbbSjAlv596h/cOnt2DO1w3DOC7OJ5EHs0hd/nycJfiu9RJbT6Yk6F1knnRRXNSpxoIVZ9Q==} dev: true - /@pkgjs/parseargs/0.11.0: + /@pkgjs/parseargs@0.11.0: resolution: {integrity: sha512-+1VkjdD0QBLPodGrJUeqarH8VAIvQODIbwh9XpP5Syisf7YoQgsJKPNFoqqLQlu+VQ/tVSshMR6loPMn8U+dPg==} engines: {node: '>=14'} requiresBuild: true dev: true optional: true - /@playwright/test/1.36.0: + /@playwright/test@1.36.0: resolution: {integrity: sha512-yN+fvMYtiyLFDCQos+lWzoX4XW3DNuaxjBu68G0lkgLgC6BP+m/iTxJQoSicz/x2G5EsrqlZTqTIP9sTgLQerg==} engines: {node: '>=16'} hasBin: true @@ -4834,7 +5527,7 @@ packages: fsevents: 2.3.2 dev: true - /@pmmmwh/react-refresh-webpack-plugin/0.5.10_3s7aftcw26g2vhqubpxl7hhzpa: + /@pmmmwh/react-refresh-webpack-plugin@0.5.10(react-refresh@0.11.0)(webpack@5.88.1): resolution: {integrity: sha512-j0Ya0hCFZPd4x40qLzbhGsh9TMtdb+CJQiso+WxLOPNasohq9cc5SNUcwsZaRH6++Xh91Xkm/xHCkuIiIu0LUA==} engines: {node: '>= 10.13'} peerDependencies: @@ -4870,17 +5563,17 @@ packages: react-refresh: 0.11.0 schema-utils: 3.3.0 source-map: 0.7.4 - webpack: 5.88.1 + webpack: 5.88.1(esbuild@0.18.11) dev: true - /@polka/url/1.0.0-next.21: + /@polka/url@1.0.0-next.21: resolution: {integrity: sha512-a5Sab1C4/icpTZVzZc5Ghpz88yQtGOyNqYXcZgOssB2uuAr+wF/MvN6bgtW32q7HHrvBki+BsZ0OuNv6EV3K9g==} - /@popperjs/core/2.11.8: + /@popperjs/core@2.11.8: resolution: {integrity: sha512-P1st0aksCrn9sGZhp8GMYwBnQsbvAWsZAX44oXNNvLHGqAOcoVxmjZiohstwQ7SqKnbR47akdNi+uleWD8+g6A==} dev: false - /@puppeteer/browsers/1.3.0: + /@puppeteer/browsers@1.3.0(typescript@5.1.6): resolution: {integrity: sha512-an3QdbNPkuU6qpxpbssxAbjRLJcF+eP4L8UqIY3+6n0sbaVxw5pz7PiCLy9g32XEZuoamUlV5ZQPnA6FxvkIHA==} engines: {node: '>=16.0.0'} hasBin: true @@ -4890,25 +5583,26 @@ packages: typescript: optional: true dependencies: - debug: 4.3.4 - extract-zip: 2.0.1 + debug: 4.3.4(supports-color@8.1.1) + extract-zip: 2.0.1(supports-color@8.1.1) http-proxy-agent: 5.0.0 https-proxy-agent: 5.0.1 progress: 2.0.3 proxy-from-env: 1.1.0 tar-fs: 2.1.1 + typescript: 5.1.6 unbzip2-stream: 1.4.3 yargs: 17.7.1 transitivePeerDependencies: - supports-color dev: true - /@remix-run/router/1.7.1: + /@remix-run/router@1.7.1: resolution: {integrity: sha512-bgVQM4ZJ2u2CM8k1ey70o1ePFXsEzYVZoWghh6WjM8p59jQ7HxzbHW4SbnWFG7V9ig9chLawQxDTZ3xzOF8MkQ==} engines: {node: '>=14'} dev: false - /@rollup/plugin-alias/5.0.0_rollup@3.26.2: + /@rollup/plugin-alias@5.0.0(rollup@3.26.2): resolution: {integrity: sha512-l9hY5chSCjuFRPsnRm16twWBiSApl2uYFLsepQYwtBuAxNMQ/1dJqADld40P0Jkqm65GRTLy/AC6hnpVebtLsA==} engines: {node: '>=14.0.0'} peerDependencies: @@ -4921,7 +5615,7 @@ packages: slash: 4.0.0 dev: true - /@rollup/plugin-babel/5.3.1_dk2tutsrvslwzit5bccevt2cya: + /@rollup/plugin-babel@5.3.1(@babel/core@7.22.8)(rollup@2.79.1): resolution: {integrity: sha512-WFfdLWU/xVWKeRQnKmIAQULUI7Il0gZnBIH/ZFO069wYIfPu+8zrfp/KMW0atmELoRDq8FbiP3VCss9MhCut7Q==} engines: {node: '>= 10.0.0'} peerDependencies: @@ -4934,11 +5628,11 @@ packages: dependencies: '@babel/core': 7.22.8 '@babel/helper-module-imports': 7.22.5 - '@rollup/pluginutils': 3.1.0_rollup@2.79.1 + '@rollup/pluginutils': 3.1.0(rollup@2.79.1) rollup: 2.79.1 dev: true - /@rollup/plugin-commonjs/25.0.2_rollup@3.26.2: + /@rollup/plugin-commonjs@25.0.2(rollup@3.26.2): resolution: {integrity: sha512-NGTwaJxIO0klMs+WSFFtBP7b9TdTJ3K76HZkewT8/+yHzMiUGVQgaPtLQxNVYIgT5F7lxkEyVID+yS3K7bhCow==} engines: {node: '>=14.0.0'} peerDependencies: @@ -4947,7 +5641,7 @@ packages: rollup: optional: true dependencies: - '@rollup/pluginutils': 5.0.2_rollup@3.26.2 + '@rollup/pluginutils': 5.0.2(rollup@3.26.2) commondir: 1.0.1 estree-walker: 2.0.2 glob: 8.1.0 @@ -4956,7 +5650,7 @@ packages: rollup: 3.26.2 dev: true - /@rollup/plugin-graphql/1.1.0_graphql@16.7.1: + /@rollup/plugin-graphql@1.1.0(graphql@16.7.1)(rollup@2.79.1): resolution: {integrity: sha512-X+H6oFlprDlnO3D0UiEytdW97AMphPXO0C7KunS7i/rBXIGQRQVDU5WKTXnBu2tfyYbjCTtfhXMSGI0i885PNg==} peerDependencies: graphql: '>=0.9.0' @@ -4964,10 +5658,11 @@ packages: dependencies: '@rollup/pluginutils': 4.2.1 graphql: 16.7.1 - graphql-tag: 2.12.6_graphql@16.7.1 + graphql-tag: 2.12.6(graphql@16.7.1) + rollup: 2.79.1 dev: false - /@rollup/plugin-json/6.0.0_rollup@3.26.2: + /@rollup/plugin-json@6.0.0(rollup@3.26.2): resolution: {integrity: sha512-i/4C5Jrdr1XUarRhVu27EEwjt4GObltD7c+MkCIpO2QIbojw8MUs+CCTqOphQi3Qtg1FLmYt+l+6YeoIf51J7w==} engines: {node: '>=14.0.0'} peerDependencies: @@ -4976,17 +5671,17 @@ packages: rollup: optional: true dependencies: - '@rollup/pluginutils': 5.0.2_rollup@3.26.2 + '@rollup/pluginutils': 5.0.2(rollup@3.26.2) rollup: 3.26.2 dev: true - /@rollup/plugin-node-resolve/11.2.1_rollup@2.79.1: + /@rollup/plugin-node-resolve@11.2.1(rollup@2.79.1): resolution: {integrity: sha512-yc2n43jcqVyGE2sqV5/YCmocy9ArjVAP/BeXyTtADTBBX6V0e5UMqwO8CdQ0kzjb6zu5P1qMzsScCMRvE9OlVg==} engines: {node: '>= 10.0.0'} peerDependencies: rollup: ^1.20.0||^2.0.0 dependencies: - '@rollup/pluginutils': 3.1.0_rollup@2.79.1 + '@rollup/pluginutils': 3.1.0(rollup@2.79.1) '@types/resolve': 1.17.1 builtin-modules: 3.3.0 deepmerge: 4.3.1 @@ -4995,7 +5690,7 @@ packages: rollup: 2.79.1 dev: true - /@rollup/plugin-node-resolve/15.1.0_rollup@3.26.2: + /@rollup/plugin-node-resolve@15.1.0(rollup@3.26.2): resolution: {integrity: sha512-xeZHCgsiZ9pzYVgAo9580eCGqwh/XCEUM9q6iQfGNocjgkufHAqC3exA+45URvhiYV8sBF9RlBai650eNs7AsA==} engines: {node: '>=14.0.0'} peerDependencies: @@ -5004,7 +5699,7 @@ packages: rollup: optional: true dependencies: - '@rollup/pluginutils': 5.0.2_rollup@3.26.2 + '@rollup/pluginutils': 5.0.2(rollup@3.26.2) '@types/resolve': 1.20.2 deepmerge: 4.3.1 is-builtin-module: 3.2.1 @@ -5013,17 +5708,17 @@ packages: rollup: 3.26.2 dev: true - /@rollup/plugin-replace/2.4.2_rollup@2.79.1: + /@rollup/plugin-replace@2.4.2(rollup@2.79.1): resolution: {integrity: sha512-IGcu+cydlUMZ5En85jxHH4qj2hta/11BHq95iHEyb2sbgiN0eCdzvUcHw5gt9pBL5lTi4JDYJ1acCoMGpTvEZg==} peerDependencies: rollup: ^1.20.0 || ^2.0.0 dependencies: - '@rollup/pluginutils': 3.1.0_rollup@2.79.1 + '@rollup/pluginutils': 3.1.0(rollup@2.79.1) magic-string: 0.25.9 rollup: 2.79.1 dev: true - /@rollup/pluginutils/3.1.0_rollup@2.79.1: + /@rollup/pluginutils@3.1.0(rollup@2.79.1): resolution: {integrity: sha512-GksZ6pr6TpIjHm8h9lSQ8pi8BE9VeubNT0OMJ3B5uZJ8pz73NPiqOtCog/x2/QzM1ENChPKxMDhiQuRHsqc+lg==} engines: {node: '>= 8.0.0'} peerDependencies: @@ -5035,7 +5730,7 @@ packages: rollup: 2.79.1 dev: true - /@rollup/pluginutils/3.1.0_rollup@3.26.2: + /@rollup/pluginutils@3.1.0(rollup@3.26.2): resolution: {integrity: sha512-GksZ6pr6TpIjHm8h9lSQ8pi8BE9VeubNT0OMJ3B5uZJ8pz73NPiqOtCog/x2/QzM1ENChPKxMDhiQuRHsqc+lg==} engines: {node: '>= 8.0.0'} peerDependencies: @@ -5047,14 +5742,14 @@ packages: rollup: 3.26.2 dev: false - /@rollup/pluginutils/4.2.1: + /@rollup/pluginutils@4.2.1: resolution: {integrity: sha512-iKnFXr7NkdZAIHiIWE+BX5ULi/ucVFYWD6TbAV+rZctiRTY2PL6tsIKhoIOaoskiWAkgu+VsbXgUVDNLHf+InQ==} engines: {node: '>= 8.0.0'} dependencies: estree-walker: 2.0.2 picomatch: 2.3.1 - /@rollup/pluginutils/5.0.2: + /@rollup/pluginutils@5.0.2(rollup@2.79.1): resolution: {integrity: sha512-pTd9rIsP92h+B6wWwFbW8RkZv4hiR/xKsqre4SIuAOaOEQRxi0lqLke9k2/7WegC85GgUs9pjmOjCUi3In4vwA==} engines: {node: '>=14.0.0'} peerDependencies: @@ -5066,9 +5761,10 @@ packages: '@types/estree': 1.0.1 estree-walker: 2.0.2 picomatch: 2.3.1 + rollup: 2.79.1 dev: true - /@rollup/pluginutils/5.0.2_rollup@3.26.2: + /@rollup/pluginutils@5.0.2(rollup@3.26.2): resolution: {integrity: sha512-pTd9rIsP92h+B6wWwFbW8RkZv4hiR/xKsqre4SIuAOaOEQRxi0lqLke9k2/7WegC85GgUs9pjmOjCUi3In4vwA==} engines: {node: '>=14.0.0'} peerDependencies: @@ -5083,27 +5779,39 @@ packages: rollup: 3.26.2 dev: true - /@sinclair/typebox/0.27.8: + /@sinclair/typebox@0.27.8: resolution: {integrity: sha512-+Fj43pSMwJs4KRrH/938Uf+uAELIgVBmQzg/q1YG10djyfA3TnrU8N8XzqCh/okZdszqBQTZf96idMfE5lnwTA==} - /@sindresorhus/is/5.4.1: + /@sindresorhus/is@5.4.1: resolution: {integrity: sha512-axlrvsHlHlFmKKMEg4VyvMzFr93JWJj4eIfXY1STVuO2fsImCa7ncaiG5gC8HKOX590AW5RtRsC41/B+OfrSqw==} engines: {node: '>=14.16'} dev: true - /@sinonjs/commons/3.0.0: + /@sinonjs/commons@1.8.6: + resolution: {integrity: sha512-Ky+XkAkqPZSm3NLBeUng77EBQl3cmeJhITaGHdYH8kjVB+aun3S4XBRti2zt17mtt0mIUDiNxYeoJm6drVvBJQ==} + dependencies: + type-detect: 4.0.8 + dev: true + + /@sinonjs/commons@3.0.0: resolution: {integrity: sha512-jXBtWAF4vmdNmZgD5FoKsVLv3rPgDnLgPbU84LIJ3otV44vJlDRokVng5v8NFJdCf/da9legHcKaRuZs4L7faA==} dependencies: type-detect: 4.0.8 dev: true - /@sinonjs/fake-timers/11.0.0: + /@sinonjs/fake-timers@11.0.0: resolution: {integrity: sha512-bqiI/5ur6ZOozG06BeJjbplIqHY/KftV1zaewbZHORH902GrHURKwl7H1G/4OC5EaxDYQJlrD0OLJ1XD6x01dQ==} dependencies: '@sinonjs/commons': 3.0.0 dev: true - /@storybook/addon-actions/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + /@sinonjs/fake-timers@8.1.0: + resolution: {integrity: sha512-OAPJUAtgeINhh/TAlUID4QTs53Njm7xzddaVlEs/SXwgtiD1tW22zAB/W1wdqfrpmikgaWQ9Fw6Ws+hsiRm5Vg==} + dependencies: + '@sinonjs/commons': 1.8.6 + dev: true + + /@storybook/addon-actions@6.5.16(react-dom@17.0.2)(react@17.0.2): resolution: {integrity: sha512-aADjilFmuD6TNGz2CRPSupnyiA/IGkPJHDBTqMpsDXTUr8xnuD122xkIhg6UxmCM2y1c+ncwYXy3WPK2xXK57g==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -5114,13 +5822,13 @@ packages: react-dom: optional: true dependencies: - '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/api': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/client-logger': 6.5.16 - '@storybook/components': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/components': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/theming': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/theming': 6.5.16(react-dom@17.0.2)(react@17.0.2) core-js: 3.31.1 fast-deep-equal: 3.1.3 global: 4.4.0 @@ -5128,8 +5836,8 @@ packages: polished: 4.2.2 prop-types: 15.8.1 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 - react-inspector: 5.1.1_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) + react-inspector: 5.1.1(react@17.0.2) regenerator-runtime: 0.13.11 telejson: 6.0.8 ts-dedent: 2.2.0 @@ -5137,7 +5845,7 @@ packages: uuid-browser: 3.1.0 dev: true - /@storybook/addon-backgrounds/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + /@storybook/addon-backgrounds@6.5.16(react-dom@17.0.2)(react@17.0.2): resolution: {integrity: sha512-t7qooZ892BruhilFmzYPbysFwpULt/q4zYXNSmKVbAYta8UVvitjcU4F18p8FpWd9WvhiTr0SDlyhNZuzvDfug==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -5148,24 +5856,24 @@ packages: react-dom: optional: true dependencies: - '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/api': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/client-logger': 6.5.16 - '@storybook/components': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/components': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/theming': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/theming': 6.5.16(react-dom@17.0.2)(react@17.0.2) core-js: 3.31.1 global: 4.4.0 memoizerific: 1.11.3 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 ts-dedent: 2.2.0 util-deprecate: 1.0.2 dev: true - /@storybook/addon-controls/6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy: + /@storybook/addon-controls@6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5): resolution: {integrity: sha512-kShSGjq1MjmmyL3l8i+uPz6yddtf82mzys0l82VKtcuyjrr5944wYFJ5NTXMfZxrO/U6FeFsfuFZE/k6ex3EMg==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -5176,19 +5884,19 @@ packages: react-dom: optional: true dependencies: - '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/api': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/client-logger': 6.5.16 - '@storybook/components': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/core-common': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy + '@storybook/components': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/core-common': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) '@storybook/csf': 0.0.2--canary.4566f4d.1 '@storybook/node-logger': 6.5.16 - '@storybook/store': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/theming': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/store': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/theming': 6.5.16(react-dom@17.0.2)(react@17.0.2) core-js: 3.31.1 lodash: 4.17.21 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) ts-dedent: 2.2.0 transitivePeerDependencies: - eslint @@ -5199,7 +5907,7 @@ packages: - webpack-command dev: true - /@storybook/addon-docs/6.5.16_7i6vyke6ny6b2xsni3leqxtq5y: + /@storybook/addon-docs@6.5.16(@babel/core@7.22.8)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5)(webpack@5.88.1): resolution: {integrity: sha512-QM9WDZG9P02UvbzLu947a8ZngOrQeAKAT8jCibQFM/+RJ39xBlfm8rm+cQy3dm94wgtjmVkA3mKGOV/yrrsddg==} peerDependencies: '@storybook/mdx2-csf': ^0.0.3 @@ -5213,31 +5921,31 @@ packages: react-dom: optional: true dependencies: - '@babel/plugin-transform-react-jsx': 7.22.5_@babel+core@7.22.8 - '@babel/preset-env': 7.22.7_@babel+core@7.22.8 + '@babel/plugin-transform-react-jsx': 7.22.5(@babel/core@7.22.8) + '@babel/preset-env': 7.22.7(@babel/core@7.22.8) '@jest/transform': 26.6.2 - '@mdx-js/react': 1.6.22_react@17.0.2 - '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/components': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/core-common': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy + '@mdx-js/react': 1.6.22(react@17.0.2) + '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/api': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/components': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/core-common': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/docs-tools': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/mdx1-csf': 0.0.1_@babel+core@7.22.8 + '@storybook/docs-tools': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/mdx1-csf': 0.0.1(@babel/core@7.22.8) '@storybook/node-logger': 6.5.16 '@storybook/postinstall': 6.5.16 - '@storybook/preview-web': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/source-loader': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/store': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/theming': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - babel-loader: 8.3.0_@babel+core@7.22.8 + '@storybook/preview-web': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/source-loader': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/store': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/theming': 6.5.16(react-dom@17.0.2)(react@17.0.2) + babel-loader: 8.3.0(@babel/core@7.22.8)(webpack@5.88.1) core-js: 3.31.1 fast-deep-equal: 3.1.3 global: 4.4.0 lodash: 4.17.21 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 remark-external-links: 8.0.0 remark-slug: 6.1.0 @@ -5254,7 +5962,7 @@ packages: - webpack-command dev: true - /@storybook/addon-essentials/6.5.16_7i6vyke6ny6b2xsni3leqxtq5y: + /@storybook/addon-essentials@6.5.16(@babel/core@7.22.8)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5)(webpack@5.88.1): resolution: {integrity: sha512-TeoMr6tEit4Pe91GH6f8g/oar1P4M0JL9S6oMcFxxrhhtOGO7XkWD5EnfyCx272Ok2VYfE58FNBTGPNBVIqYKQ==} peerDependencies: '@babel/core': ^7.9.6 @@ -5312,23 +6020,24 @@ packages: optional: true dependencies: '@babel/core': 7.22.8 - '@storybook/addon-actions': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/addon-backgrounds': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/addon-controls': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy - '@storybook/addon-docs': 6.5.16_7i6vyke6ny6b2xsni3leqxtq5y - '@storybook/addon-measure': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/addon-outline': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/addon-toolbars': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/addon-viewport': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/core-common': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy + '@storybook/addon-actions': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/addon-backgrounds': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/addon-controls': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) + '@storybook/addon-docs': 6.5.16(@babel/core@7.22.8)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5)(webpack@5.88.1) + '@storybook/addon-measure': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/addon-outline': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/addon-toolbars': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/addon-viewport': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/api': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/core-common': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) '@storybook/node-logger': 6.5.16 core-js: 3.31.1 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 ts-dedent: 2.2.0 + webpack: 5.88.1(esbuild@0.18.11) transitivePeerDependencies: - '@storybook/mdx2-csf' - eslint @@ -5339,7 +6048,7 @@ packages: - webpack-command dev: true - /@storybook/addon-links/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + /@storybook/addon-links@6.5.16(react-dom@17.0.2)(react@17.0.2): resolution: {integrity: sha512-P/mmqK57NGXnR0i3d/T5B0rIt0Lg8Yq+qionRr3LK3AwG/4yGnYt4GNomLEknn/eEwABYq1Q/Z1aOpgIhNdq5A==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -5350,23 +6059,23 @@ packages: react-dom: optional: true dependencies: - '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/client-logger': 6.5.16 '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/router': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/router': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@types/qs': 6.9.7 core-js: 3.31.1 global: 4.4.0 prop-types: 15.8.1 qs: 6.11.2 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 ts-dedent: 2.2.0 dev: true - /@storybook/addon-measure/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + /@storybook/addon-measure@6.5.16(react-dom@17.0.2)(react@17.0.2): resolution: {integrity: sha512-DMwnXkmM2L6POTh4KaOWvOAtQ2p9Tr1UUNxz6VXiN5cKFohpCs6x0txdLU5WN8eWIq0VFsO7u5ZX34CGCc6gCg==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -5377,19 +6086,19 @@ packages: react-dom: optional: true dependencies: - '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/api': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/client-logger': 6.5.16 - '@storybook/components': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/components': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 core-js: 3.31.1 global: 4.4.0 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) dev: true - /@storybook/addon-outline/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + /@storybook/addon-outline@6.5.16(react-dom@17.0.2)(react@17.0.2): resolution: {integrity: sha512-0du96nha4qltexO0Xq1xB7LeRSbqjC9XqtZLflXG7/X3ABoPD2cXgOV97eeaXUodIyb2qYBbHUfftBeA75x0+w==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -5400,21 +6109,21 @@ packages: react-dom: optional: true dependencies: - '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/api': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/client-logger': 6.5.16 - '@storybook/components': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/components': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 core-js: 3.31.1 global: 4.4.0 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 ts-dedent: 2.2.0 dev: true - /@storybook/addon-toolbars/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + /@storybook/addon-toolbars@6.5.16(react-dom@17.0.2)(react@17.0.2): resolution: {integrity: sha512-y3PuUKiwOWrAvqx1YdUvArg0UaAwmboXFeR2bkrowk1xcT+xnRO3rML4npFeUl26OQ1FzwxX/cw6nknREBBLEA==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -5425,18 +6134,18 @@ packages: react-dom: optional: true dependencies: - '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/api': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/client-logger': 6.5.16 - '@storybook/components': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/theming': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/components': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/theming': 6.5.16(react-dom@17.0.2)(react@17.0.2) core-js: 3.31.1 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 dev: true - /@storybook/addon-viewport/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + /@storybook/addon-viewport@6.5.16(react-dom@17.0.2)(react@17.0.2): resolution: {integrity: sha512-1Vyqf1U6Qng6TXlf4SdqUKyizlw1Wn6+qW8YeA2q1lbkJqn3UlnHXIp8Q0t/5q1dK5BFtREox3+jkGwbJrzkmA==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -5447,43 +6156,43 @@ packages: react-dom: optional: true dependencies: - '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/api': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/client-logger': 6.5.16 - '@storybook/components': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/components': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/core-events': 6.5.16 - '@storybook/theming': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/theming': 6.5.16(react-dom@17.0.2)(react@17.0.2) core-js: 3.31.1 global: 4.4.0 memoizerific: 1.11.3 prop-types: 15.8.1 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 dev: true - /@storybook/addons/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + /@storybook/addons@6.5.16(react-dom@17.0.2)(react@17.0.2): resolution: {integrity: sha512-p3DqQi+8QRL5k7jXhXmJZLsE/GqHqyY6PcoA1oNTJr0try48uhTGUOYkgzmqtDaa/qPFO5LP+xCPzZXckGtquQ==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/api': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/channels': 6.5.16 '@storybook/client-logger': 6.5.16 '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/router': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/theming': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/router': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/theming': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@types/webpack-env': 1.18.1 core-js: 3.31.1 global: 4.4.0 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 dev: true - /@storybook/api/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + /@storybook/api@6.5.16(react-dom@17.0.2)(react@17.0.2): resolution: {integrity: sha512-HOsuT8iomqeTMQJrRx5U8nsC7lJTwRr1DhdD0SzlqL4c80S/7uuCy4IZvOt4sYQjOzW5fOo/kamcoBXyLproTA==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -5493,16 +6202,16 @@ packages: '@storybook/client-logger': 6.5.16 '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/router': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/router': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/semver': 7.3.2 - '@storybook/theming': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/theming': 6.5.16(react-dom@17.0.2)(react@17.0.2) core-js: 3.31.1 fast-deep-equal: 3.1.3 global: 4.4.0 lodash: 4.17.21 memoizerific: 1.11.3 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 store2: 2.14.2 telejson: 6.0.8 @@ -5510,39 +6219,41 @@ packages: util-deprecate: 1.0.2 dev: true - /@storybook/builder-vite/0.1.41_qr3s4pqg2febfejexmksv4rlaa: + /@storybook/builder-vite@0.1.41(@babel/core@7.22.8)(@storybook/core-common@6.5.16)(@storybook/node-logger@6.5.16)(@storybook/source-loader@6.5.16)(react@17.0.2)(typescript@4.9.5)(vite@4.4.3): resolution: {integrity: sha512-h/7AgEUfSuVexTD6LuJ6BCNu+FSo/+IKYBQ1O3TyF2BEgcob5/BGrx9QcwM0LJCF44L1zNKaxkKpCZs9p+LRRA==} peerDependencies: '@storybook/core-common': '>=6.4.3 || >=6.5.0-alpha.0' '@storybook/mdx2-csf': ^0.0.3 '@storybook/node-logger': '>=6.4.3 || >=6.5.0-alpha.0' + '@storybook/source-loader': '>=6.4.3 || >=6.5.0-alpha.0' vite: '>=2.6.7' peerDependenciesMeta: '@storybook/mdx2-csf': optional: true dependencies: - '@joshwooding/vite-plugin-react-docgen-typescript': 0.0.4_ilntetca2wlekmurdwyomywvbi - '@storybook/mdx1-csf': 0.0.4_wumd2qseuobkz2wudw2hqnarr4 - '@storybook/source-loader': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@joshwooding/vite-plugin-react-docgen-typescript': 0.0.4(typescript@4.9.5)(vite@4.4.3) + '@storybook/core-common': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) + '@storybook/mdx1-csf': 0.0.4(@babel/core@7.22.8)(react@17.0.2) + '@storybook/node-logger': 6.5.16 + '@storybook/source-loader': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@vitejs/plugin-react': 1.3.2 ast-types: 0.14.2 es-module-lexer: 0.9.3 glob: 7.2.3 - glob-promise: 4.2.2_glob@7.2.3 + glob-promise: 4.2.2(glob@7.2.3) magic-string: 0.26.7 react-docgen: 6.0.1 slash: 3.0.0 sveltedoc-parser: 4.2.1 - vite: 4.4.3 + vite: 4.4.3(@types/node@18.16.19) transitivePeerDependencies: - '@babel/core' - react - - react-dom - supports-color - typescript dev: true - /@storybook/builder-webpack4/6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy: + /@storybook/builder-webpack4@6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5): resolution: {integrity: sha512-YqDIrVNsUo8r9xc6AxsYDLxVYtMgl5Bxk+8/h1adsOko+jAFhdg6hOcAVxEmoSI0TMASOOVMFlT2hr23ppN2rQ==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -5553,53 +6264,53 @@ packages: optional: true dependencies: '@babel/core': 7.22.8 - '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/api': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/channel-postmessage': 6.5.16 '@storybook/channels': 6.5.16 - '@storybook/client-api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/client-api': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/client-logger': 6.5.16 - '@storybook/components': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/core-common': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy + '@storybook/components': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/core-common': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) '@storybook/core-events': 6.5.16 '@storybook/node-logger': 6.5.16 - '@storybook/preview-web': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/router': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/preview-web': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/router': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/semver': 7.3.2 - '@storybook/store': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/theming': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/ui': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/store': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/theming': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/ui': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@types/node': 16.18.38 '@types/webpack': 4.41.33 autoprefixer: 9.8.8 - babel-loader: 8.3.0_n6tf3ekqtzvxjokzr6jiserpma + babel-loader: 8.3.0(@babel/core@7.22.8)(webpack@4.46.0) case-sensitive-paths-webpack-plugin: 2.4.0 core-js: 3.31.1 - css-loader: 3.6.0_webpack@4.46.0 - file-loader: 6.2.0_webpack@4.46.0 + css-loader: 3.6.0(webpack@4.46.0) + file-loader: 6.2.0(webpack@4.46.0) find-up: 5.0.0 - fork-ts-checker-webpack-plugin: 4.1.6_evijigonbo4skk2vlqtwtdqibu + fork-ts-checker-webpack-plugin: 4.1.6(eslint@8.4.1)(typescript@4.9.5)(webpack@4.46.0) glob: 7.2.3 - glob-promise: 3.4.0_glob@7.2.3 + glob-promise: 3.4.0(glob@7.2.3) global: 4.4.0 - html-webpack-plugin: 4.5.2_webpack@4.46.0 - pnp-webpack-plugin: 1.6.4_typescript@4.9.5 + html-webpack-plugin: 4.5.2(webpack@4.46.0) + pnp-webpack-plugin: 1.6.4(typescript@4.9.5) postcss: 7.0.39 postcss-flexbugs-fixes: 4.2.1 - postcss-loader: 4.3.0_gzaxsinx64nntyd3vmdqwl7coe - raw-loader: 4.0.2_webpack@4.46.0 + postcss-loader: 4.3.0(postcss@7.0.39)(webpack@4.46.0) + raw-loader: 4.0.2(webpack@4.46.0) react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) stable: 0.1.8 - style-loader: 1.3.0_webpack@4.46.0 - terser-webpack-plugin: 4.2.3_webpack@4.46.0 + style-loader: 1.3.0(webpack@4.46.0) + terser-webpack-plugin: 4.2.3(webpack@4.46.0) ts-dedent: 2.2.0 typescript: 4.9.5 - url-loader: 4.1.1_lit45vopotvaqup7lrvlnvtxwy + url-loader: 4.1.1(file-loader@6.2.0)(webpack@4.46.0) util-deprecate: 1.0.2 webpack: 4.46.0 - webpack-dev-middleware: 3.7.3_webpack@4.46.0 - webpack-filter-warnings-plugin: 1.2.1_webpack@4.46.0 + webpack-dev-middleware: 3.7.3(webpack@4.46.0) + webpack-filter-warnings-plugin: 1.2.1(webpack@4.46.0) webpack-hot-middleware: 2.25.4 webpack-virtual-modules: 0.2.2 transitivePeerDependencies: @@ -5611,7 +6322,7 @@ packages: - webpack-command dev: true - /@storybook/channel-postmessage/6.5.16: + /@storybook/channel-postmessage@6.5.16: resolution: {integrity: sha512-fZZSN29dsUArWOx7e7lTdMA9+7zijVwCwbvi2Fo4fqhRLh1DsTb/VXfz1FKMCWAjNlcX7QQvV25tnxbqsD6lyw==} dependencies: '@storybook/channels': 6.5.16 @@ -5623,7 +6334,7 @@ packages: telejson: 6.0.8 dev: true - /@storybook/channel-postmessage/7.0.26: + /@storybook/channel-postmessage@7.0.26: resolution: {integrity: sha512-ZvFLr/tUD9dWIjQtIn1JXHjqrbOP/uEEOqzwpKSVj0Cl4Vgc12s8hecbzBufkOF7fwLsFvfieSi7ENOmjoncdQ==} dependencies: '@storybook/channels': 7.0.26 @@ -5634,7 +6345,7 @@ packages: telejson: 7.1.0 dev: true - /@storybook/channel-websocket/6.5.16: + /@storybook/channel-websocket@6.5.16: resolution: {integrity: sha512-wJg2lpBjmRC2GJFzmhB9kxlh109VE58r/0WhFtLbwKvPqsvGf82xkBEl6BtBCvIQ4stzYnj/XijjA8qSi2zpOg==} dependencies: '@storybook/channels': 6.5.16 @@ -5644,7 +6355,7 @@ packages: telejson: 6.0.8 dev: true - /@storybook/channels/6.5.16: + /@storybook/channels@6.5.16: resolution: {integrity: sha512-VylzaWQZaMozEwZPJdyJoz+0jpDa8GRyaqu9TGG6QGv+KU5POoZaGLDkRE7TzWkyyP0KQLo80K99MssZCpgSeg==} dependencies: core-js: 3.31.1 @@ -5652,23 +6363,23 @@ packages: util-deprecate: 1.0.2 dev: true - /@storybook/channels/7.0.26: + /@storybook/channels@7.0.26: resolution: {integrity: sha512-Br3XILhrtuL5Sdp91I04kKjJzSqU/N8gGL6B6nIfnuaHUvGMDuMCHAB+g7aoiyH5dnpDZ6yBVGNwtYAyJA+0Og==} dev: true - /@storybook/client-api/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + /@storybook/client-api@6.5.16(react-dom@17.0.2)(react@17.0.2): resolution: {integrity: sha512-i3UwkzzUFw8I+E6fOcgB5sc4oU2fhvaKnqC1mpd9IYGJ9JN9MnGIaVl3Ko28DtFItu/QabC9JsLIJVripFLktQ==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/channel-postmessage': 6.5.16 '@storybook/channels': 6.5.16 '@storybook/client-logger': 6.5.16 '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/store': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/store': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@types/qs': 6.9.7 '@types/webpack-env': 1.18.1 core-js: 3.31.1 @@ -5678,7 +6389,7 @@ packages: memoizerific: 1.11.3 qs: 6.11.2 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 store2: 2.14.2 synchronous-promise: 2.0.17 @@ -5686,20 +6397,20 @@ packages: util-deprecate: 1.0.2 dev: true - /@storybook/client-logger/6.5.16: + /@storybook/client-logger@6.5.16: resolution: {integrity: sha512-pxcNaCj3ItDdicPTXTtmYJE3YC1SjxFrBmHcyrN+nffeNyiMuViJdOOZzzzucTUG0wcOOX8jaSyak+nnHg5H1Q==} dependencies: core-js: 3.31.1 global: 4.4.0 dev: true - /@storybook/client-logger/7.0.26: + /@storybook/client-logger@7.0.26: resolution: {integrity: sha512-OMVLbgceoeuM8sWOfTX/9a4zCrH78G32hg7x8yXLZnRJ9OLaHJHzUM0Onc4MLudqVUdaKH0c8ejpBXUyIr1rJQ==} dependencies: '@storybook/global': 5.0.0 dev: true - /@storybook/components/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + /@storybook/components@6.5.16(react-dom@17.0.2)(react@17.0.2): resolution: {integrity: sha512-LzBOFJKITLtDcbW9jXl0/PaG+4xAz25PK8JxPZpIALbmOpYWOAPcO6V9C2heX6e6NgWFMUxjplkULEk9RCQMNA==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -5707,17 +6418,17 @@ packages: dependencies: '@storybook/client-logger': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/theming': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/theming': 6.5.16(react-dom@17.0.2)(react@17.0.2) core-js: 3.31.1 memoizerific: 1.11.3 qs: 6.11.2 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 util-deprecate: 1.0.2 dev: true - /@storybook/core-client/6.5.16_kdhf477f3bq3v2mc53jwn63t6u: + /@storybook/core-client@6.5.16(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5)(webpack@4.46.0): resolution: {integrity: sha512-14IRaDrVtKrQ+gNWC0wPwkCNfkZOKghYV/swCUnQX3rP99defsZK8Hc7xHIYoAiOP5+sc3sweRAxgmFiJeQ1Ig==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -5728,16 +6439,16 @@ packages: typescript: optional: true dependencies: - '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/channel-postmessage': 6.5.16 '@storybook/channel-websocket': 6.5.16 - '@storybook/client-api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/client-api': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/client-logger': 6.5.16 '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/preview-web': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/store': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/ui': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/preview-web': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/store': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/ui': 6.5.16(react-dom@17.0.2)(react@17.0.2) airbnb-js-shims: 2.2.1 ansi-to-html: 0.6.15 core-js: 3.31.1 @@ -5745,16 +6456,16 @@ packages: lodash: 4.17.21 qs: 6.11.2 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 ts-dedent: 2.2.0 typescript: 4.9.5 unfetch: 4.2.0 util-deprecate: 1.0.2 - webpack: 5.88.1 + webpack: 4.46.0 dev: true - /@storybook/core-client/6.5.16_zpymzxef3xv3tkikcnxd3qomju: + /@storybook/core-client@6.5.16(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5)(webpack@5.88.1): resolution: {integrity: sha512-14IRaDrVtKrQ+gNWC0wPwkCNfkZOKghYV/swCUnQX3rP99defsZK8Hc7xHIYoAiOP5+sc3sweRAxgmFiJeQ1Ig==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -5765,16 +6476,16 @@ packages: typescript: optional: true dependencies: - '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/channel-postmessage': 6.5.16 '@storybook/channel-websocket': 6.5.16 - '@storybook/client-api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/client-api': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/client-logger': 6.5.16 '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/preview-web': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/store': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/ui': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/preview-web': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/store': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/ui': 6.5.16(react-dom@17.0.2)(react@17.0.2) airbnb-js-shims: 2.2.1 ansi-to-html: 0.6.15 core-js: 3.31.1 @@ -5782,16 +6493,16 @@ packages: lodash: 4.17.21 qs: 6.11.2 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 ts-dedent: 2.2.0 typescript: 4.9.5 unfetch: 4.2.0 util-deprecate: 1.0.2 - webpack: 4.46.0 + webpack: 5.88.1(esbuild@0.18.11) dev: true - /@storybook/core-common/6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy: + /@storybook/core-common@6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5): resolution: {integrity: sha512-2qtnKP3TTOzt2cp6LXKRTh7XrI9z5VanMnMTgeoFcA5ebnndD4V6BExQUdYPClE/QooLx6blUWNgS9dFEpjSqQ==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -5802,40 +6513,40 @@ packages: optional: true dependencies: '@babel/core': 7.22.8 - '@babel/plugin-proposal-class-properties': 7.18.6_@babel+core@7.22.8 - '@babel/plugin-proposal-decorators': 7.22.7_@babel+core@7.22.8 - '@babel/plugin-proposal-export-default-from': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-proposal-nullish-coalescing-operator': 7.18.6_@babel+core@7.22.8 - '@babel/plugin-proposal-object-rest-spread': 7.20.7_@babel+core@7.22.8 - '@babel/plugin-proposal-optional-chaining': 7.21.0_@babel+core@7.22.8 - '@babel/plugin-proposal-private-methods': 7.18.6_@babel+core@7.22.8 - '@babel/plugin-proposal-private-property-in-object': 7.21.11_@babel+core@7.22.8 - '@babel/plugin-syntax-dynamic-import': 7.8.3_@babel+core@7.22.8 - '@babel/plugin-transform-arrow-functions': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-block-scoping': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-classes': 7.22.6_@babel+core@7.22.8 - '@babel/plugin-transform-destructuring': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-for-of': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-parameters': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-shorthand-properties': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-spread': 7.22.5_@babel+core@7.22.8 - '@babel/preset-env': 7.22.7_@babel+core@7.22.8 - '@babel/preset-react': 7.22.5_@babel+core@7.22.8 - '@babel/preset-typescript': 7.22.5_@babel+core@7.22.8 - '@babel/register': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-proposal-class-properties': 7.18.6(@babel/core@7.22.8) + '@babel/plugin-proposal-decorators': 7.22.7(@babel/core@7.22.8) + '@babel/plugin-proposal-export-default-from': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-proposal-nullish-coalescing-operator': 7.18.6(@babel/core@7.22.8) + '@babel/plugin-proposal-object-rest-spread': 7.20.7(@babel/core@7.22.8) + '@babel/plugin-proposal-optional-chaining': 7.21.0(@babel/core@7.22.8) + '@babel/plugin-proposal-private-methods': 7.18.6(@babel/core@7.22.8) + '@babel/plugin-proposal-private-property-in-object': 7.21.11(@babel/core@7.22.8) + '@babel/plugin-syntax-dynamic-import': 7.8.3(@babel/core@7.22.8) + '@babel/plugin-transform-arrow-functions': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-block-scoping': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-classes': 7.22.6(@babel/core@7.22.8) + '@babel/plugin-transform-destructuring': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-for-of': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-parameters': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-shorthand-properties': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-spread': 7.22.5(@babel/core@7.22.8) + '@babel/preset-env': 7.22.7(@babel/core@7.22.8) + '@babel/preset-react': 7.22.5(@babel/core@7.22.8) + '@babel/preset-typescript': 7.22.5(@babel/core@7.22.8) + '@babel/register': 7.22.5(@babel/core@7.22.8) '@storybook/node-logger': 6.5.16 '@storybook/semver': 7.3.2 '@types/node': 16.18.38 '@types/pretty-hrtime': 1.0.1 - babel-loader: 8.3.0_n6tf3ekqtzvxjokzr6jiserpma + babel-loader: 8.3.0(@babel/core@7.22.8)(webpack@4.46.0) babel-plugin-macros: 3.1.0 - babel-plugin-polyfill-corejs3: 0.1.7_@babel+core@7.22.8 + babel-plugin-polyfill-corejs3: 0.1.7(@babel/core@7.22.8) chalk: 4.1.2 core-js: 3.31.1 express: 4.18.2 file-system-cache: 1.1.0 find-up: 5.0.0 - fork-ts-checker-webpack-plugin: 6.5.3_evijigonbo4skk2vlqtwtdqibu + fork-ts-checker-webpack-plugin: 6.5.3(eslint@8.4.1)(typescript@4.9.5)(webpack@4.46.0) fs-extra: 9.1.0 glob: 7.2.3 handlebars: 4.7.7 @@ -5846,7 +6557,7 @@ packages: pkg-dir: 5.0.0 pretty-hrtime: 1.0.3 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) resolve-from: 5.0.0 slash: 3.0.0 telejson: 6.0.8 @@ -5862,17 +6573,17 @@ packages: - webpack-command dev: true - /@storybook/core-events/6.5.16: + /@storybook/core-events@6.5.16: resolution: {integrity: sha512-qMZQwmvzpH5F2uwNUllTPg6eZXr2OaYZQRRN8VZJiuorZzDNdAFmiVWMWdkThwmyLEJuQKXxqCL8lMj/7PPM+g==} dependencies: core-js: 3.31.1 dev: true - /@storybook/core-events/7.0.26: + /@storybook/core-events@7.0.26: resolution: {integrity: sha512-ckZszphEAYs9wp8tPVhayEMzk8JxCiQfzbq0S45sbdqdTrl40PmsOjv5iPNaUYElI/Stfz+v4gDCEUfOsxyC+w==} dev: true - /@storybook/core-server/6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy: + /@storybook/core-server@6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5): resolution: {integrity: sha512-/3NPfmNyply395Dm0zaVZ8P9aruwO+tPx4D6/jpw8aqrRSwvAMndPMpoMCm0NXcpSm5rdX+Je4S3JW6JcggFkA==} peerDependencies: '@storybook/builder-webpack5': '*' @@ -5889,17 +6600,17 @@ packages: optional: true dependencies: '@discoveryjs/json-ext': 0.5.7 - '@storybook/builder-webpack4': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy - '@storybook/core-client': 6.5.16_zpymzxef3xv3tkikcnxd3qomju - '@storybook/core-common': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy + '@storybook/builder-webpack4': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) + '@storybook/core-client': 6.5.16(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5)(webpack@4.46.0) + '@storybook/core-common': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 '@storybook/csf-tools': 6.5.16 - '@storybook/manager-webpack4': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy + '@storybook/manager-webpack4': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) '@storybook/node-logger': 6.5.16 '@storybook/semver': 7.3.2 - '@storybook/store': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/telemetry': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy + '@storybook/store': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/telemetry': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) '@types/node': 16.18.38 '@types/node-fetch': 2.6.4 '@types/pretty-hrtime': 1.0.1 @@ -5924,7 +6635,7 @@ packages: pretty-hrtime: 1.0.3 prompts: 2.4.2 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 serve-favicon: 2.5.0 slash: 3.0.0 @@ -5949,7 +6660,7 @@ packages: - webpack-command dev: true - /@storybook/core/6.5.16_kdhf477f3bq3v2mc53jwn63t6u: + /@storybook/core@6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5)(webpack@5.88.1): resolution: {integrity: sha512-CEF3QFTsm/VMnMKtRNr4rRdLeIkIG0g1t26WcmxTdSThNPBd8CsWzQJ7Jqu7CKiut+MU4A1LMOwbwCE5F2gmyA==} peerDependencies: '@storybook/builder-webpack5': '*' @@ -5966,12 +6677,12 @@ packages: typescript: optional: true dependencies: - '@storybook/core-client': 6.5.16_kdhf477f3bq3v2mc53jwn63t6u - '@storybook/core-server': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy + '@storybook/core-client': 6.5.16(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5)(webpack@5.88.1) + '@storybook/core-server': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) typescript: 4.9.5 - webpack: 5.88.1 + webpack: 5.88.1(esbuild@0.18.11) transitivePeerDependencies: - '@storybook/mdx2-csf' - bluebird @@ -5985,7 +6696,7 @@ packages: - webpack-command dev: true - /@storybook/csf-tools/6.5.16: + /@storybook/csf-tools@6.5.16: resolution: {integrity: sha512-+WD4sH/OwAfXZX3IN6/LOZ9D9iGEFcN+Vvgv9wOsLRgsAZ10DG/NK6c1unXKDM/ogJtJYccNI8Hd+qNE/GFV6A==} peerDependencies: '@storybook/mdx2-csf': ^0.0.3 @@ -5996,12 +6707,12 @@ packages: '@babel/core': 7.22.8 '@babel/generator': 7.22.7 '@babel/parser': 7.22.7 - '@babel/plugin-transform-react-jsx': 7.22.5_@babel+core@7.22.8 - '@babel/preset-env': 7.22.7_@babel+core@7.22.8 + '@babel/plugin-transform-react-jsx': 7.22.5(@babel/core@7.22.8) + '@babel/preset-env': 7.22.7(@babel/core@7.22.8) '@babel/traverse': 7.22.8 '@babel/types': 7.22.5 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/mdx1-csf': 0.0.1_@babel+core@7.22.8 + '@storybook/mdx1-csf': 0.0.1(@babel/core@7.22.8) core-js: 3.31.1 fs-extra: 9.1.0 global: 4.4.0 @@ -6011,30 +6722,30 @@ packages: - supports-color dev: true - /@storybook/csf/0.0.2--canary.4566f4d.1: + /@storybook/csf@0.0.2--canary.4566f4d.1: resolution: {integrity: sha512-9OVvMVh3t9znYZwb0Svf/YQoxX2gVOeQTGe2bses2yj+a3+OJnCrUF3/hGv6Em7KujtOdL2LL+JnG49oMVGFgQ==} dependencies: lodash: 4.17.21 dev: true - /@storybook/csf/0.0.2--canary.87bc651.0: + /@storybook/csf@0.0.2--canary.87bc651.0: resolution: {integrity: sha512-ajk1Uxa+rBpFQHKrCcTmJyQBXZ5slfwHVEaKlkuFaW77it8RgbPJp/ccna3sgoi8oZ7FkkOyvv1Ve4SmwFqRqw==} dependencies: lodash: 4.17.21 dev: true - /@storybook/csf/0.1.1: + /@storybook/csf@0.1.1: resolution: {integrity: sha512-4hE3AlNVxR60Wc5KSC68ASYzUobjPqtSKyhV6G+ge0FIXU55N5nTY7dXGRZHQGDBPq+XqchMkIdlkHPRs8nTHg==} dependencies: type-fest: 2.19.0 dev: true - /@storybook/docs-tools/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + /@storybook/docs-tools@6.5.16(react-dom@17.0.2)(react@17.0.2): resolution: {integrity: sha512-o+rAWPRGifjBF5xZzTKOqnHN3XQWkl0QFJYVDIiJYJrVll7ExCkpEq/PahOGzIBBV+tpMstJgmKM3lr/lu/jmg==} dependencies: '@babel/core': 7.22.8 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/store': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/store': 6.5.16(react-dom@17.0.2)(react@17.0.2) core-js: 3.31.1 doctrine: 3.0.0 lodash: 4.17.21 @@ -6045,11 +6756,11 @@ packages: - supports-color dev: true - /@storybook/global/5.0.0: + /@storybook/global@5.0.0: resolution: {integrity: sha512-FcOqPAXACP0I3oJ/ws6/rrPT9WGhu915Cg8D02a9YxLo0DE9zI+a9A5gRGvmQ09fiWPukqI8ZAEoQEdWUKMQdQ==} dev: true - /@storybook/instrumenter/7.0.26: + /@storybook/instrumenter@7.0.26: resolution: {integrity: sha512-7Ty0LTslgkm5RyH6CqTAKhWz/cF6wq/sNdMYKwvVZHWNZ2LKMtXD0RWM2caCPruAGOQ9+52H+3s4TZGKaPSSWQ==} dependencies: '@storybook/channels': 7.0.26 @@ -6059,7 +6770,7 @@ packages: '@storybook/preview-api': 7.0.26 dev: true - /@storybook/manager-webpack4/6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy: + /@storybook/manager-webpack4@6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5): resolution: {integrity: sha512-5VJZwmQU6AgdsBPsYdu886UKBHQ9SJEnFMaeUxKEclXk+iRsmbzlL4GHKyVd6oGX/ZaecZtcHPR6xrzmA4Ziew==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -6070,42 +6781,42 @@ packages: optional: true dependencies: '@babel/core': 7.22.8 - '@babel/plugin-transform-template-literals': 7.22.5_@babel+core@7.22.8 - '@babel/preset-react': 7.22.5_@babel+core@7.22.8 - '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/core-client': 6.5.16_zpymzxef3xv3tkikcnxd3qomju - '@storybook/core-common': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy + '@babel/plugin-transform-template-literals': 7.22.5(@babel/core@7.22.8) + '@babel/preset-react': 7.22.5(@babel/core@7.22.8) + '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/core-client': 6.5.16(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5)(webpack@4.46.0) + '@storybook/core-common': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) '@storybook/node-logger': 6.5.16 - '@storybook/theming': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/ui': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/theming': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/ui': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@types/node': 16.18.38 '@types/webpack': 4.41.33 - babel-loader: 8.3.0_n6tf3ekqtzvxjokzr6jiserpma + babel-loader: 8.3.0(@babel/core@7.22.8)(webpack@4.46.0) case-sensitive-paths-webpack-plugin: 2.4.0 chalk: 4.1.2 core-js: 3.31.1 - css-loader: 3.6.0_webpack@4.46.0 + css-loader: 3.6.0(webpack@4.46.0) express: 4.18.2 - file-loader: 6.2.0_webpack@4.46.0 + file-loader: 6.2.0(webpack@4.46.0) find-up: 5.0.0 fs-extra: 9.1.0 - html-webpack-plugin: 4.5.2_webpack@4.46.0 + html-webpack-plugin: 4.5.2(webpack@4.46.0) node-fetch: 2.6.12 - pnp-webpack-plugin: 1.6.4_typescript@4.9.5 + pnp-webpack-plugin: 1.6.4(typescript@4.9.5) react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) read-pkg-up: 7.0.1 regenerator-runtime: 0.13.11 resolve-from: 5.0.0 - style-loader: 1.3.0_webpack@4.46.0 + style-loader: 1.3.0(webpack@4.46.0) telejson: 6.0.8 - terser-webpack-plugin: 4.2.3_webpack@4.46.0 + terser-webpack-plugin: 4.2.3(webpack@4.46.0) ts-dedent: 2.2.0 typescript: 4.9.5 - url-loader: 4.1.1_lit45vopotvaqup7lrvlnvtxwy + url-loader: 4.1.1(file-loader@6.2.0)(webpack@4.46.0) util-deprecate: 1.0.2 webpack: 4.46.0 - webpack-dev-middleware: 3.7.3_webpack@4.46.0 + webpack-dev-middleware: 3.7.3(webpack@4.46.0) webpack-virtual-modules: 0.2.2 transitivePeerDependencies: - bluebird @@ -6117,12 +6828,12 @@ packages: - webpack-command dev: true - /@storybook/mdx1-csf/0.0.1_@babel+core@7.22.8: + /@storybook/mdx1-csf@0.0.1(@babel/core@7.22.8): resolution: {integrity: sha512-4biZIWWzoWlCarMZmTpqcJNgo/RBesYZwGFbQeXiGYsswuvfWARZnW9RE9aUEMZ4XPn7B1N3EKkWcdcWe/K2tg==} dependencies: '@babel/generator': 7.22.7 '@babel/parser': 7.22.7 - '@babel/preset-env': 7.22.7_@babel+core@7.22.8 + '@babel/preset-env': 7.22.7(@babel/core@7.22.8) '@babel/types': 7.22.5 '@mdx-js/mdx': 1.6.22 '@types/lodash': 4.14.195 @@ -6136,15 +6847,15 @@ packages: - supports-color dev: true - /@storybook/mdx1-csf/0.0.4_wumd2qseuobkz2wudw2hqnarr4: + /@storybook/mdx1-csf@0.0.4(@babel/core@7.22.8)(react@17.0.2): resolution: {integrity: sha512-xxUEMy0D+0G1aSYxbeVNbs+XBU5nCqW4I7awpBYSTywXDv/MJWeC6FDRpj5P1pgfq8j8jWDD5ZDvBQ7syFg0LQ==} dependencies: '@babel/generator': 7.22.7 '@babel/parser': 7.22.7 - '@babel/preset-env': 7.22.7_@babel+core@7.22.8 + '@babel/preset-env': 7.22.7(@babel/core@7.22.8) '@babel/types': 7.22.5 '@mdx-js/mdx': 1.6.22 - '@mdx-js/react': 1.6.22_react@17.0.2 + '@mdx-js/react': 1.6.22(react@17.0.2) '@types/lodash': 4.14.195 js-string-escape: 1.0.1 loader-utils: 2.0.4 @@ -6157,7 +6868,7 @@ packages: - supports-color dev: true - /@storybook/node-logger/6.5.16: + /@storybook/node-logger@6.5.16: resolution: {integrity: sha512-YjhBKrclQtjhqFNSO+BZK+RXOx6EQypAELJKoLFaawg331e8VUfvUuRCNB3fcEWp8G9oH13PQQte0OTjLyyOYg==} dependencies: '@types/npmlog': 4.1.4 @@ -6167,13 +6878,13 @@ packages: pretty-hrtime: 1.0.3 dev: true - /@storybook/postinstall/6.5.16: + /@storybook/postinstall@6.5.16: resolution: {integrity: sha512-08K2q+qN6pqyPW7PHLCZ5G5Xa6Wosd6t0F16PQ4abX2ItlJLabVoJN5mZ0gm/aeLTjD8QYr8IDvacu4eXh0SVA==} dependencies: core-js: 3.31.1 dev: true - /@storybook/preview-api/7.0.26: + /@storybook/preview-api@7.0.26: resolution: {integrity: sha512-uJwA4errBOZOoDF2T7Z2oLqjAYvvjMr31sTsOoT0niJtWr29RQp8yS6VoSrsuh+y3FAVqBEl5pS+DX3IGLjvxw==} dependencies: '@storybook/channel-postmessage': 7.0.26 @@ -6193,25 +6904,25 @@ packages: util-deprecate: 1.0.2 dev: true - /@storybook/preview-web/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + /@storybook/preview-web@6.5.16(react-dom@17.0.2)(react@17.0.2): resolution: {integrity: sha512-IJnvfe2sKCfk7apN9Fu9U8qibbarrPX5JB55ZzK1amSHVmSDuYk5MIMc/U3NnSQNnvd1DO5v/zMcGgj563hrtg==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/channel-postmessage': 6.5.16 '@storybook/client-logger': 6.5.16 '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/store': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/store': 6.5.16(react-dom@17.0.2)(react@17.0.2) ansi-to-html: 0.6.15 core-js: 3.31.1 global: 4.4.0 lodash: 4.17.21 qs: 6.11.2 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 synchronous-promise: 2.0.17 ts-dedent: 2.2.0 @@ -6219,26 +6930,26 @@ packages: util-deprecate: 1.0.2 dev: true - /@storybook/react-docgen-typescript-plugin/1.0.2-canary.6.9d540b91e815f8fc2f8829189deb00553559ff63.0_dhumxs7xcapy5ah5ryvaq7oilu: + /@storybook/react-docgen-typescript-plugin@1.0.2-canary.6.9d540b91e815f8fc2f8829189deb00553559ff63.0(typescript@4.9.5)(webpack@5.88.1): resolution: {integrity: sha512-eVg3BxlOm2P+chijHBTByr90IZVUtgRW56qEOLX7xlww2NBuKrcavBlcmn+HH7GIUktquWkMPtvy6e0W0NgA5w==} peerDependencies: typescript: '>= 3.x' webpack: '>= 4' dependencies: - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) endent: 2.1.0 find-cache-dir: 3.3.2 flat-cache: 3.0.4 micromatch: 4.0.5 - react-docgen-typescript: 2.2.2_typescript@4.9.5 + react-docgen-typescript: 2.2.2(typescript@4.9.5) tslib: 2.6.0 typescript: 4.9.5 - webpack: 5.88.1 + webpack: 5.88.1(esbuild@0.18.11) transitivePeerDependencies: - supports-color dev: true - /@storybook/react/6.5.16_7i6vyke6ny6b2xsni3leqxtq5y: + /@storybook/react@6.5.16(@babel/core@7.22.8)(esbuild@0.18.11)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(require-from-string@2.0.2)(typescript@4.9.5): resolution: {integrity: sha512-cBtNlOzf/MySpNLBK22lJ8wFU22HnfTB2xJyBk7W7Zi71Lm7Uxkhv1Pz8HdiQndJ0SlsAAQOWjQYsSZsGkZIaA==} engines: {node: '>=10.13.0'} hasBin: true @@ -6267,24 +6978,24 @@ packages: optional: true dependencies: '@babel/core': 7.22.8 - '@babel/preset-flow': 7.22.5_@babel+core@7.22.8 - '@babel/preset-react': 7.22.5_@babel+core@7.22.8 - '@pmmmwh/react-refresh-webpack-plugin': 0.5.10_3s7aftcw26g2vhqubpxl7hhzpa - '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@babel/preset-flow': 7.22.5(@babel/core@7.22.8) + '@babel/preset-react': 7.22.5(@babel/core@7.22.8) + '@pmmmwh/react-refresh-webpack-plugin': 0.5.10(react-refresh@0.11.0)(webpack@5.88.1) + '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/client-logger': 6.5.16 - '@storybook/core': 6.5.16_kdhf477f3bq3v2mc53jwn63t6u - '@storybook/core-common': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy + '@storybook/core': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5)(webpack@5.88.1) + '@storybook/core-common': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/docs-tools': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/docs-tools': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/node-logger': 6.5.16 - '@storybook/react-docgen-typescript-plugin': 1.0.2-canary.6.9d540b91e815f8fc2f8829189deb00553559ff63.0_dhumxs7xcapy5ah5ryvaq7oilu + '@storybook/react-docgen-typescript-plugin': 1.0.2-canary.6.9d540b91e815f8fc2f8829189deb00553559ff63.0(typescript@4.9.5)(webpack@5.88.1) '@storybook/semver': 7.3.2 - '@storybook/store': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/store': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@types/estree': 0.0.51 '@types/node': 16.18.38 '@types/webpack-env': 1.18.1 acorn: 7.4.1 - acorn-jsx: 5.3.2_acorn@7.4.1 + acorn-jsx: 5.3.2(acorn@7.4.1) acorn-walk: 7.2.0 babel-plugin-add-react-displayname: 0.0.5 babel-plugin-react-docgen: 4.2.1 @@ -6296,15 +7007,16 @@ packages: lodash: 4.17.21 prop-types: 15.8.1 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 - react-element-to-jsx-string: 14.3.4_sfoxds7t5ydpegc3knd667wn6m + react-dom: 17.0.2(react@17.0.2) + react-element-to-jsx-string: 14.3.4(react-dom@17.0.2)(react@17.0.2) react-refresh: 0.11.0 read-pkg-up: 7.0.1 regenerator-runtime: 0.13.11 + require-from-string: 2.0.2 ts-dedent: 2.2.0 typescript: 4.9.5 util-deprecate: 1.0.2 - webpack: 5.88.1 + webpack: 5.88.1(esbuild@0.18.11) transitivePeerDependencies: - '@storybook/mdx2-csf' - '@swc/core' @@ -6327,7 +7039,7 @@ packages: - webpack-plugin-serve dev: true - /@storybook/router/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + /@storybook/router@6.5.16(react-dom@17.0.2)(react@17.0.2): resolution: {integrity: sha512-ZgeP8a5YV/iuKbv31V8DjPxlV4AzorRiR8OuSt/KqaiYXNXlOoQDz/qMmiNcrshrfLpmkzoq7fSo4T8lWo2UwQ==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -6338,11 +7050,11 @@ packages: memoizerific: 1.11.3 qs: 6.11.2 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 dev: true - /@storybook/semver/7.3.2: + /@storybook/semver@7.3.2: resolution: {integrity: sha512-SWeszlsiPsMI0Ps0jVNtH64cI5c0UF3f7KgjVKJoNP30crQ6wUSddY2hsdeczZXEKVJGEn50Q60flcGsQGIcrg==} engines: {node: '>=10'} hasBin: true @@ -6351,13 +7063,13 @@ packages: find-up: 4.1.0 dev: true - /@storybook/source-loader/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + /@storybook/source-loader@6.5.16(react-dom@17.0.2)(react@17.0.2): resolution: {integrity: sha512-fyVl4jrM/5JLrb48aqXPu7sTsmySQaVGFp1zfeqvPPlJRFMastDrePm5XGPN7Qjv1wsKmpuBvuweFKOT1pru3g==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/client-logger': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 core-js: 3.31.1 @@ -6367,17 +7079,17 @@ packages: lodash: 4.17.21 prettier: 2.3.0 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 dev: true - /@storybook/store/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + /@storybook/store@6.5.16(react-dom@17.0.2)(react@17.0.2): resolution: {integrity: sha512-g+bVL5hmMq/9cM51K04e37OviUPHT0rHHrRm5wj/hrf18Kd9120b3sxdQ5Dc+HZ292yuME0n+cyrQPTYx9Epmw==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/client-logger': 6.5.16 '@storybook/core-events': 6.5.16 '@storybook/csf': 0.0.2--canary.4566f4d.1 @@ -6387,7 +7099,7 @@ packages: lodash: 4.17.21 memoizerific: 1.11.3 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 slash: 3.0.0 stable: 0.1.8 @@ -6396,11 +7108,11 @@ packages: util-deprecate: 1.0.2 dev: true - /@storybook/telemetry/6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy: + /@storybook/telemetry@6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5): resolution: {integrity: sha512-CWr5Uko1l9jJW88yTXsZTj/3GTabPvw0o7pDPOXPp8JRZiJTxv1JFaFCafhK9UzYbgcRuGfCC8kEWPZims7iKA==} dependencies: '@storybook/client-logger': 6.5.16 - '@storybook/core-common': 6.5.16_jgxnvbe4faw3ohf4h6p42qq6oy + '@storybook/core-common': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) chalk: 4.1.2 core-js: 3.31.1 detect-package-manager: 2.0.1 @@ -6423,17 +7135,17 @@ packages: - webpack-command dev: true - /@storybook/testing-library/0.0.11: + /@storybook/testing-library@0.0.11: resolution: {integrity: sha512-8KbKx3s1e+uF3oWlPdyXRpZa6xtCsCHtXh1nCTisMA6P5YcSDaCg59NXIOVIQCAwKvjRomlqMJH8JL1WyOzeVg==} dependencies: '@storybook/client-logger': 7.0.26 '@storybook/instrumenter': 7.0.26 '@testing-library/dom': 8.20.1 - '@testing-library/user-event': 13.5.0_szfc7t2zqsdonxwckqxkjn2the + '@testing-library/user-event': 13.5.0(@testing-library/dom@8.20.1) ts-dedent: 2.2.0 dev: true - /@storybook/testing-react/1.3.0_o7jp7fwfcghoqe4nbzdqvmyhrm: + /@storybook/testing-react@1.3.0(@storybook/addons@6.5.16)(@storybook/client-api@6.5.16)(@storybook/preview-web@6.5.16)(@storybook/react@6.5.16)(react@17.0.2): resolution: {integrity: sha512-TfxzflxwBHSPhetWKuYt239t+1iN8gnnUN8OKo5UGtwwirghKQlApjH23QXW6j8YBqFhmq+yP29Oqf8HgKCFLw==} engines: {node: '>=10'} peerDependencies: @@ -6443,12 +7155,15 @@ packages: '@storybook/react': '>=6.4.0' react: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: + '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/client-api': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/csf': 0.0.2--canary.87bc651.0 - '@storybook/react': 6.5.16_7i6vyke6ny6b2xsni3leqxtq5y + '@storybook/preview-web': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/react': 6.5.16(@babel/core@7.22.8)(esbuild@0.18.11)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(require-from-string@2.0.2)(typescript@4.9.5) react: 17.0.2 dev: true - /@storybook/theming/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + /@storybook/theming@6.5.16(react-dom@17.0.2)(react@17.0.2): resolution: {integrity: sha512-hNLctkjaYLRdk1+xYTkC1mg4dYz2wSv6SqbLpcKMbkPHTE0ElhddGPHQqB362md/w9emYXNkt1LSMD8Xk9JzVQ==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -6458,11 +7173,11 @@ packages: core-js: 3.31.1 memoizerific: 1.11.3 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 dev: true - /@storybook/types/7.0.26: + /@storybook/types@7.0.26: resolution: {integrity: sha512-5RBi6agtDglNXdffmw4+Fyv2dUdlIdeOdUj0O5+JRYajTxfHdurZd9r/42z4OstN+ORDkLA/svt8Q9JyRpIb6Q==} dependencies: '@storybook/channels': 7.0.26 @@ -6471,31 +7186,31 @@ packages: file-system-cache: 2.3.0 dev: true - /@storybook/ui/6.5.16_sfoxds7t5ydpegc3knd667wn6m: + /@storybook/ui@6.5.16(react-dom@17.0.2)(react@17.0.2): resolution: {integrity: sha512-rHn/n12WM8BaXtZ3IApNZCiS+C4Oc5+Lkl4MoctX8V7QSml0SxZBB5hsJ/AiWkgbRxjQpa/L/Nt7/Qw0FjTH/A==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/addons': 6.5.16_sfoxds7t5ydpegc3knd667wn6m - '@storybook/api': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/api': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/channels': 6.5.16 '@storybook/client-logger': 6.5.16 - '@storybook/components': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/components': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/core-events': 6.5.16 - '@storybook/router': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/router': 6.5.16(react-dom@17.0.2)(react@17.0.2) '@storybook/semver': 7.3.2 - '@storybook/theming': 6.5.16_sfoxds7t5ydpegc3knd667wn6m + '@storybook/theming': 6.5.16(react-dom@17.0.2)(react@17.0.2) core-js: 3.31.1 memoizerific: 1.11.3 qs: 6.11.2 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 resolve-from: 5.0.0 dev: true - /@surma/rollup-plugin-off-main-thread/2.2.3: + /@surma/rollup-plugin-off-main-thread@2.2.3: resolution: {integrity: sha512-lR8q/9W7hZpMWweNiAKU7NQerBnzQQLvi8qnTDU/fxItPhtZVMbPV3lbCwjhIlNBe9Bbr5V+KHshvWmVSG9cxQ==} dependencies: ejs: 3.1.9 @@ -6504,16 +7219,16 @@ packages: string.prototype.matchall: 4.0.8 dev: true - /@sveltejs/adapter-auto/2.1.0_@sveltejs+kit@1.22.2: + /@sveltejs/adapter-auto@2.1.0(@sveltejs/kit@1.22.2): resolution: {integrity: sha512-o2pZCfATFtA/Gw/BB0Xm7k4EYaekXxaPGER3xGSY3FvzFJGTlJlZjBseaXwYSM94lZ0HniOjTokN3cWaLX6fow==} peerDependencies: '@sveltejs/kit': ^1.0.0 dependencies: - '@sveltejs/kit': 1.22.2_svelte@3.59.2+vite@4.4.3 + '@sveltejs/kit': 1.22.2(svelte@3.59.2)(vite@4.4.3) import-meta-resolve: 3.0.0 dev: true - /@sveltejs/kit/1.22.2_svelte@3.59.2+vite@4.4.3: + /@sveltejs/kit@1.22.2(svelte@3.59.2)(vite@4.4.3): resolution: {integrity: sha512-T6GY5jSfQgoDnNPNqAuDi9IK+ZW0TspzTV16UAN6GTsxbri67DGVIbw7QOXPg8FMrZQMmda1AtAxPMfXbOqCgw==} engines: {node: ^16.14 || >=18} hasBin: true @@ -6522,7 +7237,7 @@ packages: svelte: ^3.54.0 || ^4.0.0-next.0 vite: ^4.0.0 dependencies: - '@sveltejs/vite-plugin-svelte': 2.4.2_svelte@3.59.2+vite@4.4.3 + '@sveltejs/vite-plugin-svelte': 2.4.2(svelte@3.59.2)(vite@4.4.3) '@types/cookie': 0.5.1 cookie: 0.5.0 devalue: 4.3.2 @@ -6535,12 +7250,12 @@ packages: sirv: 2.0.3 svelte: 3.59.2 undici: 5.22.1 - vite: 4.4.3 + vite: 4.4.3(@types/node@18.16.19) transitivePeerDependencies: - supports-color dev: true - /@sveltejs/vite-plugin-svelte-inspector/1.0.3_cryykssficcegziiuctbhcjymy: + /@sveltejs/vite-plugin-svelte-inspector@1.0.3(@sveltejs/vite-plugin-svelte@2.4.2)(svelte@3.59.2)(vite@4.4.3): resolution: {integrity: sha512-Khdl5jmmPN6SUsVuqSXatKpQTMIifoQPDanaxC84m9JxIibWvSABJyHpyys0Z+1yYrxY5TTEQm+6elh0XCMaOA==} engines: {node: ^14.18.0 || >= 16} peerDependencies: @@ -6548,15 +7263,15 @@ packages: svelte: ^3.54.0 || ^4.0.0 vite: ^4.0.0 dependencies: - '@sveltejs/vite-plugin-svelte': 2.4.2_svelte@4.0.5+vite@4.4.3 - debug: 4.3.4 - svelte: 4.0.5 - vite: 4.4.3 + '@sveltejs/vite-plugin-svelte': 2.4.2(svelte@3.59.2)(vite@4.4.3) + debug: 4.3.4(supports-color@8.1.1) + svelte: 3.59.2 + vite: 4.4.3(@types/node@18.16.19) transitivePeerDependencies: - supports-color dev: true - /@sveltejs/vite-plugin-svelte-inspector/1.0.3_f2bspsxjd2jtgfnohks6gor5ka: + /@sveltejs/vite-plugin-svelte-inspector@1.0.3(@sveltejs/vite-plugin-svelte@2.4.2)(svelte@4.0.5)(vite@4.4.3): resolution: {integrity: sha512-Khdl5jmmPN6SUsVuqSXatKpQTMIifoQPDanaxC84m9JxIibWvSABJyHpyys0Z+1yYrxY5TTEQm+6elh0XCMaOA==} engines: {node: ^14.18.0 || >= 16} peerDependencies: @@ -6564,62 +7279,62 @@ packages: svelte: ^3.54.0 || ^4.0.0 vite: ^4.0.0 dependencies: - '@sveltejs/vite-plugin-svelte': 2.4.2_svelte@3.59.2+vite@4.4.3 - debug: 4.3.4 - svelte: 3.59.2 - vite: 4.4.3 + '@sveltejs/vite-plugin-svelte': 2.4.2(svelte@4.0.5)(vite@4.4.3) + debug: 4.3.4(supports-color@8.1.1) + svelte: 4.0.5 + vite: 4.4.3(@types/node@18.16.19) transitivePeerDependencies: - supports-color dev: true - /@sveltejs/vite-plugin-svelte/2.4.2_svelte@3.59.2+vite@4.4.3: + /@sveltejs/vite-plugin-svelte@2.4.2(svelte@3.59.2)(vite@4.4.3): resolution: {integrity: sha512-ePfcC48ftMKhkT0OFGdOyycYKnnkT6i/buzey+vHRTR/JpQvuPzzhf1PtKqCDQfJRgoPSN2vscXs6gLigx/zGw==} engines: {node: ^14.18.0 || >= 16} peerDependencies: svelte: ^3.54.0 || ^4.0.0 vite: ^4.0.0 dependencies: - '@sveltejs/vite-plugin-svelte-inspector': 1.0.3_f2bspsxjd2jtgfnohks6gor5ka - debug: 4.3.4 + '@sveltejs/vite-plugin-svelte-inspector': 1.0.3(@sveltejs/vite-plugin-svelte@2.4.2)(svelte@3.59.2)(vite@4.4.3) + debug: 4.3.4(supports-color@8.1.1) deepmerge: 4.3.1 kleur: 4.1.5 magic-string: 0.30.1 svelte: 3.59.2 - svelte-hmr: 0.15.2_svelte@3.59.2 - vite: 4.4.3 - vitefu: 0.2.4_vite@4.4.3 + svelte-hmr: 0.15.2(svelte@3.59.2) + vite: 4.4.3(@types/node@18.16.19) + vitefu: 0.2.4(vite@4.4.3) transitivePeerDependencies: - supports-color dev: true - /@sveltejs/vite-plugin-svelte/2.4.2_svelte@4.0.5+vite@4.4.3: + /@sveltejs/vite-plugin-svelte@2.4.2(svelte@4.0.5)(vite@4.4.3): resolution: {integrity: sha512-ePfcC48ftMKhkT0OFGdOyycYKnnkT6i/buzey+vHRTR/JpQvuPzzhf1PtKqCDQfJRgoPSN2vscXs6gLigx/zGw==} engines: {node: ^14.18.0 || >= 16} peerDependencies: svelte: ^3.54.0 || ^4.0.0 vite: ^4.0.0 dependencies: - '@sveltejs/vite-plugin-svelte-inspector': 1.0.3_cryykssficcegziiuctbhcjymy - debug: 4.3.4 + '@sveltejs/vite-plugin-svelte-inspector': 1.0.3(@sveltejs/vite-plugin-svelte@2.4.2)(svelte@4.0.5)(vite@4.4.3) + debug: 4.3.4(supports-color@8.1.1) deepmerge: 4.3.1 kleur: 4.1.5 magic-string: 0.30.1 svelte: 4.0.5 - svelte-hmr: 0.15.2_svelte@4.0.5 - vite: 4.4.3 - vitefu: 0.2.4_vite@4.4.3 + svelte-hmr: 0.15.2(svelte@4.0.5) + vite: 4.4.3(@types/node@18.16.19) + vitefu: 0.2.4(vite@4.4.3) transitivePeerDependencies: - supports-color dev: true - /@szmarczak/http-timer/5.0.1: + /@szmarczak/http-timer@5.0.1: resolution: {integrity: sha512-+PmQX0PiAYPMeVYe237LJAYvOMYW1j2rH5YROyS3b4CTVJum34HfRvKvAzozHAQG0TnHNdUfY9nCeUyRAs//cw==} engines: {node: '>=14.16'} dependencies: defer-to-connect: 2.0.1 dev: true - /@testing-library/cypress/9.0.0_cypress@12.17.1: + /@testing-library/cypress@9.0.0(cypress@12.17.1): resolution: {integrity: sha512-c1XiCGeHGGTWn0LAU12sFUfoX3qfId5gcSE2yHode+vsyHDWraxDPALjVnHd4/Fa3j4KBcc5k++Ccy6A9qnkMA==} engines: {node: '>=12', npm: '>=6'} peerDependencies: @@ -6630,7 +7345,7 @@ packages: cypress: 12.17.1 dev: true - /@testing-library/dom/8.20.1: + /@testing-library/dom@8.20.1: resolution: {integrity: sha512-/DiOQ5xBxgdYRC8LNk7U+RWat0S3qRLeIw3ZIkMQ9kkVlRmwD/Eg8k8CqIpD6GW7u20JIUOfMKbxtiLutpjQ4g==} engines: {node: '>=12'} dependencies: @@ -6644,7 +7359,7 @@ packages: pretty-format: 27.5.1 dev: true - /@testing-library/dom/9.3.1: + /@testing-library/dom@9.3.1: resolution: {integrity: sha512-0DGPd9AR3+iDTjGoMpxIkAsUihHZ3Ai6CneU6bRRrffXMgzCdlNk43jTrD2/5LT6CBb3MWTP8v510JzYtahD2w==} engines: {node: '>=14'} dependencies: @@ -6658,7 +7373,7 @@ packages: pretty-format: 27.5.1 dev: true - /@testing-library/jest-dom/5.16.5: + /@testing-library/jest-dom@5.16.5: resolution: {integrity: sha512-N5ixQ2qKpi5OLYfwQmUb/5mSV9LneAcaUfp32pn4yCnpb8r/Yz0pXFPck21dIicKmi+ta5WRAknkZCfA8refMA==} engines: {node: '>=8', npm: '>=6', yarn: '>=1'} dependencies: @@ -6673,7 +7388,7 @@ packages: redent: 3.0.0 dev: true - /@testing-library/react/12.1.5_sfoxds7t5ydpegc3knd667wn6m: + /@testing-library/react@12.1.5(react-dom@17.0.2)(react@17.0.2): resolution: {integrity: sha512-OfTXCJUFgjd/digLUuPxa0+/3ZxsQmE7ub9kcbW/wi96Bh3o/p5vrETcBGfP17NWPGqeYYl5LTRpwyGoMC4ysg==} engines: {node: '>=12'} peerDependencies: @@ -6684,10 +7399,10 @@ packages: '@testing-library/dom': 8.20.1 '@types/react-dom': 17.0.20 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) dev: true - /@testing-library/react/13.4.0_biqbaboplfbrettd7655fr4n2y: + /@testing-library/react@13.4.0(react-dom@18.0.0)(react@18.0.0): resolution: {integrity: sha512-sXOGON+WNTh3MLE9rve97ftaZukN3oNf2KjDy7YTx6hcTO2uuLHuCGynMDhFwGw/jYf4OJ2Qk0i4i79qMNNkyw==} engines: {node: '>=12'} peerDependencies: @@ -6697,11 +7412,11 @@ packages: '@babel/runtime': 7.22.6 '@testing-library/dom': 8.20.1 '@types/react-dom': 18.2.6 - react: 18.2.0 - react-dom: 18.2.0_react@18.2.0 + react: 18.0.0 + react-dom: 18.0.0(react@18.0.0) dev: true - /@testing-library/react/13.4.0_zpnidt7m3osuk7shl3s4oenomq: + /@testing-library/react@13.4.0(react-dom@18.2.0)(react@18.2.0): resolution: {integrity: sha512-sXOGON+WNTh3MLE9rve97ftaZukN3oNf2KjDy7YTx6hcTO2uuLHuCGynMDhFwGw/jYf4OJ2Qk0i4i79qMNNkyw==} engines: {node: '>=12'} peerDependencies: @@ -6711,11 +7426,11 @@ packages: '@babel/runtime': 7.22.6 '@testing-library/dom': 8.20.1 '@types/react-dom': 18.2.6 - react: 18.0.0 - react-dom: 18.0.0_react@18.0.0 + react: 18.2.0 + react-dom: 18.2.0(react@18.2.0) dev: true - /@testing-library/svelte/4.0.3_svelte@4.0.5: + /@testing-library/svelte@4.0.3(svelte@4.0.5): resolution: {integrity: sha512-GldAnyGEOn5gMwME+hLVQrnfuKZFB+it5YOMnRBHX+nqeHMsSa18HeqkdvGqtqLpvn81xV7R7EYFb500ngUfXA==} engines: {node: '>= 10'} peerDependencies: @@ -6725,62 +7440,70 @@ packages: svelte: 4.0.5 dev: true - /@testing-library/user-event/13.5.0: + /@testing-library/user-event@13.5.0(@testing-library/dom@8.20.1): resolution: {integrity: sha512-5Kwtbo3Y/NowpkbRuSepbyMFkZmHgD+vPzYB/RJ4oxt5Gj/avFFBYjhw27cqSVPVw/3a67NK1PbiIr9k4Gwmdg==} engines: {node: '>=10', npm: '>=6'} peerDependencies: '@testing-library/dom': '>=7.21.4' dependencies: '@babel/runtime': 7.22.6 + '@testing-library/dom': 8.20.1 dev: true - /@testing-library/user-event/13.5.0_szfc7t2zqsdonxwckqxkjn2the: + /@testing-library/user-event@13.5.0(@testing-library/dom@9.3.1): resolution: {integrity: sha512-5Kwtbo3Y/NowpkbRuSepbyMFkZmHgD+vPzYB/RJ4oxt5Gj/avFFBYjhw27cqSVPVw/3a67NK1PbiIr9k4Gwmdg==} engines: {node: '>=10', npm: '>=6'} peerDependencies: '@testing-library/dom': '>=7.21.4' dependencies: '@babel/runtime': 7.22.6 - '@testing-library/dom': 8.20.1 + '@testing-library/dom': 9.3.1 dev: true - /@testing-library/user-event/14.4.3: + /@testing-library/user-event@14.4.3(@testing-library/dom@9.3.1): resolution: {integrity: sha512-kCUc5MEwaEMakkO5x7aoD+DLi02ehmEM2QCGWvNqAS1dV/fAvORWEjnjsEIvml59M7Y5kCkWN6fCCyPOe8OL6Q==} engines: {node: '>=12', npm: '>=6'} peerDependencies: '@testing-library/dom': '>=7.21.4' + dependencies: + '@testing-library/dom': 9.3.1 + dev: true + + /@tootallnate/once@1.1.2: + resolution: {integrity: sha512-RbzJvlNzmRq5c3O09UipeuXno4tA1FE6ikOjxZK0tuxVv3412l64l5t1W5pj4+rJq9vpkm/kwiR07aZXnsKPxw==} + engines: {node: '>= 6'} dev: true - /@tootallnate/once/2.0.0: + /@tootallnate/once@2.0.0: resolution: {integrity: sha512-XCuKFP5PS55gnMVu3dty8KPatLqUoy/ZYzDzAGCQ8JNFCkLXzmI7vNHCR+XpbZaMWQK/vQubr7PkYq8g470J/A==} engines: {node: '>= 10'} dev: true - /@tsconfig/node10/1.0.9: + /@tsconfig/node10@1.0.9: resolution: {integrity: sha512-jNsYVVxU8v5g43Erja32laIDHXeoNvFEpX33OK4d6hljo3jDhCBDhx5dhCCTMWUojscpAagGiRkBKxpdl9fxqA==} dev: true - /@tsconfig/node12/1.0.11: + /@tsconfig/node12@1.0.11: resolution: {integrity: sha512-cqefuRsh12pWyGsIoBKJA9luFu3mRxCA+ORZvA4ktLSzIuCUtWVxGIuXigEwO5/ywWFMZ2QEGKWvkZG1zDMTag==} dev: true - /@tsconfig/node14/1.0.3: + /@tsconfig/node14@1.0.3: resolution: {integrity: sha512-ysT8mhdixWK6Hw3i1V2AeRqZ5WfXg1G43mqoYlM2nc6388Fq5jcXyr5mRsqViLx/GJYdoL0bfXD8nmF+Zn/Iow==} dev: true - /@tsconfig/node16/1.0.4: + /@tsconfig/node16@1.0.4: resolution: {integrity: sha512-vxhUy4J8lyeyinH7Azl1pdd43GJhZH/tP2weN8TntQblOY+A0XbT8DJk1/oCPuOOyg/Ja757rG0CgHcWC8OfMA==} dev: true - /@types/aria-query/5.0.1: + /@types/aria-query@5.0.1: resolution: {integrity: sha512-XTIieEY+gvJ39ChLcB4If5zHtPxt3Syj5rgZR+e1ctpmK8NjPf0zFqsz4JpLJT0xla9GFDKjy8Cpu331nrmE1Q==} dev: true - /@types/babel-types/7.0.11: + /@types/babel-types@7.0.11: resolution: {integrity: sha512-pkPtJUUY+Vwv6B1inAz55rQvivClHJxc9aVEPPmaq2cbyeMLCiDpbKpcKyX4LAwpNGi+SHBv0tHv6+0gXv0P2A==} dev: true - /@types/babel__core/7.20.1: + /@types/babel__core@7.20.1: resolution: {integrity: sha512-aACu/U/omhdk15O4Nfb+fHgH/z3QsfQzpnvRZhYhThms83ZnAOZz7zZAWO7mn2yyNQaA4xTO8GLK3uqFU4bYYw==} dependencies: '@babel/parser': 7.22.7 @@ -6790,168 +7513,168 @@ packages: '@types/babel__traverse': 7.20.1 dev: true - /@types/babel__generator/7.6.4: + /@types/babel__generator@7.6.4: resolution: {integrity: sha512-tFkciB9j2K755yrTALxD44McOrk+gfpIpvC3sxHjRawj6PfnQxrse4Clq5y/Rq+G3mrBurMax/lG8Qn2t9mSsg==} dependencies: '@babel/types': 7.22.5 dev: true - /@types/babel__template/7.4.1: + /@types/babel__template@7.4.1: resolution: {integrity: sha512-azBFKemX6kMg5Io+/rdGT0dkGreboUVR0Cdm3fz9QJWpaQGJRQXl7C+6hOTCZcMll7KFyEQpgbYI2lHdsS4U7g==} dependencies: '@babel/parser': 7.22.7 '@babel/types': 7.22.5 dev: true - /@types/babel__traverse/7.20.1: + /@types/babel__traverse@7.20.1: resolution: {integrity: sha512-MitHFXnhtgwsGZWtT68URpOvLN4EREih1u3QtQiN4VdAxWKRVvGCSvw/Qth0M0Qq3pJpnGOu5JaM/ydK7OGbqg==} dependencies: '@babel/types': 7.22.5 dev: true - /@types/body-parser/1.19.2: + /@types/body-parser@1.19.2: resolution: {integrity: sha512-ALYone6pm6QmwZoAgeyNksccT9Q4AWZQ6PvfwR37GT6r6FWUPguq6sUmNGSMV2Wr761oQoBxwGGa6DR5o1DC9g==} dependencies: '@types/connect': 3.4.35 '@types/node': 20.4.1 dev: true - /@types/braces/3.0.2: + /@types/braces@3.0.2: resolution: {integrity: sha512-U5tlMYa0U/2eFTmJgKcPWQOEICP173sJDa6OjHbj5Tv+NVaYcrq2xmdWpNXOwWYGwJu+jER/pfTLdoQ31q8PzA==} dev: true - /@types/chai-subset/1.3.3: + /@types/chai-subset@1.3.3: resolution: {integrity: sha512-frBecisrNGz+F4T6bcc+NLeolfiojh5FxW2klu669+8BARtyQv2C/GkNW6FUodVe4BroGMP/wER/YDGc7rEllw==} dependencies: '@types/chai': 4.3.5 dev: false - /@types/chai/4.3.5: + /@types/chai@4.3.5: resolution: {integrity: sha512-mEo1sAde+UCE6b2hxn332f1g1E8WfYRu6p5SvTKr2ZKC1f7gFJXk4h5PyGP9Dt6gCaG8y8XhwnXWC6Iy2cmBng==} dev: false - /@types/cheerio/0.22.31: + /@types/cheerio@0.22.31: resolution: {integrity: sha512-Kt7Cdjjdi2XWSfrZ53v4Of0wG3ZcmaegFXjMmz9tfNrZSkzzo36G0AL1YqSdcIA78Etjt6E609pt5h1xnQkPUw==} dependencies: '@types/node': 20.4.1 dev: true - /@types/codemirror/5.60.8: + /@types/codemirror@5.60.8: resolution: {integrity: sha512-VjFgDF/eB+Aklcy15TtOTLQeMjTo07k7KAjql8OK5Dirr7a6sJY4T1uVBDuTVG9VEmn1uUsohOpYnVfgC6/jyw==} dependencies: '@types/tern': 0.23.4 dev: true - /@types/connect/3.4.35: + /@types/connect@3.4.35: resolution: {integrity: sha512-cdeYyv4KWoEgpBISTxWvqYsVy444DOqehiF3fM3ne10AmJ62RSyNkUnxMJXHQWRQQX2eR94m5y1IZyDwBjV9FQ==} dependencies: '@types/node': 20.4.1 dev: true - /@types/cookie/0.4.1: + /@types/cookie@0.4.1: resolution: {integrity: sha512-XW/Aa8APYr6jSVVA1y/DEIZX0/GMKLEVekNG727R8cs56ahETkRAy/3DR7+fJyh7oUgGwNQaRfXCun0+KbWY7Q==} dev: true - /@types/cookie/0.5.1: + /@types/cookie@0.5.1: resolution: {integrity: sha512-COUnqfB2+ckwXXSFInsFdOAWQzCCx+a5hq2ruyj+Vjund94RJQd4LG2u9hnvJrTgunKAaax7ancBYlDrNYxA0g==} dev: true - /@types/d3-array/3.0.5: + /@types/d3-array@3.0.5: resolution: {integrity: sha512-Qk7fpJ6qFp+26VeQ47WY0mkwXaiq8+76RJcncDEfMc2ocRzXLO67bLFRNI4OX1aGBoPzsM5Y2T+/m1pldOgD+A==} dev: false - /@types/d3-color/3.1.0: + /@types/d3-color@3.1.0: resolution: {integrity: sha512-HKuicPHJuvPgCD+np6Se9MQvS6OCbJmOjGvylzMJRlDwUXjKTTXs6Pwgk79O09Vj/ho3u1ofXnhFOaEWWPrlwA==} dev: false - /@types/d3-ease/3.0.0: + /@types/d3-ease@3.0.0: resolution: {integrity: sha512-aMo4eaAOijJjA6uU+GIeW018dvy9+oH5Y2VPPzjjfxevvGQ/oRDs+tfYC9b50Q4BygRR8yE2QCLsrT0WtAVseA==} dev: false - /@types/d3-force/3.0.4: + /@types/d3-force@3.0.4: resolution: {integrity: sha512-q7xbVLrWcXvSBBEoadowIUJ7sRpS1yvgMWnzHJggFy5cUZBq2HZL5k/pBSm0GdYWS1vs5/EDwMjSKF55PDY4Aw==} dev: true - /@types/d3-interpolate/3.0.1: + /@types/d3-interpolate@3.0.1: resolution: {integrity: sha512-jx5leotSeac3jr0RePOH1KdR9rISG91QIE4Q2PYTu4OymLTZfA3SrnURSLzKH48HmXVUru50b8nje4E79oQSQw==} dependencies: '@types/d3-color': 3.1.0 dev: false - /@types/d3-path/3.0.0: + /@types/d3-path@3.0.0: resolution: {integrity: sha512-0g/A+mZXgFkQxN3HniRDbXMN79K3CdTpLsevj+PXiTcb2hVyvkZUBg37StmgCQkaD84cUJ4uaDAWq7UJOQy2Tg==} dev: false - /@types/d3-scale/4.0.3: + /@types/d3-scale@4.0.3: resolution: {integrity: sha512-PATBiMCpvHJSMtZAMEhc2WyL+hnzarKzI6wAHYjhsonjWJYGq5BXTzQjv4l8m2jO183/4wZ90rKvSeT7o72xNQ==} dependencies: '@types/d3-time': 3.0.0 dev: false - /@types/d3-selection/3.0.5: + /@types/d3-selection@3.0.5: resolution: {integrity: sha512-xCB0z3Hi8eFIqyja3vW8iV01+OHGYR2di/+e+AiOcXIOrY82lcvWW8Ke1DYE/EUVMsBl4Db9RppSBS3X1U6J0w==} dev: true - /@types/d3-shape/3.1.1: + /@types/d3-shape@3.1.1: resolution: {integrity: sha512-6Uh86YFF7LGg4PQkuO2oG6EMBRLuW9cbavUW46zkIO5kuS2PfTqo2o9SkgtQzguBHbLgNnU90UNsITpsX1My+A==} dependencies: '@types/d3-path': 3.0.0 dev: false - /@types/d3-time/3.0.0: + /@types/d3-time@3.0.0: resolution: {integrity: sha512-sZLCdHvBUcNby1cB6Fd3ZBrABbjz3v1Vm90nysCQ6Vt7vd6e/h9Lt7SiJUoEX0l4Dzc7P5llKyhqSi1ycSf1Hg==} dev: false - /@types/d3-timer/3.0.0: + /@types/d3-timer@3.0.0: resolution: {integrity: sha512-HNB/9GHqu7Fo8AQiugyJbv6ZxYz58wef0esl4Mv828w1ZKpAshw/uFWVDUcIB9KKFeFKoxS3cHY07FFgtTRZ1g==} dev: false - /@types/debug/4.1.8: + /@types/debug@4.1.8: resolution: {integrity: sha512-/vPO1EPOs306Cvhwv7KfVfYvOJqA/S/AXjaHQiJboCZzcNDb+TIJFN9/2C9DZ//ijSKWioNyUxD792QmDJ+HKQ==} dependencies: '@types/ms': 0.7.31 dev: true - /@types/diff/5.0.3: + /@types/diff@5.0.3: resolution: {integrity: sha512-amrLbRqTU9bXMCc6uX0sWpxsQzRIo9z6MJPkH1pkez/qOxuqSZVuryJAWoBRq94CeG8JxY+VK4Le9HtjQR5T9A==} dev: true - /@types/doctrine/0.0.5: + /@types/doctrine@0.0.5: resolution: {integrity: sha512-JJwEeFy8Sl9ctiugU4h4DGN9hCB47oyhUkM2H8g8xZr4tHTEXtmV4U6krKrU8Ng0S7RlG/J7fkta1rGu3pq+YQ==} dev: true - /@types/enzyme/3.10.13: + /@types/enzyme@3.10.13: resolution: {integrity: sha512-FCtoUhmFsud0Yx9fmZk179GkdZ4U9B0GFte64/Md+W/agx0L5SxsIIbhLBOxIb9y2UfBA4WQnaG1Od/UsUQs9Q==} dependencies: '@types/cheerio': 0.22.31 '@types/react': 16.14.43 dev: true - /@types/eslint-scope/3.7.4: + /@types/eslint-scope@3.7.4: resolution: {integrity: sha512-9K4zoImiZc3HlIp6AVUDE4CWYx22a+lhSZMYNpbjW04+YF0KWj4pJXnEMjdnFTiQibFFmElcsasJXDbdI/EPhA==} dependencies: '@types/eslint': 8.44.0 '@types/estree': 1.0.1 dev: true - /@types/eslint/8.44.0: + /@types/eslint@8.44.0: resolution: {integrity: sha512-gsF+c/0XOguWgaOgvFs+xnnRqt9GwgTvIks36WpE6ueeI4KCEHHd8K/CKHqhOqrJKsYH8m27kRzQEvWXAwXUTw==} dependencies: '@types/estree': 1.0.1 '@types/json-schema': 7.0.12 dev: true - /@types/estree/0.0.39: + /@types/estree@0.0.39: resolution: {integrity: sha512-EYNwp3bU+98cpU4lAWYYL7Zz+2gryWH1qbdDTidVd6hkiR6weksdbMadyXKXNPEkQFhXM+hVO9ZygomHXp+AIw==} - /@types/estree/0.0.51: + /@types/estree@0.0.51: resolution: {integrity: sha512-CuPgU6f3eT/XgKKPqKd/gLZV1Xmvf1a2R5POBOGQa6uv82xpls89HU5zKeVoyR8XzHd1RGNOlQlvUe3CFkjWNQ==} dev: true - /@types/estree/1.0.1: + /@types/estree@1.0.1: resolution: {integrity: sha512-LG4opVs2ANWZ1TJoKc937iMmNstM/d0ae1vNbnBvBhqCSezgVUOzcLCqbI5elV8Vy6WKwKjaqR+zO9VKirBBCA==} - /@types/express-serve-static-core/4.17.35: + /@types/express-serve-static-core@4.17.35: resolution: {integrity: sha512-wALWQwrgiB2AWTT91CB62b6Yt0sNHpznUXeZEcnPU3DRdlDIz74x8Qg1UUYKSVFi+va5vKOLYRBI1bRKiLLKIg==} dependencies: '@types/node': 20.4.1 @@ -6960,7 +7683,7 @@ packages: '@types/send': 0.17.1 dev: true - /@types/express/4.17.17: + /@types/express@4.17.17: resolution: {integrity: sha512-Q4FmmuLGBG58btUnfS1c1r/NQdlp3DMfGDGig8WhfpA2YRUtEkxAjkZb0yvplJGYdF1fsQ81iMDcH24sSCNC/Q==} dependencies: '@types/body-parser': 1.19.2 @@ -6969,72 +7692,72 @@ packages: '@types/serve-static': 1.15.2 dev: true - /@types/fs-extra/11.0.1: + /@types/fs-extra@11.0.1: resolution: {integrity: sha512-MxObHvNl4A69ofaTRU8DFqvgzzv8s9yRtaPPm5gud9HDNvpB3GPQFvNuTWAI59B9huVGV5jXYJwbCsmBsOGYWA==} dependencies: '@types/jsonfile': 6.1.1 - '@types/node': 18.16.19 + '@types/node': 20.4.1 dev: true - /@types/fs-extra/9.0.13: + /@types/fs-extra@9.0.13: resolution: {integrity: sha512-nEnwB++1u5lVDM2UI4c1+5R+FYaKfaAzS4OococimjVm3nQw3TuzH5UNsocrcTBbhnerblyHj4A49qXbIiZdpA==} dependencies: '@types/node': 20.4.1 dev: true - /@types/glob/7.2.0: + /@types/glob@7.2.0: resolution: {integrity: sha512-ZUxbzKl0IfJILTS6t7ip5fQQM/J3TJYubDm3nMbgubNNYS62eXeUpoLUC8/7fJNiFYHTrGPQn7hspDUzIHX3UA==} dependencies: '@types/minimatch': 5.1.2 '@types/node': 20.4.1 dev: true - /@types/glob/8.1.0: + /@types/glob@8.1.0: resolution: {integrity: sha512-IO+MJPVhoqz+28h1qLAcBEH2+xHMK6MTyHJc7MTnnYb6wsoLR29POVGJ7LycmVXIqyy/4/2ShP5sUwTXuOwb/w==} dependencies: '@types/minimatch': 5.1.2 - '@types/node': 16.18.38 + '@types/node': 20.4.1 dev: true - /@types/graceful-fs/4.1.6: + /@types/graceful-fs@4.1.6: resolution: {integrity: sha512-Sig0SNORX9fdW+bQuTEovKj3uHcUL6LQKbCrrqb1X7J6/ReAbhCXRAhc+SMejhLELFj2QcyuxmUooZ4bt5ReSw==} dependencies: '@types/node': 20.4.1 dev: true - /@types/hast/2.3.5: + /@types/hast@2.3.5: resolution: {integrity: sha512-SvQi0L/lNpThgPoleH53cdjB3y9zpLlVjRbqB3rH8hx1jiRSBGAhyjV3H+URFjNVRqt2EdYNrbZE5IsGlNfpRg==} dependencies: '@types/unist': 2.0.7 dev: true - /@types/html-minifier-terser/5.1.2: + /@types/html-minifier-terser@5.1.2: resolution: {integrity: sha512-h4lTMgMJctJybDp8CQrxTUiiYmedihHWkjnF/8Pxseu2S6Nlfcy8kwboQ8yejh456rP2yWoEVm1sS/FVsfM48w==} dev: true - /@types/http-cache-semantics/4.0.1: + /@types/http-cache-semantics@4.0.1: resolution: {integrity: sha512-SZs7ekbP8CN0txVG2xVRH6EgKmEm31BOxA07vkFaETzZz1xh+cbt8BcI0slpymvwhx5dlFnQG2rTlPVQn+iRPQ==} dev: true - /@types/http-errors/2.0.1: + /@types/http-errors@2.0.1: resolution: {integrity: sha512-/K3ds8TRAfBvi5vfjuz8y6+GiAYBZ0x4tXv1Av6CWBWn0IlADc+ZX9pMq7oU0fNQPnBwIZl3rmeLp6SBApbxSQ==} dev: true - /@types/inquirer/9.0.3: + /@types/inquirer@9.0.3: resolution: {integrity: sha512-CzNkWqQftcmk2jaCWdBTf9Sm7xSw4rkI1zpU/Udw3HX5//adEZUIm9STtoRP1qgWj0CWQtJ9UTvqmO2NNjhMJw==} dependencies: '@types/through': 0.0.30 rxjs: 7.8.1 dev: true - /@types/is-function/1.0.1: + /@types/is-function@1.0.1: resolution: {integrity: sha512-A79HEEiwXTFtfY+Bcbo58M2GRYzCr9itHWzbzHVFNEYCcoU/MMGwYYf721gBrnhpj1s6RGVVha/IgNFnR0Iw/Q==} dev: true - /@types/istanbul-lib-coverage/2.0.4: + /@types/istanbul-lib-coverage@2.0.4: resolution: {integrity: sha512-z/QT1XN4K4KYuslS23k62yDIDLwLFkzxOuMplDtObz0+y7VqJCaO2o+SPwHCvLFZh7xazvvoor2tA/hPz9ee7g==} - /@types/istanbul-lib-instrument/1.7.4: + /@types/istanbul-lib-instrument@1.7.4: resolution: {integrity: sha512-1i1VVkU2KrpZCmti+t5J/zBb2KLKxHgU1EYL+0QtnDnVyZ59aSKcpnG6J0I6BZGDON566YzPNIlNfk7m+9l1JA==} dependencies: '@types/babel-types': 7.0.11 @@ -7042,37 +7765,37 @@ packages: source-map: 0.6.1 dev: true - /@types/istanbul-lib-report/3.0.0: + /@types/istanbul-lib-report@3.0.0: resolution: {integrity: sha512-plGgXAPfVKFoYfa9NpYDAkseG+g6Jr294RqeqcqDixSbU34MZVJRi/P+7Y8GDpzkEwLaGZZOpKIEmeVZNtKsrg==} dependencies: '@types/istanbul-lib-coverage': 2.0.4 dev: true - /@types/istanbul-lib-source-maps/4.0.1: + /@types/istanbul-lib-source-maps@4.0.1: resolution: {integrity: sha512-WH6e5naLXI3vB2Px3whNeYxzDgm6S6sk3Ht8e3/BiWwEnzZi72wja3bWzWwcgbFTFp8hBLB7NT2p3lNJgxCxvA==} dependencies: '@types/istanbul-lib-coverage': 2.0.4 source-map: 0.6.1 dev: true - /@types/istanbul-reports/3.0.1: + /@types/istanbul-reports@3.0.1: resolution: {integrity: sha512-c3mAZEuK0lvBp8tmuL74XRKn1+y2dcwOUpH7x4WrF6gk1GIgiluDRgMYQtw2OFcBvAJWlt6ASU3tSqxp0Uu0Aw==} dependencies: '@types/istanbul-lib-report': 3.0.0 dev: true - /@types/jest/29.5.3: + /@types/jest@29.5.3: resolution: {integrity: sha512-1Nq7YrO/vJE/FYnqYyw0FS8LdrjExSgIiHyKg7xPpn+yi8Q4huZryKnkJatN1ZRH89Kw2v33/8ZMB7DuZeSLlA==} dependencies: expect: 29.6.1 pretty-format: 29.6.1 dev: true - /@types/js-levenshtein/1.1.1: + /@types/js-levenshtein@1.1.1: resolution: {integrity: sha512-qC4bCqYGy1y/NP7dDVr7KJarn+PbX1nSpwA7JXdu0HxT3QYjO8MJ+cntENtHFVy2dRAyBV23OZ6MxsW1AM1L8g==} dev: true - /@types/jsdom/21.1.1: + /@types/jsdom@21.1.1: resolution: {integrity: sha512-cZFuoVLtzKP3gmq9eNosUL1R50U+USkbLtUQ1bYVgl/lKp0FZM7Cq4aIHAL8oIvQ17uSHi7jXPtfDOdjPwBE7A==} dependencies: '@types/node': 20.4.1 @@ -7080,150 +7803,149 @@ packages: parse5: 7.1.2 dev: true - /@types/json-schema/7.0.12: + /@types/json-schema@7.0.12: resolution: {integrity: sha512-Hr5Jfhc9eYOQNPYO5WLDq/n4jqijdHNlDXjuAQkkt+mWdQR+XJToOHrsD4cPaMXpn6KO7y2+wM8AZEs8VpBLVA==} dev: true - /@types/jsonfile/6.1.1: + /@types/jsonfile@6.1.1: resolution: {integrity: sha512-GSgiRCVeapDN+3pqA35IkQwasaCh/0YFH5dEF6S88iDvEn901DjOeH3/QPY+XYP1DFzDZPvIvfeEgk+7br5png==} dependencies: - '@types/node': 18.16.19 + '@types/node': 20.4.1 dev: true - /@types/lodash/4.14.195: + /@types/lodash@4.14.195: resolution: {integrity: sha512-Hwx9EUgdwf2GLarOjQp5ZH8ZmblzcbTBC2wtQWNKARBSxM9ezRIAUpeDTgoQRAFB0+8CNWXVA9+MaSOzOF3nPg==} dev: true - /@types/mdast/3.0.12: + /@types/mdast@3.0.12: resolution: {integrity: sha512-DT+iNIRNX884cx0/Q1ja7NyUPpZuv0KPyL5rGNxm1WC1OtHstl7n4Jb7nk+xacNShQMbczJjt8uFzznpp6kYBg==} dependencies: '@types/unist': 2.0.7 dev: true - /@types/micromatch/4.0.2: + /@types/micromatch@4.0.2: resolution: {integrity: sha512-oqXqVb0ci19GtH0vOA/U2TmHTcRY9kuZl4mqUxe0QmJAlIW13kzhuK5pi1i9+ngav8FjpSb9FVS/GE00GLX1VA==} dependencies: '@types/braces': 3.0.2 dev: true - /@types/mime/1.3.2: + /@types/mime@1.3.2: resolution: {integrity: sha512-YATxVxgRqNH6nHEIsvg6k2Boc1JHI9ZbH5iWFFv/MTkchz3b1ieGDa5T0a9RznNdI0KhVbdbWSN+KWWrQZRxTw==} dev: true - /@types/mime/3.0.1: + /@types/mime@3.0.1: resolution: {integrity: sha512-Y4XFY5VJAuw0FgAqPNd6NNoV44jbq9Bz2L7Rh/J6jLTiHBSBJa9fxqQIvkIld4GsoDOcCbvzOUAbLPsSKKg+uA==} dev: true - /@types/minimatch/5.1.2: + /@types/minimatch@5.1.2: resolution: {integrity: sha512-K0VQKziLUWkVKiRVrx4a40iPaxTUefQmjtkQofBkYRcoaaL/8rhwDWww9qWbrgicNOgnpIsMxyNIUM4+n6dUIA==} dev: true - /@types/ms/0.7.31: + /@types/ms@0.7.31: resolution: {integrity: sha512-iiUgKzV9AuaEkZqkOLDIvlQiL6ltuZd9tGcW3gwpnX8JbuiuhFlEGmmFXEXkN50Cvq7Os88IY2v0dkDqXYWVgA==} dev: true - /@types/natural-compare/1.4.1: + /@types/natural-compare@1.4.1: resolution: {integrity: sha512-9dr4UakpvN0QUvwNefk9+o14Sr1pPPIDWkgCxPkHcg3kyjtc9eKK1ng6dZ23vRwByloCqXYtZ1T5nJxkk3Ib3A==} dev: true - /@types/node-fetch/2.6.4: + /@types/node-fetch@2.6.4: resolution: {integrity: sha512-1ZX9fcN4Rvkvgv4E6PAY5WXUFWFcRWxZa3EW83UjycOB9ljJCedb2CupIP4RZMEwF/M3eTcCihbBRgwtGbg5Rg==} dependencies: - '@types/node': 16.18.38 + '@types/node': 20.4.1 form-data: 3.0.1 dev: true - /@types/node/14.18.53: + /@types/node@14.18.53: resolution: {integrity: sha512-soGmOpVBUq+gaBMwom1M+krC/NNbWlosh4AtGA03SyWNDiqSKtwp7OulO1M6+mg8YkHMvJ/y0AkCeO8d1hNb7A==} dev: true - /@types/node/16.18.38: + /@types/node@16.18.38: resolution: {integrity: sha512-6sfo1qTulpVbkxECP+AVrHV9OoJqhzCsfTNp5NIG+enM4HyM3HvZCO798WShIXBN0+QtDIcutJCjsVYnQP5rIQ==} dev: true - /@types/node/18.16.19: + /@types/node@18.16.19: resolution: {integrity: sha512-IXl7o+R9iti9eBW4Wg2hx1xQDig183jj7YLn8F7udNceyfkbn1ZxmzZXuak20gR40D7pIkIY1kYGx5VIGbaHKA==} - dev: true - /@types/node/20.4.1: + /@types/node@20.4.1: resolution: {integrity: sha512-JIzsAvJeA/5iY6Y/OxZbv1lUcc8dNSE77lb2gnBH+/PJ3lFR1Ccvgwl5JWnHAkNHcRsT0TbpVOsiMKZ1F/yyJg==} - /@types/normalize-package-data/2.4.1: + /@types/normalize-package-data@2.4.1: resolution: {integrity: sha512-Gj7cI7z+98M282Tqmp2K5EIsoouUEzbBJhQQzDE3jSIRk6r9gsz0oUokqIUR4u1R3dMHo0pDHM7sNOHyhulypw==} dev: true - /@types/npmlog/4.1.4: + /@types/npmlog@4.1.4: resolution: {integrity: sha512-WKG4gTr8przEZBiJ5r3s8ZIAoMXNbOgQ+j/d5O4X3x6kZJRLNvyUJuUK/KoG3+8BaOHPhp2m7WC6JKKeovDSzQ==} dev: true - /@types/parse-json/4.0.0: + /@types/parse-json@4.0.0: resolution: {integrity: sha512-//oorEZjL6sbPcKUaCdIGlIUeH26mgzimjBB77G6XRgnDl/L5wOnpyBGRe/Mmf5CVW3PwEBE1NjiMZ/ssFh4wA==} - /@types/parse5/5.0.3: + /@types/parse5@5.0.3: resolution: {integrity: sha512-kUNnecmtkunAoQ3CnjmMkzNU/gtxG8guhi+Fk2U/kOpIKjIMKnXGp4IJCgQJrXSgMsWYimYG4TGjz/UzbGEBTw==} dev: true - /@types/prettier/2.7.3: + /@types/prettier@2.7.3: resolution: {integrity: sha512-+68kP9yzs4LMp7VNh8gdzMSPZFL44MLGqiHWvttYJe+6qnuVr4Ek9wSBQoveqY/r+LwjCcU29kNVkidwim+kYA==} dev: true - /@types/pretty-hrtime/1.0.1: + /@types/pretty-hrtime@1.0.1: resolution: {integrity: sha512-VjID5MJb1eGKthz2qUerWT8+R4b9N+CHvGCzg9fn4kWZgaF9AhdYikQio3R7wV8YY1NsQKPaCwKz1Yff+aHNUQ==} dev: true - /@types/prompts/2.4.4: + /@types/prompts@2.4.4: resolution: {integrity: sha512-p5N9uoTH76lLvSAaYSZtBCdEXzpOOufsRjnhjVSrZGXikVGHX9+cc9ERtHRV4hvBKHyZb1bg4K+56Bd2TqUn4A==} dependencies: '@types/node': 20.4.1 kleur: 3.0.3 dev: true - /@types/prop-types/15.7.5: + /@types/prop-types@15.7.5: resolution: {integrity: sha512-JCB8C6SnDoQf0cNycqd/35A7MjcnK+ZTqE7judS6o7utxUCg6imJg3QK2qzHKszlTjcj2cn+NwMB2i96ubpj7w==} - /@types/pug/2.0.6: + /@types/pug@2.0.6: resolution: {integrity: sha512-SnHmG9wN1UVmagJOnyo/qkk0Z7gejYxOYYmaAwr5u2yFYfsupN3sg10kyzN8Hep/2zbHxCnsumxOoRIRMBwKCg==} dev: true - /@types/qs/6.9.7: + /@types/qs@6.9.7: resolution: {integrity: sha512-FGa1F62FT09qcrueBA6qYTrJPVDzah9a+493+o2PCXsesWHIn27G98TsSMs3WPNbZIEj4+VJf6saSFpvD+3Zsw==} dev: true - /@types/range-parser/1.2.4: + /@types/range-parser@1.2.4: resolution: {integrity: sha512-EEhsLsD6UsDM1yFhAvy0Cjr6VwmpMWqFBCb9w07wVugF7w9nfajxLuVmngTIpgS6svCnm6Vaw+MZhoDCKnOfsw==} dev: true - /@types/react-dom/17.0.20: + /@types/react-dom@17.0.20: resolution: {integrity: sha512-4pzIjSxDueZZ90F52mU3aPoogkHIoSIDG+oQ+wQK7Cy2B9S+MvOqY0uEA/qawKz381qrEDkvpwyt8Bm31I8sbA==} dependencies: '@types/react': 17.0.62 dev: true - /@types/react-dom/18.2.6: + /@types/react-dom@18.2.6: resolution: {integrity: sha512-2et4PDvg6PVCyS7fuTc4gPoksV58bW0RwSxWKcPRcHZf0PRUGq03TKcD/rUHe3azfV6/5/biUBJw+HhCQjaP0A==} dependencies: '@types/react': 18.2.14 dev: true - /@types/react-is/18.2.1: + /@types/react-is@18.2.1: resolution: {integrity: sha512-wyUkmaaSZEzFZivD8F2ftSyAfk6L+DfFliVj/mYdOXbVjRcS87fQJLTnhk6dRZPuJjI+9g6RZJO4PNCngUrmyw==} dependencies: '@types/react': 18.2.14 dev: false - /@types/react-test-renderer/17.0.2: + /@types/react-test-renderer@17.0.2: resolution: {integrity: sha512-+F1KONQTBHDBBhbHuT2GNydeMpPuviduXIVJRB7Y4nma4NR5DrTJfMMZ+jbhEHbpwL+Uqhs1WXh4KHiyrtYTPg==} dependencies: '@types/react': 17.0.62 dev: true - /@types/react-transition-group/4.4.6: + /@types/react-transition-group@4.4.6: resolution: {integrity: sha512-VnCdSxfcm08KjsJVQcfBmhEQAPnLB8G08hAxn39azX1qYBQ/5RVQuoHuKIcfKOdncuaUvEpFKFzEvbtIMsfVew==} dependencies: '@types/react': 18.2.14 dev: false - /@types/react/16.14.43: + /@types/react@16.14.43: resolution: {integrity: sha512-7zdjv7jvoLLQg1tTvpQsm+hyNUMT2mPlNV1+d0I8fbGhkJl82spopMyBlu4wb1dviZAxpGdk5eHu/muacknnfw==} dependencies: '@types/prop-types': 15.7.5 @@ -7231,7 +7953,7 @@ packages: csstype: 3.1.2 dev: true - /@types/react/17.0.62: + /@types/react@17.0.62: resolution: {integrity: sha512-eANCyz9DG8p/Vdhr0ZKST8JV12PhH2ACCDYlFw6DIO+D+ca+uP4jtEDEpVqXZrh/uZdXQGwk7whJa3ah5DtyLw==} dependencies: '@types/prop-types': 15.7.5 @@ -7239,38 +7961,38 @@ packages: csstype: 3.1.2 dev: true - /@types/react/18.2.14: + /@types/react@18.2.14: resolution: {integrity: sha512-A0zjq+QN/O0Kpe30hA1GidzyFjatVvrpIvWLxD+xv67Vt91TWWgco9IvrJBkeyHm1trGaFS/FSGqPlhyeZRm0g==} dependencies: '@types/prop-types': 15.7.5 '@types/scheduler': 0.16.3 csstype: 3.1.2 - /@types/resolve/1.17.1: + /@types/resolve@1.17.1: resolution: {integrity: sha512-yy7HuzQhj0dhGpD8RLXSZWEkLsV9ibvxvi6EiJ3bkqLAO1RGo0WbkWQiwpRlSFymTJRz0d3k5LM3kkx8ArDbLw==} dependencies: '@types/node': 20.4.1 dev: true - /@types/resolve/1.20.2: + /@types/resolve@1.20.2: resolution: {integrity: sha512-60BCwRFOZCQhDncwQdxxeOEEkbc5dIMccYLwbxsS4TUNeVECQ/pBJ0j09mrHOl/JJvpRPGwO9SvE4nR2Nb/a4Q==} dev: true - /@types/scheduler/0.16.3: + /@types/scheduler@0.16.3: resolution: {integrity: sha512-5cJ8CB4yAx7BH1oMvdU0Jh9lrEXyPkar6F9G/ERswkCuvP4KQZfZkSjcMbAICCpQTN4OuZn8tz0HiKv9TGZgrQ==} - /@types/semver/7.5.0: + /@types/semver@7.5.0: resolution: {integrity: sha512-G8hZ6XJiHnuhQKR7ZmysCeJWE08o8T0AXtk5darsCaTVsYZhhgUrq53jizaR2FvsoeCwJhlmwTjkXBY5Pn/ZHw==} dev: true - /@types/send/0.17.1: + /@types/send@0.17.1: resolution: {integrity: sha512-Cwo8LE/0rnvX7kIIa3QHCkcuF21c05Ayb0ZfxPiv0W8VRiZiNW/WuRupHKpqqGVGf7SUA44QSOUKaEd9lIrd/Q==} dependencies: '@types/mime': 1.3.2 '@types/node': 20.4.1 dev: true - /@types/serve-static/1.15.2: + /@types/serve-static@1.15.2: resolution: {integrity: sha512-J2LqtvFYCzaj8pVYKw8klQXrLLk7TBZmQ4ShlcdkELFKGwGMfevMLneMMRkMgZxotOD9wg497LpC7O8PcvAmfw==} dependencies: '@types/http-errors': 2.0.1 @@ -7278,98 +8000,98 @@ packages: '@types/node': 20.4.1 dev: true - /@types/set-cookie-parser/2.4.2: + /@types/set-cookie-parser@2.4.2: resolution: {integrity: sha512-fBZgytwhYAUkj/jC/FAV4RQ5EerRup1YQsXQCh8rZfiHkc4UahC192oH0smGwsXol3cL3A5oETuAHeQHmhXM4w==} dependencies: '@types/node': 20.4.1 dev: true - /@types/sinonjs__fake-timers/8.1.1: + /@types/sinonjs__fake-timers@8.1.1: resolution: {integrity: sha512-0kSuKjAS0TrGLJ0M/+8MaFkGsQhZpB6pxOmvS3K8FYI72K//YmdfoW9X2qPsAKh1mkwxGD5zib9s1FIFed6E8g==} dev: true - /@types/sinonjs__fake-timers/8.1.2: + /@types/sinonjs__fake-timers@8.1.2: resolution: {integrity: sha512-9GcLXF0/v3t80caGs5p2rRfkB+a8VBGLJZVih6CNFkx8IZ994wiKKLSRs9nuFwk1HevWs/1mnUmkApGrSGsShA==} dev: true - /@types/sizzle/2.3.3: + /@types/sizzle@2.3.3: resolution: {integrity: sha512-JYM8x9EGF163bEyhdJBpR2QX1R5naCJHC8ucJylJ3w9/CVBaskdQ8WqBf8MmQrd1kRvp/a4TS8HJ+bxzR7ZJYQ==} dev: true - /@types/source-list-map/0.1.2: + /@types/source-list-map@0.1.2: resolution: {integrity: sha512-K5K+yml8LTo9bWJI/rECfIPrGgxdpeNbj+d53lwN4QjW1MCwlkhUms+gtdzigTeUyBr09+u8BwOIY3MXvHdcsA==} dev: true - /@types/stack-utils/2.0.1: + /@types/stack-utils@2.0.1: resolution: {integrity: sha512-Hl219/BT5fLAaz6NDkSuhzasy49dwQS/DSdu4MdggFB8zcXv7vflBI3xp7FEmkmdDkBUI2bPUNeMttp2knYdxw==} dev: true - /@types/tapable/1.0.8: + /@types/tapable@1.0.8: resolution: {integrity: sha512-ipixuVrh2OdNmauvtT51o3d8z12p6LtFW9in7U79der/kwejjdNchQC5UMn5u/KxNoM7VHHOs/l8KS8uHxhODQ==} dev: true - /@types/tern/0.23.4: + /@types/tern@0.23.4: resolution: {integrity: sha512-JAUw1iXGO1qaWwEOzxTKJZ/5JxVeON9kvGZ/osgZaJImBnyjyn0cjovPsf6FNLmyGY8Vw9DoXZCMlfMkMwHRWg==} dependencies: '@types/estree': 1.0.1 dev: true - /@types/testing-library__jest-dom/5.14.8: + /@types/testing-library__jest-dom@5.14.8: resolution: {integrity: sha512-NRfJE9Cgpmu4fx716q9SYmU4jxxhYRU1BQo239Txt/9N3EC745XZX1Yl7h/SBIDlo1ANVOCRB4YDXjaQdoKCHQ==} dependencies: '@types/jest': 29.5.3 dev: true - /@types/through/0.0.30: + /@types/through@0.0.30: resolution: {integrity: sha512-FvnCJljyxhPM3gkRgWmxmDZyAQSiBQQWLI0A0VFL0K7W1oRUrPJSqNO0NvTnLkBcotdlp3lKvaT0JrnyRDkzOg==} dependencies: '@types/node': 20.4.1 dev: true - /@types/tough-cookie/4.0.2: + /@types/tough-cookie@4.0.2: resolution: {integrity: sha512-Q5vtl1W5ue16D+nIaW8JWebSSraJVlK+EthKn7e7UcD4KWsaSJ8BqGPXNaPghgtcn/fhvrN17Tv8ksUsQpiplw==} dev: true - /@types/trusted-types/2.0.3: + /@types/trusted-types@2.0.3: resolution: {integrity: sha512-NfQ4gyz38SL8sDNrSixxU2Os1a5xcdFxipAFxYEuLUlvU2uDwS4NUpsImcf1//SlWItCVMMLiylsxbmNMToV/g==} - /@types/uglify-js/3.17.1: + /@types/uglify-js@3.17.1: resolution: {integrity: sha512-GkewRA4i5oXacU/n4MA9+bLgt5/L3F1mKrYvFGm7r2ouLXhRKjuWwo9XHNnbx6WF3vlGW21S3fCvgqxvxXXc5g==} dependencies: source-map: 0.6.1 dev: true - /@types/ungap__structured-clone/0.3.0: + /@types/ungap__structured-clone@0.3.0: resolution: {integrity: sha512-eBWREUhVUGPze+bUW22AgUr05k8u+vETzuYdLYSvWqGTUe0KOf+zVnOB1qER5wMcw8V6D9Ar4DfJmVvD1yu0kQ==} dev: true - /@types/unist/2.0.7: + /@types/unist@2.0.7: resolution: {integrity: sha512-cputDpIbFgLUaGQn6Vqg3/YsJwxUwHLO13v3i5ouxT4lat0khip9AEWxtERujXV9wxIB1EyF97BSJFt6vpdI8g==} dev: true - /@types/web-bluetooth/0.0.14: + /@types/web-bluetooth@0.0.14: resolution: {integrity: sha512-5d2RhCard1nQUC3aHcq/gHzWYO6K0WJmAbjO7mQJgCQKtZpgXxv1rOM6O/dBDhDYYVutk1sciOgNSe+5YyfM8A==} dev: false - /@types/web-bluetooth/0.0.17: + /@types/web-bluetooth@0.0.17: resolution: {integrity: sha512-4p9vcSmxAayx72yn70joFoL44c9MO/0+iVEBIQXe3v2h2SiAsEIo/G5v6ObFWvNKRFjbrVadNf9LqEEZeQPzdA==} - /@types/webpack-env/1.18.1: + /@types/webpack-env@1.18.1: resolution: {integrity: sha512-D0HJET2/UY6k9L6y3f5BL+IDxZmPkYmPT4+qBrRdmRLYRuV0qNKizMgTvYxXZYn+36zjPeoDZAEYBCM6XB+gww==} dev: true - /@types/webpack-sources/3.2.0: + /@types/webpack-sources@3.2.0: resolution: {integrity: sha512-Ft7YH3lEVRQ6ls8k4Ff1oB4jN6oy/XmU6tQISKdhfh+1mR+viZFphS6WL0IrtDOzvefmJg5a0s7ZQoRXwqTEFg==} dependencies: - '@types/node': 16.18.38 + '@types/node': 20.4.1 '@types/source-list-map': 0.1.2 source-map: 0.7.4 dev: true - /@types/webpack/4.41.33: + /@types/webpack@4.41.33: resolution: {integrity: sha512-PPajH64Ft2vWevkerISMtnZ8rTs4YmRbs+23c402J0INmxDKCrhZNvwZYtzx96gY2wAtXdrK1BS2fiC8MlLr3g==} dependencies: - '@types/node': 16.18.38 + '@types/node': 20.4.1 '@types/tapable': 1.0.8 '@types/uglify-js': 3.17.1 '@types/webpack-sources': 3.2.0 @@ -7377,33 +8099,39 @@ packages: source-map: 0.6.1 dev: true - /@types/which/2.0.2: + /@types/which@2.0.2: resolution: {integrity: sha512-113D3mDkZDjo+EeUEHCFy0qniNc1ZpecGiAU7WSo7YDoSzolZIQKpYFHrPpjkB2nuyahcKfrmLXeQlh7gqJYdw==} dev: true - /@types/ws/8.5.5: + /@types/ws@8.5.5: resolution: {integrity: sha512-lwhs8hktwxSjf9UaZ9tG5M03PGogvFaH8gUgLNbN9HKIg0dvv6q+gkSuJ8HN4/VbyxkuLzCjlN7GquQ0gUJfIg==} dependencies: '@types/node': 20.4.1 dev: true - /@types/yargs-parser/21.0.0: + /@types/yargs-parser@21.0.0: resolution: {integrity: sha512-iO9ZQHkZxHn4mSakYV0vFHAVDyEOIJQrV2uZ06HxEPcx+mt8swXoZHIbaaJ2crJYFfErySgktuTZ3BeLz+XmFA==} dev: true - /@types/yargs/15.0.15: + /@types/yargs@15.0.15: resolution: {integrity: sha512-IziEYMU9XoVj8hWg7k+UJrXALkGFjWJhn5QFEv9q4p+v40oZhSuC135M38st8XPjICL7Ey4TV64ferBGUoJhBg==} dependencies: '@types/yargs-parser': 21.0.0 dev: true - /@types/yargs/17.0.24: + /@types/yargs@16.0.5: + resolution: {integrity: sha512-AxO/ADJOBFJScHbWhq2xAhlWP24rY4aCEG/NFaMvbT3X2MgRsLjhjQwsn0Zi5zn0LG9jUhCCZMeX9Dkuw6k+vQ==} + dependencies: + '@types/yargs-parser': 21.0.0 + dev: true + + /@types/yargs@17.0.24: resolution: {integrity: sha512-6i0aC7jV6QzQB8ne1joVZ0eSFIstHsCrobmOtghM11yGlH0j43FKL2UhWdELkyps0zuf7qVTUVCCR+tgSlyLLw==} dependencies: '@types/yargs-parser': 21.0.0 dev: true - /@types/yauzl/2.10.0: + /@types/yauzl@2.10.0: resolution: {integrity: sha512-Cn6WYCm0tXv8p6k+A8PvbDG763EDpBoTzHdA+Q/MF6H3sapGjCm9NzoaJncJS9tUKSuCoDs9XHxYYsQDgxR6kw==} requiresBuild: true dependencies: @@ -7411,7 +8139,7 @@ packages: dev: true optional: true - /@typescript-eslint/eslint-plugin/5.62.0_l3h7p4bxv72z3fumgmc6kvfciu: + /@typescript-eslint/eslint-plugin@5.62.0(@typescript-eslint/parser@5.62.0)(eslint@8.44.0)(typescript@5.1.6): resolution: {integrity: sha512-TiZzBSJja/LbhNPvk6yc0JrX9XqhQ0hdh6M2svYfsHGejaKFIAGd9MQ+ERIMzLGlN/kZoYIgdxFV0PuljTKXag==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: @@ -7423,23 +8151,23 @@ packages: optional: true dependencies: '@eslint-community/regexpp': 4.5.1 - '@typescript-eslint/parser': 5.62.0_iqf7tbmerllfqanu4l3d6aqdn4 + '@typescript-eslint/parser': 5.62.0(eslint@8.44.0)(typescript@5.1.6) '@typescript-eslint/scope-manager': 5.62.0 - '@typescript-eslint/type-utils': 5.62.0_iqf7tbmerllfqanu4l3d6aqdn4 - '@typescript-eslint/utils': 5.62.0_iqf7tbmerllfqanu4l3d6aqdn4 - debug: 4.3.4 + '@typescript-eslint/type-utils': 5.62.0(eslint@8.44.0)(typescript@5.1.6) + '@typescript-eslint/utils': 5.62.0(eslint@8.44.0)(typescript@5.1.6) + debug: 4.3.4(supports-color@8.1.1) eslint: 8.44.0 graphemer: 1.4.0 ignore: 5.2.4 natural-compare-lite: 1.4.0 semver: 7.5.4 - tsutils: 3.21.0_typescript@5.1.6 + tsutils: 3.21.0(typescript@5.1.6) typescript: 5.1.6 transitivePeerDependencies: - supports-color dev: true - /@typescript-eslint/parser/5.62.0_iqf7tbmerllfqanu4l3d6aqdn4: + /@typescript-eslint/parser@5.62.0(eslint@8.44.0)(typescript@5.1.6): resolution: {integrity: sha512-VlJEV0fOQ7BExOsHYAGrgbEiZoi8D+Bl2+f6V2RrXerRSylnp+ZBHmPvaIa8cz0Ajx7WO7Z5RqfgYg7ED1nRhA==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: @@ -7451,15 +8179,15 @@ packages: dependencies: '@typescript-eslint/scope-manager': 5.62.0 '@typescript-eslint/types': 5.62.0 - '@typescript-eslint/typescript-estree': 5.62.0_typescript@5.1.6 - debug: 4.3.4 + '@typescript-eslint/typescript-estree': 5.62.0(typescript@5.1.6) + debug: 4.3.4(supports-color@8.1.1) eslint: 8.44.0 typescript: 5.1.6 transitivePeerDependencies: - supports-color dev: true - /@typescript-eslint/scope-manager/5.62.0: + /@typescript-eslint/scope-manager@5.62.0: resolution: {integrity: sha512-VXuvVvZeQCQb5Zgf4HAxc04q5j+WrNAtNh9OwCsCgpKqESMTu3tF/jhZ3xG6T4NZwWl65Bg8KuS2uEvhSfLl0w==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dependencies: @@ -7467,7 +8195,7 @@ packages: '@typescript-eslint/visitor-keys': 5.62.0 dev: true - /@typescript-eslint/type-utils/5.62.0_iqf7tbmerllfqanu4l3d6aqdn4: + /@typescript-eslint/type-utils@5.62.0(eslint@8.44.0)(typescript@5.1.6): resolution: {integrity: sha512-xsSQreu+VnfbqQpW5vnCJdq1Z3Q0U31qiWmRhr98ONQmcp/yhiPJFPq8MXiJVLiksmOKSjIldZzkebzHuCGzew==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: @@ -7477,22 +8205,22 @@ packages: typescript: optional: true dependencies: - '@typescript-eslint/typescript-estree': 5.62.0_typescript@5.1.6 - '@typescript-eslint/utils': 5.62.0_iqf7tbmerllfqanu4l3d6aqdn4 - debug: 4.3.4 + '@typescript-eslint/typescript-estree': 5.62.0(typescript@5.1.6) + '@typescript-eslint/utils': 5.62.0(eslint@8.44.0)(typescript@5.1.6) + debug: 4.3.4(supports-color@8.1.1) eslint: 8.44.0 - tsutils: 3.21.0_typescript@5.1.6 + tsutils: 3.21.0(typescript@5.1.6) typescript: 5.1.6 transitivePeerDependencies: - supports-color dev: true - /@typescript-eslint/types/5.62.0: + /@typescript-eslint/types@5.62.0: resolution: {integrity: sha512-87NVngcbVXUahrRTqIK27gD2t5Cu1yuCXxbLcFtCzZGlfyVWWh8mLHkoxzjsB6DDNnvdL+fW8MiwPEJyGJQDgQ==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dev: true - /@typescript-eslint/typescript-estree/5.62.0_typescript@5.1.6: + /@typescript-eslint/typescript-estree@5.62.0(typescript@5.1.6): resolution: {integrity: sha512-CmcQ6uY7b9y694lKdRB8FEel7JbU/40iSAPomu++SjLMntB+2Leay2LO6i8VnJk58MtE9/nQSFIH6jpyRWyYzA==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: @@ -7503,28 +8231,28 @@ packages: dependencies: '@typescript-eslint/types': 5.62.0 '@typescript-eslint/visitor-keys': 5.62.0 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) globby: 11.1.0 is-glob: 4.0.3 semver: 7.5.4 - tsutils: 3.21.0_typescript@5.1.6 + tsutils: 3.21.0(typescript@5.1.6) typescript: 5.1.6 transitivePeerDependencies: - supports-color dev: true - /@typescript-eslint/utils/5.62.0_iqf7tbmerllfqanu4l3d6aqdn4: + /@typescript-eslint/utils@5.62.0(eslint@8.44.0)(typescript@5.1.6): resolution: {integrity: sha512-n8oxjeb5aIbPFEtmQxQYOLI0i9n5ySBEY/ZEHHZqKQSFnxio1rv6dthascc9dLuwrL0RC5mPCxB7vnAVGAYWAQ==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: eslint: ^6.0.0 || ^7.0.0 || ^8.0.0 dependencies: - '@eslint-community/eslint-utils': 4.4.0_eslint@8.44.0 + '@eslint-community/eslint-utils': 4.4.0(eslint@8.44.0) '@types/json-schema': 7.0.12 '@types/semver': 7.5.0 '@typescript-eslint/scope-manager': 5.62.0 '@typescript-eslint/types': 5.62.0 - '@typescript-eslint/typescript-estree': 5.62.0_typescript@5.1.6 + '@typescript-eslint/typescript-estree': 5.62.0(typescript@5.1.6) eslint: 8.44.0 eslint-scope: 5.1.1 semver: 7.5.4 @@ -7533,7 +8261,7 @@ packages: - typescript dev: true - /@typescript-eslint/visitor-keys/5.62.0: + /@typescript-eslint/visitor-keys@5.62.0: resolution: {integrity: sha512-07ny+LHRzQXepkGg6w0mFY41fVUNBrL2Roj/++7V1txKugfjm/Ci/qSND03r2RhlJhJYMcTn9AhhSSqQp0Ysyw==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dependencies: @@ -7541,28 +8269,61 @@ packages: eslint-visitor-keys: 3.4.1 dev: true - /@ungap/structured-clone/1.2.0: + /@ungap/structured-clone@1.2.0: resolution: {integrity: sha512-zuVdFrMJiuCDQUMCzQaD6KL28MjnqqN8XnAqiEq9PNm/hCPTSGfrXCOfwj1ow4LFb/tNymJPwsNbVePc1xFqrQ==} dev: true - /@unocss/astro/0.53.5_vite@4.4.3: + /@unocss/astro@0.53.5(rollup@2.79.1)(vite@4.4.3): + resolution: {integrity: sha512-W4A0uIN4xAzVH6Vwf5ukG8rJpCeIwQZcpZPrEBWsqY5YcHZcLTFGMHcNmxyeG0qoXpXoxtvHyXXhgGU0BY5ZEw==} + dependencies: + '@unocss/core': 0.53.5 + '@unocss/reset': 0.53.5 + '@unocss/vite': 0.53.5(rollup@2.79.1)(vite@4.4.3) + transitivePeerDependencies: + - rollup + - vite + dev: true + + /@unocss/astro@0.53.5(rollup@3.26.2)(vite@4.4.3): resolution: {integrity: sha512-W4A0uIN4xAzVH6Vwf5ukG8rJpCeIwQZcpZPrEBWsqY5YcHZcLTFGMHcNmxyeG0qoXpXoxtvHyXXhgGU0BY5ZEw==} dependencies: '@unocss/core': 0.53.5 '@unocss/reset': 0.53.5 - '@unocss/vite': 0.53.5_vite@4.4.3 + '@unocss/vite': 0.53.5(rollup@3.26.2)(vite@4.4.3) transitivePeerDependencies: - rollup - vite dev: true - /@unocss/cli/0.53.5: + /@unocss/cli@0.53.5(rollup@2.79.1): + resolution: {integrity: sha512-UKi+9BAKh3X5eM4pPQviXMOtN8JkQWKdGy/056rRLQysPB07VBwWr5gYAlJMMJ2wFAIthag43X5I8btQAicFkg==} + engines: {node: '>=14'} + hasBin: true + dependencies: + '@ampproject/remapping': 2.2.1 + '@rollup/pluginutils': 5.0.2(rollup@2.79.1) + '@unocss/config': 0.53.5 + '@unocss/core': 0.53.5 + '@unocss/preset-uno': 0.53.5 + cac: 6.7.14 + chokidar: 3.5.3 + colorette: 2.0.20 + consola: 3.2.3 + fast-glob: 3.3.0 + magic-string: 0.30.1 + pathe: 1.1.1 + perfect-debounce: 1.0.0 + transitivePeerDependencies: + - rollup + dev: true + + /@unocss/cli@0.53.5(rollup@3.26.2): resolution: {integrity: sha512-UKi+9BAKh3X5eM4pPQviXMOtN8JkQWKdGy/056rRLQysPB07VBwWr5gYAlJMMJ2wFAIthag43X5I8btQAicFkg==} engines: {node: '>=14'} hasBin: true dependencies: '@ampproject/remapping': 2.2.1 - '@rollup/pluginutils': 5.0.2 + '@rollup/pluginutils': 5.0.2(rollup@3.26.2) '@unocss/config': 0.53.5 '@unocss/core': 0.53.5 '@unocss/preset-uno': 0.53.5 @@ -7578,7 +8339,7 @@ packages: - rollup dev: true - /@unocss/config/0.53.5: + /@unocss/config@0.53.5: resolution: {integrity: sha512-YtpWoIFB1V8Dp3KcVQqislQYQSSBYbjTpoVIkUGrpupwOz9+W1tfL2yKEENDiZc11crJSneGr04wsP2dI1ld0w==} engines: {node: '>=14'} dependencies: @@ -7586,26 +8347,28 @@ packages: unconfig: 0.3.9 dev: true - /@unocss/core/0.53.5: + /@unocss/core@0.53.5: resolution: {integrity: sha512-jBvk4FeUAALAomGfMFFmrXLy01/5DjugdnWgawFAQpSToFTxbMHS7x+pXKu/18cq+YLS8uyl9S0Ywy1jNbfS3Q==} dev: true - /@unocss/extractor-arbitrary-variants/0.53.5: + /@unocss/extractor-arbitrary-variants@0.53.5: resolution: {integrity: sha512-rSS3Q8/+lEwxXfXzEOFuhAQGMpaaZcBAYDiNCYS/9BqKrTzhSYG82Qy80ISpqSZr0BTLET4X3dC6B6Rd4GU5vQ==} dependencies: '@unocss/core': 0.53.5 dev: true - /@unocss/inspector/0.53.5: + /@unocss/inspector@0.53.5: resolution: {integrity: sha512-gWUhgsoB3LyjIAdw6n/eMcLGmUNwuSTrgwcRubIDFhHOC5/E6ppdUQmS8a4oH4qjunfvBgoTHwcGlXvlvb3S5w==} dependencies: gzip-size: 6.0.0 sirv: 2.0.3 dev: true - /@unocss/postcss/0.53.5: + /@unocss/postcss@0.53.5(postcss@8.4.25): resolution: {integrity: sha512-IfZl4GxrpegP/861bp3e0X3VcQJ9/M3VxC9UQ7zzxkOz/E8R09iMpbnznVLrTiLp2r96p5k/ggXLoadFm1FxGA==} engines: {node: '>=14'} + peerDependencies: + postcss: ^8.4.21 dependencies: '@unocss/config': 0.53.5 '@unocss/core': 0.53.5 @@ -7615,13 +8378,13 @@ packages: postcss: 8.4.25 dev: true - /@unocss/preset-attributify/0.53.5: + /@unocss/preset-attributify@0.53.5: resolution: {integrity: sha512-0TJD9hVUWu0T4dtdURApyFiliqbckYYGZe2PZBgUrHCypbI0zq7k3MdXFYmIuYxqDPErJVm8rO9lwMpKfTsvuA==} dependencies: '@unocss/core': 0.53.5 dev: true - /@unocss/preset-icons/0.53.5: + /@unocss/preset-icons@0.53.5: resolution: {integrity: sha512-zlO0fLJiJtITta3BnE3y5Yc0hajjovCB/woos4MR5gvcFXHW9Hfy7pXuj90GvHLfaRj0JRWXa1WRaqJXS4tzOw==} dependencies: '@iconify/utils': 2.1.7 @@ -7631,27 +8394,27 @@ packages: - supports-color dev: true - /@unocss/preset-mini/0.53.5: + /@unocss/preset-mini@0.53.5: resolution: {integrity: sha512-aeVctTW0M41RXyCyQvhRawIh+ylhl7mlWfAjv7cP3ALvIRWbB6jUw1C8Ke6rU2vg0s0yaJKRuFPFmLMqGwzoSg==} dependencies: '@unocss/core': 0.53.5 '@unocss/extractor-arbitrary-variants': 0.53.5 dev: true - /@unocss/preset-tagify/0.53.5: + /@unocss/preset-tagify@0.53.5: resolution: {integrity: sha512-0HpWU85Pz1RbFqf/QtlP992ISSqWZ3JT2rWI7ekBLai463ptdBUks/PfH22M+uBSwPig5XNJ0DtyS7hm8TEWhg==} dependencies: '@unocss/core': 0.53.5 dev: true - /@unocss/preset-typography/0.53.5: + /@unocss/preset-typography@0.53.5: resolution: {integrity: sha512-roZXiJ14wuXcpLN5YodAN1wKYlwCDJ8L/TQlUphyM487i0QbKwXAZg8dA1SWCQIl5V9Qcq/3EXAQmLnhRdwBMA==} dependencies: '@unocss/core': 0.53.5 '@unocss/preset-mini': 0.53.5 dev: true - /@unocss/preset-uno/0.53.5: + /@unocss/preset-uno@0.53.5: resolution: {integrity: sha512-DRJMBkSqfz0EOzf5cwefkPF8J6lNvrhBp4ztw9blewDc2wTQqL/lAj/I/nbyOdXhJUOxhj/qj7gJjsNZctud0A==} dependencies: '@unocss/core': 0.53.5 @@ -7659,66 +8422,86 @@ packages: '@unocss/preset-wind': 0.53.5 dev: true - /@unocss/preset-web-fonts/0.53.5: + /@unocss/preset-web-fonts@0.53.5: resolution: {integrity: sha512-yVkOOECyOQqahRGSefcBKtNYAUnYFqqFedGy0SBBjadPWn80vjVg7ojljKlJsgSQdrpcJ38wwWr3Oh4UWwBuQQ==} dependencies: '@unocss/core': 0.53.5 ofetch: 1.1.1 dev: true - /@unocss/preset-wind/0.53.5: + /@unocss/preset-wind@0.53.5: resolution: {integrity: sha512-hSMF11Gx8oMDtePvXLmpArSNpQRHb098P8+qYpwvyNfS29i6agfjGBuIDk/f+j8mhqcfrEEuEmPIl2yojT9nxA==} dependencies: '@unocss/core': 0.53.5 '@unocss/preset-mini': 0.53.5 dev: true - /@unocss/reset/0.53.5: + /@unocss/reset@0.53.5: resolution: {integrity: sha512-tH8K4jw76mbWA67UUHKV6zxiwOsiG+byrHoG3lz8hr+cm6OgEJ3WjNNp7dZINmr7S7ylWO6igbxGQpsAuIQZCw==} dev: true - /@unocss/scope/0.53.5: + /@unocss/scope@0.53.5: resolution: {integrity: sha512-KBwemWNJIbu3+BWp0X4o5ERN0/nzF7hXBnjYNSb0s8phrydC6oJrp52XYlIHHTe7O4KzwkqGgf/xOMXMFpviDg==} dev: true - /@unocss/transformer-attributify-jsx-babel/0.53.5: + /@unocss/transformer-attributify-jsx-babel@0.53.5: resolution: {integrity: sha512-z9ar2IaZmcNVTZhK9ZuRUd3LqA/iUG/JMF0OA92RNclo8SazWdu7eJAdV86SHXqAf7eSB/t0evsde14DtEREjA==} dependencies: '@unocss/core': 0.53.5 dev: true - /@unocss/transformer-attributify-jsx/0.53.5: + /@unocss/transformer-attributify-jsx@0.53.5: resolution: {integrity: sha512-ynAElIi9DxtHyKCW+OXPcLxje2ghVzKo80eaAVRAdVpyawsjtE4iHWjHRbESkiTsHW5CiJupdXo2vx1obXFLnQ==} dependencies: '@unocss/core': 0.53.5 dev: true - /@unocss/transformer-compile-class/0.53.5: + /@unocss/transformer-compile-class@0.53.5: resolution: {integrity: sha512-7Z0/40T4EuHMGpXb2XlamkResaASMRm07csCl7REGUTg9ccDRWlnSLzGD8UUgKoygsmqXp2cxKMJLMb5YJ9LLA==} dependencies: '@unocss/core': 0.53.5 dev: true - /@unocss/transformer-directives/0.53.5: + /@unocss/transformer-directives@0.53.5: resolution: {integrity: sha512-u1OIZZUAXux9Q0mb58X3infxY2Iq6pY7uJB7IhMc2I1ntpyx875spwyvvfUHqOgIPTNR4XxfxKFGPHpjPNbNeQ==} dependencies: '@unocss/core': 0.53.5 css-tree: 2.3.1 dev: true - /@unocss/transformer-variant-group/0.53.5: + /@unocss/transformer-variant-group@0.53.5: resolution: {integrity: sha512-+xDx6JojGkcKwx87sX0y4xM/RuTI0QyPJAKebXUSyuKnctXrTH/p+WNGFIVWiY8suUMnnMesAZpw6O2Oln921w==} dependencies: '@unocss/core': 0.53.5 dev: true - /@unocss/vite/0.53.5_vite@4.4.3: + /@unocss/vite@0.53.5(rollup@2.79.1)(vite@4.4.3): + resolution: {integrity: sha512-ez0MVRatewLUQq79LI+XRAVRbXWaGbK1K1ht2B8vGyL9OrL6uieEwzxjHV7+rUa8i+FEHfD4Ntmtdpb3WuQSAA==} + peerDependencies: + vite: ^2.9.0 || ^3.0.0-0 || ^4.0.0 + dependencies: + '@ampproject/remapping': 2.2.1 + '@rollup/pluginutils': 5.0.2(rollup@2.79.1) + '@unocss/config': 0.53.5 + '@unocss/core': 0.53.5 + '@unocss/inspector': 0.53.5 + '@unocss/scope': 0.53.5 + '@unocss/transformer-directives': 0.53.5 + chokidar: 3.5.3 + fast-glob: 3.3.0 + magic-string: 0.30.1 + vite: 4.4.3(@types/node@18.16.19) + transitivePeerDependencies: + - rollup + dev: true + + /@unocss/vite@0.53.5(rollup@3.26.2)(vite@4.4.3): resolution: {integrity: sha512-ez0MVRatewLUQq79LI+XRAVRbXWaGbK1K1ht2B8vGyL9OrL6uieEwzxjHV7+rUa8i+FEHfD4Ntmtdpb3WuQSAA==} peerDependencies: vite: ^2.9.0 || ^3.0.0-0 || ^4.0.0 dependencies: '@ampproject/remapping': 2.2.1 - '@rollup/pluginutils': 5.0.2 + '@rollup/pluginutils': 5.0.2(rollup@3.26.2) '@unocss/config': 0.53.5 '@unocss/core': 0.53.5 '@unocss/inspector': 0.53.5 @@ -7727,12 +8510,12 @@ packages: chokidar: 3.5.3 fast-glob: 3.3.0 magic-string: 0.30.1 - vite: 4.4.3 + vite: 4.4.3(@types/node@18.16.19) transitivePeerDependencies: - rollup dev: true - /@vite-pwa/assets-generator/0.0.3: + /@vite-pwa/assets-generator@0.0.3: resolution: {integrity: sha512-rGjzFTGAZsY9fIf9qGbvXbo38Yj0MbAtTxAaL/GBlEU0+q/m6upw+4HKE58p2MnjUAOOBHf0871u3onHtkPWlQ==} engines: {node: '>=16.14.0'} hasBin: true @@ -7745,23 +8528,23 @@ packages: unconfig: 0.3.9 dev: true - /@vite-pwa/vitepress/0.2.0_vite-plugin-pwa@0.16.4: + /@vite-pwa/vitepress@0.2.0(vite-plugin-pwa@0.16.4): resolution: {integrity: sha512-dVQVaP6NB9woCFe4UASUqRp7uwBQJOVXlJlqK4krqXcbb3NuXIXIWOnU7HLpJnHqZj5U/81gKtLN6gs5gJBwiQ==} peerDependencies: vite-plugin-pwa: '>=0.16.3 <1' dependencies: - vite-plugin-pwa: 0.16.4_cqwyifvz3q2qdw6r4piqd2mqaa + vite-plugin-pwa: 0.16.4(vite@4.4.3)(workbox-build@7.0.0)(workbox-window@7.0.0) dev: true - /@vitejs/plugin-react/1.3.2: + /@vitejs/plugin-react@1.3.2: resolution: {integrity: sha512-aurBNmMo0kz1O4qRoY+FM4epSA39y3ShWGuqfLRA/3z0oEJAdtoSfgA3aO98/PCCHAqMaduLxIxErWrVKIFzXA==} engines: {node: '>=12.0.0'} dependencies: '@babel/core': 7.22.8 - '@babel/plugin-transform-react-jsx': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-react-jsx-development': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-react-jsx-self': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-react-jsx-source': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-react-jsx': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-react-jsx-development': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-react-jsx-self': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-react-jsx-source': 7.22.5(@babel/core@7.22.8) '@rollup/pluginutils': 4.2.1 react-refresh: 0.13.0 resolve: 1.22.2 @@ -7769,36 +8552,22 @@ packages: - supports-color dev: true - /@vitejs/plugin-react/4.0.3: - resolution: {integrity: sha512-pwXDog5nwwvSIzwrvYYmA2Ljcd/ZNlcsSG2Q9CNDBwnsd55UGAyr2doXtB5j+2uymRCnCfExlznzzSFbBRcoCg==} - engines: {node: ^14.18.0 || >=16.0.0} - peerDependencies: - vite: ^4.2.0 - dependencies: - '@babel/core': 7.22.8 - '@babel/plugin-transform-react-jsx-self': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-react-jsx-source': 7.22.5_@babel+core@7.22.8 - react-refresh: 0.14.0 - transitivePeerDependencies: - - supports-color - dev: true - - /@vitejs/plugin-react/4.0.3_vite@4.4.3: + /@vitejs/plugin-react@4.0.3(vite@4.4.3): resolution: {integrity: sha512-pwXDog5nwwvSIzwrvYYmA2Ljcd/ZNlcsSG2Q9CNDBwnsd55UGAyr2doXtB5j+2uymRCnCfExlznzzSFbBRcoCg==} engines: {node: ^14.18.0 || >=16.0.0} peerDependencies: vite: ^4.2.0 dependencies: '@babel/core': 7.22.8 - '@babel/plugin-transform-react-jsx-self': 7.22.5_@babel+core@7.22.8 - '@babel/plugin-transform-react-jsx-source': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-transform-react-jsx-self': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-react-jsx-source': 7.22.5(@babel/core@7.22.8) react-refresh: 0.14.0 - vite: 4.4.3 + vite: 4.4.3(@types/node@20.4.1) transitivePeerDependencies: - supports-color dev: true - /@vitejs/plugin-vue-jsx/3.0.1_vite@4.4.3+vue@3.3.4: + /@vitejs/plugin-vue-jsx@3.0.1(vite@4.4.3)(vue@3.3.4): resolution: {integrity: sha512-+Jb7ggL48FSPS1uhPnJbJwWa9Sr90vQ+d0InW+AhBM22n+cfuYqJZDckBc+W3QSHe1WDvewMZfa4wZOtk5pRgw==} engines: {node: ^14.18.0 || >=16.0.0} peerDependencies: @@ -7806,55 +8575,55 @@ packages: vue: ^3.0.0 dependencies: '@babel/core': 7.22.8 - '@babel/plugin-transform-typescript': 7.22.5_@babel+core@7.22.8 - '@vue/babel-plugin-jsx': 1.1.5_@babel+core@7.22.8 - vite: 4.4.3 + '@babel/plugin-transform-typescript': 7.22.5(@babel/core@7.22.8) + '@vue/babel-plugin-jsx': 1.1.5(@babel/core@7.22.8) + vite: 4.4.3(@types/node@18.16.19) vue: 3.3.4 transitivePeerDependencies: - supports-color dev: true - /@vitejs/plugin-vue/4.2.3_vite@4.4.3+vue@3.3.4: - resolution: {integrity: sha512-R6JDUfiZbJA9cMiguQ7jxALsgiprjBeHL5ikpXfJCH62pPHtI+JdJ5xWj6Ev73yXSlYl86+blXn1kZHQ7uElxw==} - engines: {node: ^14.18.0 || >=16.0.0} - peerDependencies: - vite: ^4.0.0 - vue: ^3.2.25 - dependencies: - vite: 4.4.3 - vue: 3.3.4 - dev: true - - /@vitejs/plugin-vue2/1.1.2_vite@4.4.3+vue@2.7.14: + /@vitejs/plugin-vue2@1.1.2(vite@4.4.3)(vue@2.7.14): resolution: {integrity: sha512-y6OEA+2UdJ0xrEQHodq20v9r3SpS62IOHrgN92JPLvVpNkhcissu7yvD5PXMzMESyazj0XNWGsc8UQk8+mVrjQ==} engines: {node: '>=14.6.0'} peerDependencies: vite: '>=2.5.10' vue: ^2.7.0-0 dependencies: - vite: 4.4.3 + vite: 4.4.3(@types/node@18.16.19) vue: 2.7.14 dev: true - /@volar/code-gen/0.40.13: + /@vitejs/plugin-vue@4.2.3(vite@4.4.3)(vue@3.3.4): + resolution: {integrity: sha512-R6JDUfiZbJA9cMiguQ7jxALsgiprjBeHL5ikpXfJCH62pPHtI+JdJ5xWj6Ev73yXSlYl86+blXn1kZHQ7uElxw==} + engines: {node: ^14.18.0 || >=16.0.0} + peerDependencies: + vite: ^4.0.0 + vue: ^3.2.25 + dependencies: + vite: 4.4.3(@types/node@18.16.19) + vue: 3.3.4 + dev: true + + /@volar/code-gen@0.40.13: resolution: {integrity: sha512-4gShBWuMce868OVvgyA1cU5WxHbjfEme18Tw6uVMfweZCF5fB2KECG0iPrA9D54vHk3FeHarODNwgIaaFfUBlA==} dependencies: '@volar/source-map': 0.40.13 dev: true - /@volar/source-map/0.40.13: + /@volar/source-map@0.40.13: resolution: {integrity: sha512-dbdkAB2Nxb0wLjAY5O64o3ywVWlAGONnBIoKAkXSf6qkGZM+nJxcizsoiI66K+RHQG0XqlyvjDizfnTxr+6PWg==} dependencies: '@vue/reactivity': 3.2.38 dev: true - /@volar/typescript-faster/0.40.13: + /@volar/typescript-faster@0.40.13: resolution: {integrity: sha512-uy+TlcFkKoNlKEnxA4x5acxdxLyVDIXGSc8cYDNXpPKjBKXrQaetzCzlO3kVBqu1VLMxKNGJMTKn35mo+ILQmw==} dependencies: semver: 7.5.4 dev: true - /@volar/vue-language-core/0.40.13: + /@volar/vue-language-core@0.40.13: resolution: {integrity: sha512-QkCb8msi2KUitTdM6Y4kAb7/ZlEvuLcbBFOC2PLBlFuoZwyxvSP7c/dBGmKGtJlEvMX0LdCyrg5V2aBYxD38/Q==} dependencies: '@volar/code-gen': 0.40.13 @@ -7866,7 +8635,7 @@ packages: '@vue/shared': 3.3.4 dev: true - /@volar/vue-typescript/0.40.13: + /@volar/vue-typescript@0.40.13: resolution: {integrity: sha512-o7bNztwjs8JmbQjVkrnbZUOfm7q4B8ZYssETISN1tRaBdun6cfNqgpkvDYd+VUBh1O4CdksvN+5BUNnwAz4oCQ==} dependencies: '@volar/code-gen': 0.40.13 @@ -7874,18 +8643,18 @@ packages: '@volar/vue-language-core': 0.40.13 dev: true - /@vue/babel-helper-vue-transform-on/1.1.5: + /@vue/babel-helper-vue-transform-on@1.1.5: resolution: {integrity: sha512-SgUymFpMoAyWeYWLAY+MkCK3QEROsiUnfaw5zxOVD/M64KQs8D/4oK6Q5omVA2hnvEOE0SCkH2TZxs/jnnUj7w==} dev: true - /@vue/babel-plugin-jsx/1.1.5_@babel+core@7.22.8: + /@vue/babel-plugin-jsx@1.1.5(@babel/core@7.22.8): resolution: {integrity: sha512-nKs1/Bg9U1n3qSWnsHhCVQtAzI6aQXqua8j/bZrau8ywT1ilXQbK4FwEJGmU8fV7tcpuFvWmmN7TMmV1OBma1g==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: '@babel/core': 7.22.8 '@babel/helper-module-imports': 7.22.5 - '@babel/plugin-syntax-jsx': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-syntax-jsx': 7.22.5(@babel/core@7.22.8) '@babel/template': 7.22.5 '@babel/traverse': 7.22.8 '@babel/types': 7.22.5 @@ -7897,7 +8666,7 @@ packages: - supports-color dev: true - /@vue/compiler-core/3.3.4: + /@vue/compiler-core@3.3.4: resolution: {integrity: sha512-cquyDNvZ6jTbf/+x+AgM2Arrp6G4Dzbb0R64jiG804HRMfRiFXWI6kqUVqZ6ZR0bQhIoQjB4+2bhNtVwndW15g==} dependencies: '@babel/parser': 7.22.7 @@ -7905,20 +8674,20 @@ packages: estree-walker: 2.0.2 source-map-js: 1.0.2 - /@vue/compiler-dom/3.3.4: + /@vue/compiler-dom@3.3.4: resolution: {integrity: sha512-wyM+OjOVpuUukIq6p5+nwHYtj9cFroz9cwkfmP9O1nzH68BenTTv0u7/ndggT8cIQlnBeOo6sUT/gvHcIkLA5w==} dependencies: '@vue/compiler-core': 3.3.4 '@vue/shared': 3.3.4 - /@vue/compiler-sfc/2.7.14: + /@vue/compiler-sfc@2.7.14: resolution: {integrity: sha512-aNmNHyLPsw+sVvlQFQ2/8sjNuLtK54TC6cuKnVzAY93ks4ZBrvwQSnkkIh7bsbNhum5hJBS00wSDipQ937f5DA==} dependencies: '@babel/parser': 7.22.7 postcss: 8.4.25 source-map: 0.6.1 - /@vue/compiler-sfc/3.3.4: + /@vue/compiler-sfc@3.3.4: resolution: {integrity: sha512-6y/d8uw+5TkCuzBkgLS0v3lSM3hJDntFEiUORM11pQ/hKvkhSKZrXW6i69UyXlJQisJxuUEJKAWEqWbWsLeNKQ==} dependencies: '@babel/parser': 7.22.7 @@ -7932,17 +8701,17 @@ packages: postcss: 8.4.25 source-map-js: 1.0.2 - /@vue/compiler-ssr/3.3.4: + /@vue/compiler-ssr@3.3.4: resolution: {integrity: sha512-m0v6oKpup2nMSehwA6Uuu+j+wEwcy7QmwMkVNVfrV9P2qE5KshC6RwOCq8fjGS/Eak/uNb8AaWekfiXxbBB6gQ==} dependencies: '@vue/compiler-dom': 3.3.4 '@vue/shared': 3.3.4 - /@vue/devtools-api/6.5.0: + /@vue/devtools-api@6.5.0: resolution: {integrity: sha512-o9KfBeaBmCKl10usN4crU53fYtC1r7jJwdGKjPT24t348rHxgfpZ0xL3Xm/gLUYnc0oTp8LAmrxOeLyu6tbk2Q==} dev: true - /@vue/reactivity-transform/3.3.4: + /@vue/reactivity-transform@3.3.4: resolution: {integrity: sha512-MXgwjako4nu5WFLAjpBnCj/ieqcjE2aJBINUNQzkZQfzIZA4xn+0fV1tIYBJvvva3N3OvKGofRLvQIwEQPpaXw==} dependencies: '@babel/parser': 7.22.7 @@ -7951,31 +8720,31 @@ packages: estree-walker: 2.0.2 magic-string: 0.30.1 - /@vue/reactivity/3.2.38: + /@vue/reactivity@3.2.38: resolution: {integrity: sha512-6L4myYcH9HG2M25co7/BSo0skKFHpAN8PhkNPM4xRVkyGl1K5M3Jx4rp5bsYhvYze2K4+l+pioN4e6ZwFLUVtw==} dependencies: '@vue/shared': 3.2.38 dev: true - /@vue/reactivity/3.3.4: + /@vue/reactivity@3.3.4: resolution: {integrity: sha512-kLTDLwd0B1jG08NBF3R5rqULtv/f8x3rOFByTDz4J53ttIQEDmALqKqXY0J+XQeN0aV2FBxY8nJDf88yvOPAqQ==} dependencies: '@vue/shared': 3.3.4 - /@vue/runtime-core/3.3.4: + /@vue/runtime-core@3.3.4: resolution: {integrity: sha512-R+bqxMN6pWO7zGI4OMlmvePOdP2c93GsHFM/siJI7O2nxFRzj55pLwkpCedEY+bTMgp5miZ8CxfIZo3S+gFqvA==} dependencies: '@vue/reactivity': 3.3.4 '@vue/shared': 3.3.4 - /@vue/runtime-dom/3.3.4: + /@vue/runtime-dom@3.3.4: resolution: {integrity: sha512-Aj5bTJ3u5sFsUckRghsNjVTtxZQ1OyMWCr5dZRAPijF/0Vy4xEoRCwLyHXcj4D0UFbJ4lbx3gPTgg06K/GnPnQ==} dependencies: '@vue/runtime-core': 3.3.4 '@vue/shared': 3.3.4 csstype: 3.1.2 - /@vue/server-renderer/3.3.4_vue@3.3.4: + /@vue/server-renderer@3.3.4(vue@3.3.4): resolution: {integrity: sha512-Q6jDDzR23ViIb67v+vM1Dqntu+HUexQcsWKhhQa4ARVzxOY2HbC7QRW/ggkDBd5BU+uM1sV6XOAP0b216o34JQ==} peerDependencies: vue: 3.3.4 @@ -7984,14 +8753,14 @@ packages: '@vue/shared': 3.3.4 vue: 3.3.4 - /@vue/shared/3.2.38: + /@vue/shared@3.2.38: resolution: {integrity: sha512-dTyhTIRmGXBjxJE+skC8tTWCGLCVc4wQgRRLt8+O9p5ewBAjoBwtCAkLPrtToSr1xltoe3st21Pv953aOZ7alg==} dev: true - /@vue/shared/3.3.4: + /@vue/shared@3.3.4: resolution: {integrity: sha512-7OjdcV8vQ74eiz1TZLzZP4JwqM5fA94K6yntPS5Z25r9HDuGNzaGdgvwKYq6S+MxwF0TFRwe50fIR/MYnakdkQ==} - /@vue/test-utils/1.3.6_rhqkolmkwunxzlyyxxsuwaiuri: + /@vue/test-utils@1.3.6(vue-template-compiler@2.7.14)(vue@2.7.14): resolution: {integrity: sha512-udMmmF1ts3zwxUJEIAj5ziioR900reDrt6C9H3XpWPsLBx2lpHKoA4BTdd9HNIYbkGltWw+JjWJ+5O6QBwiyEw==} peerDependencies: vue: 2.x @@ -8004,7 +8773,7 @@ packages: vue-template-compiler: 2.7.14 dev: true - /@vue/test-utils/2.4.0_vue@3.3.4: + /@vue/test-utils@2.4.0(vue@3.3.4): resolution: {integrity: sha512-BKB9aj1yky63/I3IwSr1FjUeHYsKXI7D6S9F378AHt7a5vC0dLkOBtSsFXoRGC/7BfHmiB9HRhT+i9xrUHoAKw==} peerDependencies: '@vue/compiler-dom': ^3.0.1 @@ -8021,18 +8790,18 @@ packages: vue-component-type-helpers: 1.6.5 dev: true - /@vueuse/core/10.2.1_vue@3.3.4: + /@vueuse/core@10.2.1(vue@3.3.4): resolution: {integrity: sha512-c441bfMbkAwTNwVRHQ0zdYZNETK//P84rC01aP2Uy/aRFCiie9NE/k9KdIXbno0eDYP5NPUuWv0aA/I4Unr/7w==} dependencies: '@types/web-bluetooth': 0.0.17 '@vueuse/metadata': 10.2.1 - '@vueuse/shared': 10.2.1_vue@3.3.4 - vue-demi: 0.14.5_vue@3.3.4 + '@vueuse/shared': 10.2.1(vue@3.3.4) + vue-demi: 0.14.5(vue@3.3.4) transitivePeerDependencies: - '@vue/composition-api' - vue - /@vueuse/core/8.9.4_vue@3.3.4: + /@vueuse/core@8.9.4(vue@3.3.4): resolution: {integrity: sha512-B/Mdj9TK1peFyWaPof+Zf/mP9XuGAngaJZBwPaXBvU3aCTZlx3ltlrFFFyMV4iGBwsjSCeUCgZrtkEj9dS2Y3Q==} peerDependencies: '@vue/composition-api': ^1.1.0 @@ -8045,12 +8814,12 @@ packages: dependencies: '@types/web-bluetooth': 0.0.14 '@vueuse/metadata': 8.9.4 - '@vueuse/shared': 8.9.4_vue@3.3.4 + '@vueuse/shared': 8.9.4(vue@3.3.4) vue: 3.3.4 - vue-demi: 0.14.5_vue@3.3.4 + vue-demi: 0.14.5(vue@3.3.4) dev: false - /@vueuse/integrations/10.2.1_focus-trap@7.5.2+vue@3.3.4: + /@vueuse/integrations@10.2.1(focus-trap@7.5.2)(vue@3.3.4): resolution: {integrity: sha512-FDP5lni+z9FjHE9H3xuvwSjoRV9U8jmDvJpmHPCBjUgPGYRynwb60eHWXCFJXLUtb4gSIHy0e+iaEbrKdalCkQ==} peerDependencies: async-validator: '*' @@ -8091,16 +8860,16 @@ packages: universal-cookie: optional: true dependencies: - '@vueuse/core': 10.2.1_vue@3.3.4 - '@vueuse/shared': 10.2.1_vue@3.3.4 + '@vueuse/core': 10.2.1(vue@3.3.4) + '@vueuse/shared': 10.2.1(vue@3.3.4) focus-trap: 7.5.2 - vue-demi: 0.14.5_vue@3.3.4 + vue-demi: 0.14.5(vue@3.3.4) transitivePeerDependencies: - '@vue/composition-api' - vue dev: true - /@vueuse/integrations/8.9.4_axios@0.26.1+vue@3.3.4: + /@vueuse/integrations@8.9.4(axios@0.26.1)(vue@3.3.4): resolution: {integrity: sha512-Nk7mH0ThTdiuiiuB+1lyC+5ihnywrr+9h9IA4R4Ry8Mli/cZL38zc3qZWIsCVPm66Lr+7kEp3nnHdSxKi7ivrg==} peerDependencies: async-validator: '*' @@ -8135,31 +8904,31 @@ packages: universal-cookie: optional: true dependencies: - '@vueuse/core': 8.9.4_vue@3.3.4 - '@vueuse/shared': 8.9.4_vue@3.3.4 + '@vueuse/core': 8.9.4(vue@3.3.4) + '@vueuse/shared': 8.9.4(vue@3.3.4) axios: 0.26.1 - vue-demi: 0.14.5_vue@3.3.4 + vue-demi: 0.14.5(vue@3.3.4) transitivePeerDependencies: - '@vue/composition-api' - vue dev: false - /@vueuse/metadata/10.2.1: + /@vueuse/metadata@10.2.1: resolution: {integrity: sha512-3Gt68mY/i6bQvFqx7cuGBzrCCQu17OBaGWS5JdwISpMsHnMKKjC2FeB5OAfMcCQ0oINfADP3i9A4PPRo0peHdQ==} - /@vueuse/metadata/8.9.4: + /@vueuse/metadata@8.9.4: resolution: {integrity: sha512-IwSfzH80bnJMzqhaapqJl9JRIiyQU0zsRGEgnxN6jhq7992cPUJIRfV+JHRIZXjYqbwt07E1gTEp0R0zPJ1aqw==} dev: false - /@vueuse/shared/10.2.1_vue@3.3.4: + /@vueuse/shared@10.2.1(vue@3.3.4): resolution: {integrity: sha512-QWHq2bSuGptkcxx4f4M/fBYC3Y8d3M2UYyLsyzoPgEoVzJURQ0oJeWXu79OiLlBb8gTKkqe4mO85T/sf39mmiw==} dependencies: - vue-demi: 0.14.5_vue@3.3.4 + vue-demi: 0.14.5(vue@3.3.4) transitivePeerDependencies: - '@vue/composition-api' - vue - /@vueuse/shared/8.9.4_vue@3.3.4: + /@vueuse/shared@8.9.4(vue@3.3.4): resolution: {integrity: sha512-wt+T30c4K6dGRMVqPddexEVLa28YwxW5OFIPmzUHICjphfAuBFTTdDoyqREZNDOFJZ44ARH1WWQNCUK8koJ+Ag==} peerDependencies: '@vue/composition-api': ^1.1.0 @@ -8171,10 +8940,10 @@ packages: optional: true dependencies: vue: 3.3.4 - vue-demi: 0.14.5_vue@3.3.4 + vue-demi: 0.14.5(vue@3.3.4) dev: false - /@wdio/config/8.12.1: + /@wdio/config@8.12.1: resolution: {integrity: sha512-6DfTU+5Ugg6HKMSqVNCLEgdFd7l+QnaMoDe2/tZ8zoYNdJlFu0NfClXLL4qnTCCjebmz3eu0/O+aRPJyxo6GGQ==} engines: {node: ^16.13 || >=18} dependencies: @@ -8188,7 +8957,7 @@ packages: read-pkg-up: 9.1.0 dev: true - /@wdio/logger/8.11.0: + /@wdio/logger@8.11.0: resolution: {integrity: sha512-IsuKSaYi7NKEdgA57h8muzlN/MVp1dQG+V4C//7g4m03YJUnNQLvDhJzLjdeNTfvZy61U7foQSyt+3ktNzZkXA==} engines: {node: ^16.13 || >=18} dependencies: @@ -8198,25 +8967,25 @@ packages: strip-ansi: 7.1.0 dev: true - /@wdio/protocols/8.11.0: + /@wdio/protocols@8.11.0: resolution: {integrity: sha512-eXTMYt/XoaX53H/Q2qmsn1uWthIC5aSTGtX9YyXD/AkagG2hXeX3lLmzNWBaSIvKR+vWXRYbg3Y/7IvL2s25Wg==} dev: true - /@wdio/repl/8.10.1: + /@wdio/repl@8.10.1: resolution: {integrity: sha512-VZ1WFHTNKjR8Ga97TtV2SZM6fvRjWbYI2i/f4pJB4PtusorKvONAMJf2LQcUBIyzbVobqr7KSrcjmSwRolI+yw==} engines: {node: ^16.13 || >=18} dependencies: '@types/node': 20.4.1 dev: true - /@wdio/types/8.10.4: + /@wdio/types@8.10.4: resolution: {integrity: sha512-aLJ1QQW+hhALeRK3bvMLjIrlUVyhOs3Od+91pR4Z4pLwyeNG1bJZCJRD5bAJK/mm7CnFa0NsdixPS9jJxZcRrw==} engines: {node: ^16.13 || >=18} dependencies: '@types/node': 20.4.1 dev: true - /@wdio/utils/8.12.1: + /@wdio/utils@8.12.1: resolution: {integrity: sha512-VmF6O++84FTH3AKaVFyqn0MJA65/1G6dbm6p61KBqkD25LxaWo4398lCCbt264hzBIobtXRZoQ87bSxdfnlUKQ==} engines: {node: ^16.13 || >=18} dependencies: @@ -8226,14 +8995,14 @@ packages: p-iteration: 1.1.8 dev: true - /@webassemblyjs/ast/1.11.6: + /@webassemblyjs/ast@1.11.6: resolution: {integrity: sha512-IN1xI7PwOvLPgjcf180gC1bqn3q/QaOCwYUahIOhbYUu8KA/3tw2RT/T0Gidi1l7Hhj5D/INhJxiICObqpMu4Q==} dependencies: '@webassemblyjs/helper-numbers': 1.11.6 '@webassemblyjs/helper-wasm-bytecode': 1.11.6 dev: true - /@webassemblyjs/ast/1.9.0: + /@webassemblyjs/ast@1.9.0: resolution: {integrity: sha512-C6wW5L+b7ogSDVqymbkkvuW9kruN//YisMED04xzeBBqjHa2FYnmvOlS6Xj68xWQRgWvI9cIglsjFowH/RJyEA==} dependencies: '@webassemblyjs/helper-module-context': 1.9.0 @@ -8241,47 +9010,47 @@ packages: '@webassemblyjs/wast-parser': 1.9.0 dev: true - /@webassemblyjs/floating-point-hex-parser/1.11.6: + /@webassemblyjs/floating-point-hex-parser@1.11.6: resolution: {integrity: sha512-ejAj9hfRJ2XMsNHk/v6Fu2dGS+i4UaXBXGemOfQ/JfQ6mdQg/WXtwleQRLLS4OvfDhv8rYnVwH27YJLMyYsxhw==} dev: true - /@webassemblyjs/floating-point-hex-parser/1.9.0: + /@webassemblyjs/floating-point-hex-parser@1.9.0: resolution: {integrity: sha512-TG5qcFsS8QB4g4MhrxK5TqfdNe7Ey/7YL/xN+36rRjl/BlGE/NcBvJcqsRgCP6Z92mRE+7N50pRIi8SmKUbcQA==} dev: true - /@webassemblyjs/helper-api-error/1.11.6: + /@webassemblyjs/helper-api-error@1.11.6: resolution: {integrity: sha512-o0YkoP4pVu4rN8aTJgAyj9hC2Sv5UlkzCHhxqWj8butaLvnpdc2jOwh4ewE6CX0txSfLn/UYaV/pheS2Txg//Q==} dev: true - /@webassemblyjs/helper-api-error/1.9.0: + /@webassemblyjs/helper-api-error@1.9.0: resolution: {integrity: sha512-NcMLjoFMXpsASZFxJ5h2HZRcEhDkvnNFOAKneP5RbKRzaWJN36NC4jqQHKwStIhGXu5mUWlUUk7ygdtrO8lbmw==} dev: true - /@webassemblyjs/helper-buffer/1.11.6: + /@webassemblyjs/helper-buffer@1.11.6: resolution: {integrity: sha512-z3nFzdcp1mb8nEOFFk8DrYLpHvhKC3grJD2ardfKOzmbmJvEf/tPIqCY+sNcwZIY8ZD7IkB2l7/pqhUhqm7hLA==} dev: true - /@webassemblyjs/helper-buffer/1.9.0: + /@webassemblyjs/helper-buffer@1.9.0: resolution: {integrity: sha512-qZol43oqhq6yBPx7YM3m9Bv7WMV9Eevj6kMi6InKOuZxhw+q9hOkvq5e/PpKSiLfyetpaBnogSbNCfBwyB00CA==} dev: true - /@webassemblyjs/helper-code-frame/1.9.0: + /@webassemblyjs/helper-code-frame@1.9.0: resolution: {integrity: sha512-ERCYdJBkD9Vu4vtjUYe8LZruWuNIToYq/ME22igL+2vj2dQ2OOujIZr3MEFvfEaqKoVqpsFKAGsRdBSBjrIvZA==} dependencies: '@webassemblyjs/wast-printer': 1.9.0 dev: true - /@webassemblyjs/helper-fsm/1.9.0: + /@webassemblyjs/helper-fsm@1.9.0: resolution: {integrity: sha512-OPRowhGbshCb5PxJ8LocpdX9Kl0uB4XsAjl6jH/dWKlk/mzsANvhwbiULsaiqT5GZGT9qinTICdj6PLuM5gslw==} dev: true - /@webassemblyjs/helper-module-context/1.9.0: + /@webassemblyjs/helper-module-context@1.9.0: resolution: {integrity: sha512-MJCW8iGC08tMk2enck1aPW+BE5Cw8/7ph/VGZxwyvGbJwjktKkDK7vy7gAmMDx88D7mhDTCNKAW5tED+gZ0W8g==} dependencies: '@webassemblyjs/ast': 1.9.0 dev: true - /@webassemblyjs/helper-numbers/1.11.6: + /@webassemblyjs/helper-numbers@1.11.6: resolution: {integrity: sha512-vUIhZ8LZoIWHBohiEObxVm6hwP034jwmc9kuq5GdHZH0wiLVLIPcMCdpJzG4C11cHoQ25TFIQj9kaVADVX7N3g==} dependencies: '@webassemblyjs/floating-point-hex-parser': 1.11.6 @@ -8289,15 +9058,15 @@ packages: '@xtuc/long': 4.2.2 dev: true - /@webassemblyjs/helper-wasm-bytecode/1.11.6: + /@webassemblyjs/helper-wasm-bytecode@1.11.6: resolution: {integrity: sha512-sFFHKwcmBprO9e7Icf0+gddyWYDViL8bpPjJJl0WHxCdETktXdmtWLGVzoHbqUcY4Be1LkNfwTmXOJUFZYSJdA==} dev: true - /@webassemblyjs/helper-wasm-bytecode/1.9.0: + /@webassemblyjs/helper-wasm-bytecode@1.9.0: resolution: {integrity: sha512-R7FStIzyNcd7xKxCZH5lE0Bqy+hGTwS3LJjuv1ZVxd9O7eHCedSdrId/hMOd20I+v8wDXEn+bjfKDLzTepoaUw==} dev: true - /@webassemblyjs/helper-wasm-section/1.11.6: + /@webassemblyjs/helper-wasm-section@1.11.6: resolution: {integrity: sha512-LPpZbSOwTpEC2cgn4hTydySy1Ke+XEu+ETXuoyvuyezHO3Kjdu90KK95Sh9xTbmjrCsUwvWwCOQQNta37VrS9g==} dependencies: '@webassemblyjs/ast': 1.11.6 @@ -8306,7 +9075,7 @@ packages: '@webassemblyjs/wasm-gen': 1.11.6 dev: true - /@webassemblyjs/helper-wasm-section/1.9.0: + /@webassemblyjs/helper-wasm-section@1.9.0: resolution: {integrity: sha512-XnMB8l3ek4tvrKUUku+IVaXNHz2YsJyOOmz+MMkZvh8h1uSJpSen6vYnw3IoQ7WwEuAhL8Efjms1ZWjqh2agvw==} dependencies: '@webassemblyjs/ast': 1.9.0 @@ -8315,39 +9084,39 @@ packages: '@webassemblyjs/wasm-gen': 1.9.0 dev: true - /@webassemblyjs/ieee754/1.11.6: + /@webassemblyjs/ieee754@1.11.6: resolution: {integrity: sha512-LM4p2csPNvbij6U1f19v6WR56QZ8JcHg3QIJTlSwzFcmx6WSORicYj6I63f9yU1kEUtrpG+kjkiIAkevHpDXrg==} dependencies: '@xtuc/ieee754': 1.2.0 dev: true - /@webassemblyjs/ieee754/1.9.0: + /@webassemblyjs/ieee754@1.9.0: resolution: {integrity: sha512-dcX8JuYU/gvymzIHc9DgxTzUUTLexWwt8uCTWP3otys596io0L5aW02Gb1RjYpx2+0Jus1h4ZFqjla7umFniTg==} dependencies: '@xtuc/ieee754': 1.2.0 dev: true - /@webassemblyjs/leb128/1.11.6: + /@webassemblyjs/leb128@1.11.6: resolution: {integrity: sha512-m7a0FhE67DQXgouf1tbN5XQcdWoNgaAuoULHIfGFIEVKA6tu/edls6XnIlkmS6FrXAquJRPni3ZZKjw6FSPjPQ==} dependencies: '@xtuc/long': 4.2.2 dev: true - /@webassemblyjs/leb128/1.9.0: + /@webassemblyjs/leb128@1.9.0: resolution: {integrity: sha512-ENVzM5VwV1ojs9jam6vPys97B/S65YQtv/aanqnU7D8aSoHFX8GyhGg0CMfyKNIHBuAVjy3tlzd5QMMINa7wpw==} dependencies: '@xtuc/long': 4.2.2 dev: true - /@webassemblyjs/utf8/1.11.6: + /@webassemblyjs/utf8@1.11.6: resolution: {integrity: sha512-vtXf2wTQ3+up9Zsg8sa2yWiQpzSsMyXj0qViVP6xKGCUT8p8YJ6HqI7l5eCnWx1T/FYdsv07HQs2wTFbbof/RA==} dev: true - /@webassemblyjs/utf8/1.9.0: + /@webassemblyjs/utf8@1.9.0: resolution: {integrity: sha512-GZbQlWtopBTP0u7cHrEx+73yZKrQoBMpwkGEIqlacljhXCkVM1kMQge/Mf+csMJAjEdSwhOyLAS0AoR3AG5P8w==} dev: true - /@webassemblyjs/wasm-edit/1.11.6: + /@webassemblyjs/wasm-edit@1.11.6: resolution: {integrity: sha512-Ybn2I6fnfIGuCR+Faaz7YcvtBKxvoLV3Lebn1tM4o/IAJzmi9AWYIPWpyBfU8cC+JxAO57bk4+zdsTjJR+VTOw==} dependencies: '@webassemblyjs/ast': 1.11.6 @@ -8360,7 +9129,7 @@ packages: '@webassemblyjs/wast-printer': 1.11.6 dev: true - /@webassemblyjs/wasm-edit/1.9.0: + /@webassemblyjs/wasm-edit@1.9.0: resolution: {integrity: sha512-FgHzBm80uwz5M8WKnMTn6j/sVbqilPdQXTWraSjBwFXSYGirpkSWE2R9Qvz9tNiTKQvoKILpCuTjBKzOIm0nxw==} dependencies: '@webassemblyjs/ast': 1.9.0 @@ -8373,7 +9142,7 @@ packages: '@webassemblyjs/wast-printer': 1.9.0 dev: true - /@webassemblyjs/wasm-gen/1.11.6: + /@webassemblyjs/wasm-gen@1.11.6: resolution: {integrity: sha512-3XOqkZP/y6B4F0PBAXvI1/bky7GryoogUtfwExeP/v7Nzwo1QLcq5oQmpKlftZLbT+ERUOAZVQjuNVak6UXjPA==} dependencies: '@webassemblyjs/ast': 1.11.6 @@ -8383,7 +9152,7 @@ packages: '@webassemblyjs/utf8': 1.11.6 dev: true - /@webassemblyjs/wasm-gen/1.9.0: + /@webassemblyjs/wasm-gen@1.9.0: resolution: {integrity: sha512-cPE3o44YzOOHvlsb4+E9qSqjc9Qf9Na1OO/BHFy4OI91XDE14MjFN4lTMezzaIWdPqHnsTodGGNP+iRSYfGkjA==} dependencies: '@webassemblyjs/ast': 1.9.0 @@ -8393,7 +9162,7 @@ packages: '@webassemblyjs/utf8': 1.9.0 dev: true - /@webassemblyjs/wasm-opt/1.11.6: + /@webassemblyjs/wasm-opt@1.11.6: resolution: {integrity: sha512-cOrKuLRE7PCe6AsOVl7WasYf3wbSo4CeOk6PkrjS7g57MFfVUF9u6ysQBBODX0LdgSvQqRiGz3CXvIDKcPNy4g==} dependencies: '@webassemblyjs/ast': 1.11.6 @@ -8402,7 +9171,7 @@ packages: '@webassemblyjs/wasm-parser': 1.11.6 dev: true - /@webassemblyjs/wasm-opt/1.9.0: + /@webassemblyjs/wasm-opt@1.9.0: resolution: {integrity: sha512-Qkjgm6Anhm+OMbIL0iokO7meajkzQD71ioelnfPEj6r4eOFuqm4YC3VBPqXjFyyNwowzbMD+hizmprP/Fwkl2A==} dependencies: '@webassemblyjs/ast': 1.9.0 @@ -8411,7 +9180,7 @@ packages: '@webassemblyjs/wasm-parser': 1.9.0 dev: true - /@webassemblyjs/wasm-parser/1.11.6: + /@webassemblyjs/wasm-parser@1.11.6: resolution: {integrity: sha512-6ZwPeGzMJM3Dqp3hCsLgESxBGtT/OeCvCZ4TA1JUPYgmhAx38tTPR9JaKy0S5H3evQpO/h2uWs2j6Yc/fjkpTQ==} dependencies: '@webassemblyjs/ast': 1.11.6 @@ -8422,7 +9191,7 @@ packages: '@webassemblyjs/utf8': 1.11.6 dev: true - /@webassemblyjs/wasm-parser/1.9.0: + /@webassemblyjs/wasm-parser@1.9.0: resolution: {integrity: sha512-9+wkMowR2AmdSWQzsPEjFU7njh8HTO5MqO8vjwEHuM+AMHioNqSBONRdr0NQQ3dVQrzp0s8lTcYqzUdb7YgELA==} dependencies: '@webassemblyjs/ast': 1.9.0 @@ -8433,7 +9202,7 @@ packages: '@webassemblyjs/utf8': 1.9.0 dev: true - /@webassemblyjs/wast-parser/1.9.0: + /@webassemblyjs/wast-parser@1.9.0: resolution: {integrity: sha512-qsqSAP3QQ3LyZjNC/0jBJ/ToSxfYJ8kYyuiGvtn/8MK89VrNEfwj7BPQzJVHi0jGTRK2dGdJ5PRqhtjzoww+bw==} dependencies: '@webassemblyjs/ast': 1.9.0 @@ -8444,14 +9213,14 @@ packages: '@xtuc/long': 4.2.2 dev: true - /@webassemblyjs/wast-printer/1.11.6: + /@webassemblyjs/wast-printer@1.11.6: resolution: {integrity: sha512-JM7AhRcE+yW2GWYaKeHL5vt4xqee5N2WcezptmgyhNS+ScggqcT1OtXykhAb13Sn5Yas0j2uv9tHgrjwvzAP4A==} dependencies: '@webassemblyjs/ast': 1.11.6 '@xtuc/long': 4.2.2 dev: true - /@webassemblyjs/wast-printer/1.9.0: + /@webassemblyjs/wast-printer@1.9.0: resolution: {integrity: sha512-2J0nE95rHXHyQ24cWjMKJ1tqB/ds8z/cyeOZxJhcb+rW+SQASVjuznUSmdz5GpVJTzU8JkhYut0D3siFDD6wsA==} dependencies: '@webassemblyjs/ast': 1.9.0 @@ -8459,25 +9228,25 @@ packages: '@xtuc/long': 4.2.2 dev: true - /@wojtekmaj/enzyme-adapter-react-17/0.6.7_7ltvq4e2railvf5uya4ffxpe2a: + /@wojtekmaj/enzyme-adapter-react-17@0.6.7(enzyme@3.11.0)(react-dom@17.0.2)(react@17.0.2): resolution: {integrity: sha512-B+byiwi/T1bx5hcj9wc0fUL5Hlb5giSXJzcnEfJVl2j6dGV2NJfcxDBYX0WWwIxlzNiFz8kAvlkFWI2y/nscZQ==} peerDependencies: enzyme: ^3.0.0 react: ^17.0.0-0 react-dom: ^17.0.0-0 dependencies: - '@wojtekmaj/enzyme-adapter-utils': 0.1.4_react@17.0.2 + '@wojtekmaj/enzyme-adapter-utils': 0.1.4(react@17.0.2) enzyme: 3.11.0 enzyme-shallow-equal: 1.0.5 has: 1.0.3 prop-types: 15.8.1 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) react-is: 17.0.2 - react-test-renderer: 17.0.2_react@17.0.2 + react-test-renderer: 17.0.2(react@17.0.2) dev: true - /@wojtekmaj/enzyme-adapter-utils/0.1.4_react@17.0.2: + /@wojtekmaj/enzyme-adapter-utils@0.1.4(react@17.0.2): resolution: {integrity: sha512-ARGIQSIIv3oBia1m5Ihn1VU0FGmft6KPe39SBKTb8p7LSXO23YI4kNtc4M/cKoIY7P+IYdrZcgMObvedyjoSQA==} peerDependencies: react: ^17.0.0-0 @@ -8489,77 +9258,77 @@ packages: react: 17.0.2 dev: true - /@wry/context/0.7.3: + /@wry/context@0.7.3: resolution: {integrity: sha512-Nl8WTesHp89RF803Se9X3IiHjdmLBrIvPMaJkl+rKVJAYyPsz1TEUbu89943HpvujtSJgDUx9W4vZw3K1Mr3sA==} engines: {node: '>=8'} dependencies: tslib: 2.6.0 dev: false - /@wry/equality/0.5.6: + /@wry/equality@0.5.6: resolution: {integrity: sha512-D46sfMTngaYlrH+OspKf8mIJETntFnf6Hsjb0V41jAXJ7Bx2kB8Rv8RCUujuVWYttFtHkUNp7g+FwxNQAr6mXA==} engines: {node: '>=8'} dependencies: tslib: 2.6.0 dev: false - /@wry/trie/0.3.2: + /@wry/trie@0.3.2: resolution: {integrity: sha512-yRTyhWSls2OY/pYLfwff867r8ekooZ4UI+/gxot5Wj8EFwSf2rG+n+Mo/6LoLQm1TKA4GRj2+LCpbfS937dClQ==} engines: {node: '>=8'} dependencies: tslib: 2.6.0 dev: false - /@wry/trie/0.4.3: + /@wry/trie@0.4.3: resolution: {integrity: sha512-I6bHwH0fSf6RqQcnnXLJKhkSXG45MFral3GxPaY4uAl0LYDZM+YDVDAiU9bYwjTuysy1S0IeecWtmq1SZA3M1w==} engines: {node: '>=8'} dependencies: tslib: 2.6.0 dev: false - /@xmldom/xmldom/0.8.8: + /@xmldom/xmldom@0.8.8: resolution: {integrity: sha512-0LNz4EY8B/8xXY86wMrQ4tz6zEHZv9ehFMJPm8u2gq5lQ71cfRKdaKyxfJAx5aUoyzx0qzgURblTisPGgz3d+Q==} engines: {node: '>=10.0.0'} dev: true - /@xtuc/ieee754/1.2.0: + /@xtuc/ieee754@1.2.0: resolution: {integrity: sha512-DX8nKgqcGwsc0eJSqYt5lwP4DH5FlHnmuWWBRy7X0NcaGR0ZtuyeESgMwTYVEtxmsNGY+qit4QYT/MIYTOTPeA==} dev: true - /@xtuc/long/4.2.2: + /@xtuc/long@4.2.2: resolution: {integrity: sha512-NuHqBY1PB/D8xU6s/thBgOAiAP7HOYDQ32+BFZILJ8ivkUkAHQnWfn6WhL79Owj1qmUnoN/YPhktdIoucipkAQ==} dev: true - /@yeger/debounce/1.0.66: + /@yeger/debounce@1.0.66: resolution: {integrity: sha512-uG9dJufP1iV9msj78v/kPGW3AFemU6QndULKgL6KJ+EbjBVo/2dgBgRZ1XduasCtkrFxEuf3DAqFDF4XTSsZ0g==} dev: true - /@zxing/text-encoding/0.9.0: + /@zxing/text-encoding@0.9.0: resolution: {integrity: sha512-U/4aVJ2mxI0aDNI8Uq0wEhMgY+u4CNtEb0om3+y3+niDAsoTCOB33UF0sxpzqzdqXLqmvc+vZyAt4O8pPdfkwA==} requiresBuild: true dev: true optional: true - /abab/2.0.6: + /abab@2.0.6: resolution: {integrity: sha512-j2afSsaIENvHZN2B8GOpF566vZ5WVk5opAiMTvWgaQT8DkbOqsTfvNAvHoRGU2zzP8cPoqys+xHTRDWW8L+/BA==} dev: true - /abbrev/1.1.1: + /abbrev@1.1.1: resolution: {integrity: sha512-nne9/IiQ/hzIhY6pdDnbBtz7DjPTKrY00P/zvPSm5pOFkl6xuGrGnXn/VtTNNfNtAfZ9/1RtehkszU9qcTii0Q==} dev: true - /abort-controller/3.0.0: + /abort-controller@3.0.0: resolution: {integrity: sha512-h8lQ8tacZYnR3vNQTgibj+tODHI5/+l06Au2Pcriv/Gmet0eaj4TwWH41sO9wnHDiQsEj19q0drzdWdeAHtweg==} engines: {node: '>=6.5'} dependencies: event-target-shim: 5.0.1 dev: true - /abstract-logging/2.0.1: + /abstract-logging@2.0.1: resolution: {integrity: sha512-2BjRTZxTPvheOvGbBslFSYOUkr+SjPtOnrLP33f+VIWLzezQpZcqVg7ja3L4dBXmzzgwT+a029jRx5PCi3JuiA==} dev: true - /accepts/1.3.8: + /accepts@1.3.8: resolution: {integrity: sha512-PYAthTa2m2VKxuvSD3DPC/Gy+U+sOA1LAuT8mkmRuvw+NACSaeXEQ+NHcVF7rONl6qcaxV3Uuemwawk+7+SJLw==} engines: {node: '>= 0.6'} dependencies: @@ -8567,14 +9336,21 @@ packages: negotiator: 0.6.3 dev: true - /acorn-globals/7.0.1: + /acorn-globals@6.0.0: + resolution: {integrity: sha512-ZQl7LOWaF5ePqqcX4hLuv/bLXYQNfNWw2c0/yX/TsPRKamzHcTGQnlCjHT3TsmkOUVEPS3crCxiPfdzE/Trlhg==} + dependencies: + acorn: 7.4.1 + acorn-walk: 7.2.0 + dev: true + + /acorn-globals@7.0.1: resolution: {integrity: sha512-umOSDSDrfHbTNPuNpC2NSnnA3LUrqpevPb4T9jRx4MagXNS0rs+gwiTcAvqCRmsD6utzsrzNt+ebm00SNWiC3Q==} dependencies: acorn: 8.10.0 acorn-walk: 8.2.0 dev: true - /acorn-import-assertions/1.9.0_acorn@8.10.0: + /acorn-import-assertions@1.9.0(acorn@8.10.0): resolution: {integrity: sha512-cmMwop9x+8KFhxvKrKfPYmN6/pKTYYHBqLa0DfvVZcKMJWNyWLnaqND7dx/qn66R7ewM1UX5XMaDVP5wlVTaVA==} peerDependencies: acorn: ^8 @@ -8582,7 +9358,7 @@ packages: acorn: 8.10.0 dev: true - /acorn-jsx/5.3.2_acorn@7.4.1: + /acorn-jsx@5.3.2(acorn@7.4.1): resolution: {integrity: sha512-rq9s+JNhf0IChjtDXxllJ7g41oZk5SlXtp0LHwyA5cejwn7vKmKp4pPri6YEePv2PU65sAsegbXtIinmDFDXgQ==} peerDependencies: acorn: ^6.0.0 || ^7.0.0 || ^8.0.0 @@ -8590,7 +9366,7 @@ packages: acorn: 7.4.1 dev: true - /acorn-jsx/5.3.2_acorn@8.10.0: + /acorn-jsx@5.3.2(acorn@8.10.0): resolution: {integrity: sha512-rq9s+JNhf0IChjtDXxllJ7g41oZk5SlXtp0LHwyA5cejwn7vKmKp4pPri6YEePv2PU65sAsegbXtIinmDFDXgQ==} peerDependencies: acorn: ^6.0.0 || ^7.0.0 || ^8.0.0 @@ -8598,47 +9374,47 @@ packages: acorn: 8.10.0 dev: true - /acorn-walk/7.2.0: + /acorn-walk@7.2.0: resolution: {integrity: sha512-OPdCF6GsMIP+Az+aWfAAOEt2/+iVDKE7oy6lJ098aoe59oAmK76qV6Gw60SbZ8jHuG2wH058GF4pLFbYamYrVA==} engines: {node: '>=0.4.0'} dev: true - /acorn-walk/8.2.0: + /acorn-walk@8.2.0: resolution: {integrity: sha512-k+iyHEuPgSw6SbuDpGQM+06HQUa04DZ3o+F6CSzXMvvI5KMvnaEqXe+YVe555R9nn6GPt404fos4wcgpw12SDA==} engines: {node: '>=0.4.0'} - /acorn/6.4.2: + /acorn@6.4.2: resolution: {integrity: sha512-XtGIhXwF8YM8bJhGxG5kXgjkEuNGLTkoYqVE+KMR+aspr4KGYmKYg7yUe3KghyQ9yheNwLnjmzh/7+gfDBmHCQ==} engines: {node: '>=0.4.0'} hasBin: true dev: true - /acorn/7.4.1: + /acorn@7.4.1: resolution: {integrity: sha512-nQyp0o1/mNdbTO1PO6kHkwSrmgZ0MT/jCCpNiwbUjGoRN4dlBhqJtoQuCnEOKzgTVwg0ZWiCoQy6SxMebQVh8A==} engines: {node: '>=0.4.0'} hasBin: true dev: true - /acorn/8.10.0: + /acorn@8.10.0: resolution: {integrity: sha512-F0SAmZ8iUtS//m8DmCTA0jlh6TDKkHQyK6xc6V4KDTyZKA9dnvX9/3sRTVQrWm79glUAZbnmmNcdYwUIHWVybw==} engines: {node: '>=0.4.0'} hasBin: true - /address/1.2.2: + /address@1.2.2: resolution: {integrity: sha512-4B/qKCfeE/ODUaAUpSwfzazo5x29WD4r3vXiWsB7I2mSDAihwEqKO+g8GELZUQSSAo5e1XTYh3ZVfLyxBc12nA==} engines: {node: '>= 10.0.0'} dev: true - /agent-base/6.0.2: + /agent-base@6.0.2: resolution: {integrity: sha512-RZNwNclF7+MS/8bDg70amg32dyeZGZxiDuQmZxKLAlQjr3jGyLx+4Kkk58UO7D2QdgFIQCovuSuZESne6RG6XQ==} engines: {node: '>= 6.0.0'} dependencies: - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) transitivePeerDependencies: - supports-color dev: true - /aggregate-error/3.1.0: + /aggregate-error@3.1.0: resolution: {integrity: sha512-4I7Td01quW/RpocfNayFdFVk1qSuoh0E7JrbRJ16nH01HhKFQ88INq9Sd+nd72zqRySlr9BmDA8xlEJ6vJMrYA==} engines: {node: '>=8'} dependencies: @@ -8646,7 +9422,7 @@ packages: indent-string: 4.0.0 dev: true - /airbnb-js-shims/2.2.1: + /airbnb-js-shims@2.2.1: resolution: {integrity: sha512-wJNXPH66U2xjgo1Zwyjf9EydvJ2Si94+vSdk6EERcBfB2VZkeltpqIats0cqIZMLCXP3zcyaUKGYQeIBT6XjsQ==} dependencies: array-includes: 3.1.6 @@ -8668,7 +9444,7 @@ packages: symbol.prototype.description: 1.0.5 dev: true - /ajv-errors/1.0.1_ajv@6.12.6: + /ajv-errors@1.0.1(ajv@6.12.6): resolution: {integrity: sha512-DCRfO/4nQ+89p/RK43i8Ezd41EqdGIU4ld7nGF8OQ14oc/we5rEntLCUa7+jrn3nn83BosfwZA0wb4pon2o8iQ==} peerDependencies: ajv: '>=5.0.0' @@ -8676,8 +9452,10 @@ packages: ajv: 6.12.6 dev: true - /ajv-formats/2.1.1: + /ajv-formats@2.1.1(ajv@8.12.0): resolution: {integrity: sha512-Wx0Kx52hxE7C18hkMEggYlEifqWZtYaRgouJor+WMdPnQyEK13vgEWyVNup7SoeeoLMsr4kf5h6dOW11I15MUA==} + peerDependencies: + ajv: ^8.0.0 peerDependenciesMeta: ajv: optional: true @@ -8685,7 +9463,7 @@ packages: ajv: 8.12.0 dev: true - /ajv-keywords/3.5.2_ajv@6.12.6: + /ajv-keywords@3.5.2(ajv@6.12.6): resolution: {integrity: sha512-5p6WTN0DdTGVQk6VjcEju19IgaHudalcfabD7yhDGeA6bcQnmL+CpveLJq/3hvfwd1aof6L386Ougkx6RfyMIQ==} peerDependencies: ajv: ^6.9.1 @@ -8693,7 +9471,7 @@ packages: ajv: 6.12.6 dev: true - /ajv/6.12.6: + /ajv@6.12.6: resolution: {integrity: sha512-j3fVLgvTo527anyYyJOGTYJbG+vnnQYvE0m5mmkc1TK+nxAppkCLMIL0aZ4dblVCNoGShhm+kzE4ZUykBoMg4g==} dependencies: fast-deep-equal: 3.1.3 @@ -8702,7 +9480,7 @@ packages: uri-js: 4.4.1 dev: true - /ajv/8.12.0: + /ajv@8.12.0: resolution: {integrity: sha512-sRu1kpcO9yLtYxBKvqfTeh9KzZEwO3STyX1HT+4CaDzC6HpTGYhIhPIzj9XuKU7KYDwnaeh5hcOwjy1QuJzBPA==} dependencies: fast-deep-equal: 3.1.3 @@ -8711,7 +9489,7 @@ packages: uri-js: 4.4.1 dev: true - /algoliasearch/4.18.0: + /algoliasearch@4.18.0: resolution: {integrity: sha512-pCuVxC1SVcpc08ENH32T4sLKSyzoU7TkRIDBMwSLfIiW+fq4znOmWDkAygHZ6pRcO9I1UJdqlfgnV7TRj+MXrA==} dependencies: '@algolia/cache-browser-local-storage': 4.18.0 @@ -8730,89 +9508,89 @@ packages: '@algolia/transporter': 4.18.0 dev: true - /ansi-align/3.0.1: + /ansi-align@3.0.1: resolution: {integrity: sha512-IOfwwBF5iczOjp/WeY4YxyjqAFMQoZufdQWDd19SEExbVLNXqvpzSJ/M7Za4/sCPmQ0+GRquoA7bGcINcxew6w==} dependencies: string-width: 4.2.3 dev: true - /ansi-colors/3.2.4: + /ansi-colors@3.2.4: resolution: {integrity: sha512-hHUXGagefjN2iRrID63xckIvotOXOojhQKWIPUZ4mNUZ9nLZW+7FMNoE1lOkEhNWYsx/7ysGIuJYCiMAA9FnrA==} engines: {node: '>=6'} dev: true - /ansi-colors/4.1.3: + /ansi-colors@4.1.3: resolution: {integrity: sha512-/6w/C21Pm1A7aZitlI5Ni/2J6FFQN8i1Cvz3kHABAAbw93v/NlvKdVOqz7CCWz/3iv/JplRSEEZ83XION15ovw==} engines: {node: '>=6'} dev: true - /ansi-escapes/4.3.2: + /ansi-escapes@4.3.2: resolution: {integrity: sha512-gKXj5ALrKWQLsYG9jlTRmR/xKluxHV+Z9QEwNIgCfM1/uwPMCuzVVnh5mwTd+OuBZcwSIMbqssNWRm1lE51QaQ==} engines: {node: '>=8'} dependencies: type-fest: 0.21.3 dev: true - /ansi-escapes/5.0.0: + /ansi-escapes@5.0.0: resolution: {integrity: sha512-5GFMVX8HqE/TB+FuBJGuO5XG0WrsA6ptUqoODaT/n9mmUaZFkqnBueB4leqGBCmrUHnCnC4PCZTCd0E7QQ83bA==} engines: {node: '>=12'} dependencies: type-fest: 1.4.0 dev: true - /ansi-html-community/0.0.8: + /ansi-html-community@0.0.8: resolution: {integrity: sha512-1APHAyr3+PCamwNw3bXCPp4HFLONZt/yIH0sZp0/469KWNTEy+qN5jQ3GVX6DMZ1UXAi34yVwtTeaG/HpBuuzw==} engines: {'0': node >= 0.8.0} hasBin: true dev: true - /ansi-regex/2.1.1: + /ansi-regex@2.1.1: resolution: {integrity: sha512-TIGnTpdo+E3+pCyAluZvtED5p5wCqLdezCyhPZzKPcxvFplEt4i+W7OONCKgeZFT3+y5NZZfOOS/Bdcanm1MYA==} engines: {node: '>=0.10.0'} dev: true - /ansi-regex/5.0.1: + /ansi-regex@5.0.1: resolution: {integrity: sha512-quJQXlTSUGL2LH9SUXo8VwsY4soanhgo6LNSm84E1LBcE8s3O0wpdiRzyR9z/ZZJMlMWv37qOOb9pdJlMUEKFQ==} engines: {node: '>=8'} dev: true - /ansi-regex/6.0.1: + /ansi-regex@6.0.1: resolution: {integrity: sha512-n5M855fKb2SsfMIiFFoVrABHJC8QtHwVx+mHWP3QcEqBHYienj5dHSgjbxtC0WEZXYt4wcD6zrQElDPhFuZgfA==} engines: {node: '>=12'} dev: true - /ansi-sequence-parser/1.1.0: + /ansi-sequence-parser@1.1.0: resolution: {integrity: sha512-lEm8mt52to2fT8GhciPCGeCXACSz2UwIN4X2e2LJSnZ5uAbn2/dsYdOmUXq0AtWS5cpAupysIneExOgH0Vd2TQ==} dev: true - /ansi-styles/2.2.1: + /ansi-styles@2.2.1: resolution: {integrity: sha512-kmCevFghRiWM7HB5zTPULl4r9bVFSWjz62MhqizDGUrq2NWuNMQyuv4tHHoKJHs69M/MF64lEcHdYIocrdWQYA==} engines: {node: '>=0.10.0'} dev: true - /ansi-styles/3.2.1: + /ansi-styles@3.2.1: resolution: {integrity: sha512-VT0ZI6kZRdTh8YyJw3SMbYm/u+NqfsAxEpWO0Pf9sq8/e94WxxOpPKx9FR1FlyCtOVDNOQ+8ntlqFxiRc+r5qA==} engines: {node: '>=4'} dependencies: color-convert: 1.9.3 - /ansi-styles/4.3.0: + /ansi-styles@4.3.0: resolution: {integrity: sha512-zbB9rCJAT1rbjiVDb2hqKFHNYLxgtk8NURxZ3IZwD3F6NtxbXZQCnnSi1Lkx+IDohdPlFp222wVALIheZJQSEg==} engines: {node: '>=8'} dependencies: color-convert: 2.0.1 dev: true - /ansi-styles/5.2.0: + /ansi-styles@5.2.0: resolution: {integrity: sha512-Cxwpt2SfTzTtXcfOlzGEee8O+c+MmUgGrNiBcXnuWxuFJHe6a5Hz7qwhwe5OgaSYI0IJvkLqWX1ASG+cJOkEiA==} engines: {node: '>=10'} - /ansi-styles/6.2.1: + /ansi-styles@6.2.1: resolution: {integrity: sha512-bN798gFfQX+viw3R7yrGWRqnrN2oRkEkUjjl4JNn4E8GxxbjtG3FbrEIIY3l8/hrwUwIeCZvi4QuOTP4MErVug==} engines: {node: '>=12'} dev: true - /ansi-to-html/0.6.15: + /ansi-to-html@0.6.15: resolution: {integrity: sha512-28ijx2aHJGdzbs+O5SNQF65r6rrKYnkuwTYm8lZlChuoJ9P1vVzIpWO20sQTqTPDXYp6NFwk326vApTtLVFXpQ==} engines: {node: '>=8.0.0'} hasBin: true @@ -8820,7 +9598,7 @@ packages: entities: 2.2.0 dev: true - /ansi-to-html/0.7.2: + /ansi-to-html@0.7.2: resolution: {integrity: sha512-v6MqmEpNlxF+POuyhKkidusCHWWkaLcGRURzivcU3I9tv7k4JVhFcnukrM5Rlk2rUywdZuzYAZ+kbZqWCnfN3g==} engines: {node: '>=8.0.0'} hasBin: true @@ -8828,11 +9606,11 @@ packages: entities: 2.2.0 dev: true - /any-promise/1.3.0: + /any-promise@1.3.0: resolution: {integrity: sha512-7UvmKalWRt1wgjL1RrGxoSJW/0QZFIegpeGvZG9kjp8vrRu55XTHbwnqq2GpXm9uLbcuhxm3IqX9OB4MZR1b2A==} dev: true - /anymatch/2.0.0: + /anymatch@2.0.0: resolution: {integrity: sha512-5teOsQWABXHHBFP9y3skS5P3d/WfWXpv3FUpy+LorMrNYaT9pI4oLMQX7jzQ2KklNpGpWHzdCXTDT2Y3XGlZBw==} dependencies: micromatch: 3.1.10 @@ -8841,7 +9619,7 @@ packages: - supports-color dev: true - /anymatch/3.1.3: + /anymatch@3.1.3: resolution: {integrity: sha512-KMReFUr0B4t+D+OBkjR3KYqvocp2XaSzO55UcB6mgQMd3KbcE+mWTyvVV7D/zsdEbNnV6acZUutkiHQXvTr1Rw==} engines: {node: '>= 8'} dependencies: @@ -8849,27 +9627,27 @@ packages: picomatch: 2.3.1 dev: true - /app-root-dir/1.0.2: + /app-root-dir@1.0.2: resolution: {integrity: sha512-jlpIfsOoNoafl92Sz//64uQHGSyMrD2vYG5d8o2a4qGvyNCvXur7bzIsWtAC/6flI2RYAp3kv8rsfBtaLm7w0g==} dev: true - /appdata-path/1.0.0: + /appdata-path@1.0.0: resolution: {integrity: sha512-ZbH3ezXfnT/YE3NdqduIt4lBV+H0ybvA2Qx3K76gIjQvh8gROpDFdDLpx6B1QJtW7zxisCbpTlCLhKqoR8cDBw==} dev: true - /aproba/1.2.0: + /aproba@1.2.0: resolution: {integrity: sha512-Y9J6ZjXtoYh8RnXVCMOU/ttDmk1aBjunq9vO0ta5x85WDQiQfUF9sIPBITdbiiIVcBo03Hi3jMxigBtsddlXRw==} dev: true - /aproba/2.0.0: + /aproba@2.0.0: resolution: {integrity: sha512-lYe4Gx7QT+MKGbDsA+Z+he/Wtef0BiwDOlK/XkBrdfsh9J/jPPXbX0tE9x9cl27Tmu5gg3QUbUrQYa/y+KOHPQ==} dev: true - /arch/2.2.0: + /arch@2.2.0: resolution: {integrity: sha512-Of/R0wqp83cgHozfIYLbBMnej79U/SVGOOyuB3VVFv1NRM/PSFMK12x9KVtiYzJqmnU5WR2qp0Z5rHb7sWGnFQ==} dev: true - /archiver-utils/2.1.0: + /archiver-utils@2.1.0: resolution: {integrity: sha512-bEL/yUb/fNNiNTuUz979Z0Yg5L+LzLxGJz8x79lYmR54fmTIb6ob/hNQgkQnIUDWIFjZVQwl9Xs356I6BAMHfw==} engines: {node: '>= 6'} dependencies: @@ -8885,7 +9663,7 @@ packages: readable-stream: 2.3.8 dev: true - /archiver/5.3.1: + /archiver@5.3.1: resolution: {integrity: sha512-8KyabkmbYrH+9ibcTScQ1xCJC/CGcugdVIwB+53f5sZziXgwUh3iXlAlANMxcZyDEfTHMe6+Z5FofV8nopXP7w==} engines: {node: '>= 10'} dependencies: @@ -8898,11 +9676,11 @@ packages: zip-stream: 4.1.0 dev: true - /archy/1.0.0: + /archy@1.0.0: resolution: {integrity: sha512-Xg+9RwCg/0p32teKdGMPTPnVXKD0w3DfHnFTficozsAgsvq2XenPJq/MYpzzQ/v8zrOyJn6Ds39VA4JIDwFfqw==} dev: true - /are-we-there-yet/2.0.0: + /are-we-there-yet@2.0.0: resolution: {integrity: sha512-Ci/qENmwHnsYo9xKIcUJN5LeDKdJ6R1Z1j9V/J5wyq8nh/mYPEpIKJbBZXtZjG04HiK7zV/p6Vs9952MrMeUIw==} engines: {node: '>=10'} dependencies: @@ -8910,64 +9688,64 @@ packages: readable-stream: 3.6.2 dev: true - /arg/4.1.3: + /arg@4.1.3: resolution: {integrity: sha512-58S9QDqG0Xx27YwPSt9fJxivjYl432YCwfDMfZ+71RAqUrZef7LrKQZ3LHLOwCS4FLNBplP533Zx895SeOCHvA==} dev: true - /argparse/1.0.10: + /argparse@1.0.10: resolution: {integrity: sha512-o5Roy6tNG4SL/FOkCAN6RzjiakZS25RLYFrcMttJqbdd8BWrnA+fGz57iN5Pb06pvBGvl5gQ0B48dJlslXvoTg==} dependencies: sprintf-js: 1.0.3 dev: true - /argparse/2.0.1: + /argparse@2.0.1: resolution: {integrity: sha512-8+9WqebbFzpX9OR+Wa6O29asIogeRMzcGtAINdpMHHyAg10f05aSFVBbcEqGf/PXw1EjAZ+q2/bEBg3DvurK3Q==} dev: true - /aria-query/5.1.3: + /aria-query@5.1.3: resolution: {integrity: sha512-R5iJ5lkuHybztUfuOAznmboyjWq8O6sqNqtK7CLOqdydi54VNbORp49mb14KbWgG1QD3JFO9hJdZ+y4KutfdOQ==} dependencies: deep-equal: 2.2.2 dev: true - /aria-query/5.3.0: + /aria-query@5.3.0: resolution: {integrity: sha512-b0P0sZPKtyu8HkeRAfCq0IfURZK+SuwMjY1UXGBU27wpAiTwQAIlq56IbIO+ytk/JjS1fMR14ee5WBBfKi5J6A==} dependencies: dequal: 2.0.3 dev: true - /arr-diff/4.0.0: + /arr-diff@4.0.0: resolution: {integrity: sha512-YVIQ82gZPGBebQV/a8dar4AitzCQs0jjXwMPZllpXMaGjXPYVUawSxQrRsjhjupyVxEvbHgUmIhKVlND+j02kA==} engines: {node: '>=0.10.0'} dev: true - /arr-flatten/1.1.0: + /arr-flatten@1.1.0: resolution: {integrity: sha512-L3hKV5R/p5o81R7O02IGnwpDmkp6E982XhtbuwSe3O4qOtMMMtodicASA1Cny2U+aCXcNpml+m4dPsvsJ3jatg==} engines: {node: '>=0.10.0'} dev: true - /arr-union/3.1.0: + /arr-union@3.1.0: resolution: {integrity: sha512-sKpyeERZ02v1FeCZT8lrfJq5u6goHCtpTAzPwJYe7c8SPFOboNjNg1vz2L4VTn9T4PQxEx13TbXLmYUcS6Ug7Q==} engines: {node: '>=0.10.0'} dev: true - /array-buffer-byte-length/1.0.0: + /array-buffer-byte-length@1.0.0: resolution: {integrity: sha512-LPuwb2P+NrQw3XhxGc36+XSvuBPopovXYTR9Ew++Du9Yb/bx5AzBfrIsBoj0EZUifjQU+sHL21sseZ3jerWO/A==} dependencies: call-bind: 1.0.2 is-array-buffer: 3.0.2 dev: true - /array-find-index/1.0.2: + /array-find-index@1.0.2: resolution: {integrity: sha512-M1HQyIXcBGtVywBt8WVdim+lrNaK7VHp99Qt5pSNziXznKHViIBbXWtfRTpEFpF/c4FdfxNAsCCwPp5phBYJtw==} engines: {node: '>=0.10.0'} dev: true - /array-flatten/1.1.1: + /array-flatten@1.1.1: resolution: {integrity: sha512-PCVAQswWemu6UdxsDFFX/+gVeYqKAod3D3UVm91jHwynguOwAvYPhx8nNlM++NqRcK6CxxpUafjmhIdKiHibqg==} dev: true - /array-includes/3.1.6: + /array-includes@3.1.6: resolution: {integrity: sha512-sgTbLvL6cNnw24FnbaDyjmvddQ2ML8arZsgaJhoABMoplz/4QRhtrYS+alr1BUM1Bwp6dhx8vVCBSLG+StwOFw==} engines: {node: '>= 0.4'} dependencies: @@ -8978,29 +9756,29 @@ packages: is-string: 1.0.7 dev: true - /array-union/1.0.2: + /array-union@1.0.2: resolution: {integrity: sha512-Dxr6QJj/RdU/hCaBjOfxW+q6lyuVE6JFWIrAUpuOOhoJJoQ99cUn3igRaHVB5P9WrgFVN0FfArM3x0cueOU8ng==} engines: {node: '>=0.10.0'} dependencies: array-uniq: 1.0.3 dev: true - /array-union/2.1.0: + /array-union@2.1.0: resolution: {integrity: sha512-HGyxoOTYUyCM6stUe6EJgnd4EoewAI7zMdfqO+kGjnlZmBDz/cR5pf8r/cR4Wq60sL/p0IkcjUEEPwS3GFrIyw==} engines: {node: '>=8'} dev: true - /array-uniq/1.0.3: + /array-uniq@1.0.3: resolution: {integrity: sha512-MNha4BWQ6JbwhFhj03YK552f7cb3AzoE8SzeljgChvL1dl3IcvggXVz1DilzySZkCja+CXuZbdW7yATchWn8/Q==} engines: {node: '>=0.10.0'} dev: true - /array-unique/0.3.2: + /array-unique@0.3.2: resolution: {integrity: sha512-SleRWjh9JUud2wH1hPs9rZBZ33H6T9HOiL0uwGnGx9FpE6wKGyfWugmbkEOIs6qWrZhg0LWeLziLrEwQJhs5mQ==} engines: {node: '>=0.10.0'} dev: true - /array.prototype.filter/1.0.2: + /array.prototype.filter@1.0.2: resolution: {integrity: sha512-us+UrmGOilqttSOgoWZTpOvHu68vZT2YCjc/H4vhu56vzZpaDFBhB+Se2UwqWzMKbDv7Myq5M5pcZLAtUvTQdQ==} engines: {node: '>= 0.4'} dependencies: @@ -9011,7 +9789,7 @@ packages: is-string: 1.0.7 dev: true - /array.prototype.flat/1.3.1: + /array.prototype.flat@1.3.1: resolution: {integrity: sha512-roTU0KWIOmJ4DRLmwKd19Otg0/mT3qPNt0Qb3GWW8iObuZXxrjB/pzn0R3hqpRSWg4HCwqx+0vwOnWnvlOyeIA==} engines: {node: '>= 0.4'} dependencies: @@ -9021,7 +9799,7 @@ packages: es-shim-unscopables: 1.0.0 dev: true - /array.prototype.flatmap/1.3.1: + /array.prototype.flatmap@1.3.1: resolution: {integrity: sha512-8UGn9O1FDVvMNB0UlLv4voxRMze7+FpHyF5mSMRjWHUMlpoDViniy05870VlxhfgTnLbpuwTzvD76MTtWxB/mQ==} engines: {node: '>= 0.4'} dependencies: @@ -9031,7 +9809,7 @@ packages: es-shim-unscopables: 1.0.0 dev: true - /array.prototype.map/1.0.5: + /array.prototype.map@1.0.5: resolution: {integrity: sha512-gfaKntvwqYIuC7mLLyv2wzZIJqrRhn5PZ9EfFejSx6a78sV7iDsGpG9P+3oUPtm1Rerqm6nrKS4FYuTIvWfo3g==} engines: {node: '>= 0.4'} dependencies: @@ -9042,7 +9820,7 @@ packages: is-string: 1.0.7 dev: true - /array.prototype.reduce/1.0.5: + /array.prototype.reduce@1.0.5: resolution: {integrity: sha512-kDdugMl7id9COE8R7MHF5jWk7Dqt/fs4Pv+JXoICnYwqpjjjbUurz6w5fT5IG6brLdJhv6/VoHB0H7oyIBXd+Q==} engines: {node: '>= 0.4'} dependencies: @@ -9053,16 +9831,16 @@ packages: is-string: 1.0.7 dev: true - /arrify/2.0.1: + /arrify@2.0.1: resolution: {integrity: sha512-3duEwti880xqi4eAMN8AyR4a0ByT90zoYdLlevfrvU43vb0YZwZVfxOgxWrLXXXpyugL0hNZc9G6BiB5B3nUug==} engines: {node: '>=8'} dev: true - /asap/2.0.6: + /asap@2.0.6: resolution: {integrity: sha512-BSHWgDSAiKs50o2Re8ppvp3seVHXSRM44cdSsT9FfNEUUZLOGWVCsiWaRPWM1Znn+mqZ1OfVZ3z3DWEzSp7hRA==} dev: true - /asn1.js/5.4.1: + /asn1.js@5.4.1: resolution: {integrity: sha512-+I//4cYPccV8LdmBLiX8CYvf9Sp3vQsrqu2QNXRcrbiWvcx/UdlFiqUJJzxRQxgsZmvhXhn4cSKeSmoFjVdupA==} dependencies: bn.js: 4.12.0 @@ -9071,75 +9849,75 @@ packages: safer-buffer: 2.1.2 dev: true - /asn1/0.2.6: + /asn1@0.2.6: resolution: {integrity: sha512-ix/FxPn0MDjeyJ7i/yoHGFt/EX6LyNbxSEhPPXODPL+KB0VPk86UYfL0lMdy+KCnv+fmvIzySwaK5COwqVbWTQ==} dependencies: safer-buffer: 2.1.2 dev: true - /assert-plus/1.0.0: + /assert-plus@1.0.0: resolution: {integrity: sha512-NfJ4UzBCcQGLDlQq7nHxH+tv3kyZ0hHQqF5BO6J7tNJeP5do1llPr8dZ8zHonfhAu0PHAdMkSo+8o0wxg9lZWw==} engines: {node: '>=0.8'} dev: true - /assert/1.5.0: + /assert@1.5.0: resolution: {integrity: sha512-EDsgawzwoun2CZkCgtxJbv392v4nbk9XDD06zI+kQYoBM/3RBWLlEyJARDOmhAAosBjWACEkKL6S+lIZtcAubA==} dependencies: object-assign: 4.1.1 util: 0.10.3 dev: true - /assertion-error/1.1.0: + /assertion-error@1.1.0: resolution: {integrity: sha512-jgsaNduz+ndvGyFt3uSuWqvy4lCnIJiovtouQN5JZHOKCS2QuhEdbcQHFhVksz2N2U9hXJo8odG7ETyWlEeuDw==} dev: false - /assign-symbols/1.0.0: + /assign-symbols@1.0.0: resolution: {integrity: sha512-Q+JC7Whu8HhmTdBph/Tq59IoRtoy6KAm5zzPv00WdujX82lbAL8K7WVjne7vdCsAmbF4AYaDOPyO3k0kl8qIrw==} engines: {node: '>=0.10.0'} dev: true - /ast-types/0.14.2: + /ast-types@0.14.2: resolution: {integrity: sha512-O0yuUDnZeQDL+ncNGlJ78BiO4jnYI3bvMsD5prT0/nsgijG/LpNBIr63gTjVTNsiGkgQhiyCShTgxt8oXOrklA==} engines: {node: '>=4'} dependencies: tslib: 2.6.0 dev: true - /astral-regex/2.0.0: + /astral-regex@2.0.0: resolution: {integrity: sha512-Z7tMw1ytTXt5jqMcOP+OQteU1VuNK9Y02uuJtKQ1Sv69jXQKKg5cibLwGJow8yzZP+eAc18EmLGPal0bp36rvQ==} engines: {node: '>=8'} dev: true - /async-each/1.0.6: + /async-each@1.0.6: resolution: {integrity: sha512-c646jH1avxr+aVpndVMeAfYw7wAa6idufrlN3LPA4PmKS0QEGp6PIC9nwz0WQkkvBGAMEki3pFdtxaF39J9vvg==} dev: true optional: true - /async/3.2.4: + /async@3.2.4: resolution: {integrity: sha512-iAB+JbDEGXhyIUavoDl9WP/Jj106Kz9DEn1DPgYw5ruDn0e3Wgi3sKFm55sASdGBNOQB8F59d9qQ7deqrHA8wQ==} dev: true - /asynckit/0.4.0: + /asynckit@0.4.0: resolution: {integrity: sha512-Oei9OH4tRh0YqU3GxhX79dM/mwVgvbZJaSNaRk+bshkj0S5cfHcgYakreBjrHwatXKbz+IoIdYLxrKim2MjW0Q==} dev: true - /at-least-node/1.0.0: + /at-least-node@1.0.0: resolution: {integrity: sha512-+q/t7Ekv1EDY2l6Gda6LLiX14rU9TV20Wa3ofeQmwPFZbOMo9DXrLbOjFaaclkXKWidIaopwAObQDqwWtGUjqg==} engines: {node: '>= 4.0.0'} dev: true - /atob/2.1.2: + /atob@2.1.2: resolution: {integrity: sha512-Wm6ukoaOGJi/73p/cl2GvLjTI5JM1k/O14isD73YML8StrH/7/lRFgmg8nICZgD3bZZvjwCGxtMOD3wWNAu8cg==} engines: {node: '>= 4.5.0'} hasBin: true dev: true - /atomic-sleep/1.0.0: + /atomic-sleep@1.0.0: resolution: {integrity: sha512-kNOjDqAh7px0XWNI+4QbzoiR/nTkHAWNud2uvnJquD1/x5a7EQZMJT0AczqK0Qn67oY/TTQ1LbUKajZpp3I9tQ==} engines: {node: '>=8.0.0'} dev: true - /autoprefixer/9.8.8: + /autoprefixer@9.8.8: resolution: {integrity: sha512-eM9d/swFopRt5gdJ7jrpCwgvEMIayITpojhkkSMRsFHYuH5bkSQ4p/9qTEHtmNudUZh22Tehu7I6CxAW0IXTKA==} hasBin: true dependencies: @@ -9152,47 +9930,66 @@ packages: postcss-value-parser: 4.2.0 dev: true - /available-typed-arrays/1.0.5: + /available-typed-arrays@1.0.5: resolution: {integrity: sha512-DMD0KiN46eipeziST1LPP/STfDU0sufISXmjSgvVsoU2tqxctQeASejWcfNtxYKqETM1UxQ8sp2OrSBWpHY6sw==} engines: {node: '>= 0.4'} dev: true - /avvio/8.2.1: + /avvio@8.2.1: resolution: {integrity: sha512-TAlMYvOuwGyLK3PfBb5WKBXZmXz2fVCgv23d6zZFdle/q3gPjmxBaeuC0pY0Dzs5PWMSgfqqEZkrye19GlDTgw==} dependencies: archy: 1.0.0 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) fastq: 1.15.0 transitivePeerDependencies: - supports-color dev: true - /aws-sign2/0.7.0: + /aws-sign2@0.7.0: resolution: {integrity: sha512-08kcGqnYf/YmjoRhfxyu+CLxBjUtHLXLXX/vUfx9l2LYzG3c1m61nrpyFUZI6zeS+Li/wWMMidD9KgrqtGq3mA==} dev: true - /aws4/1.12.0: + /aws4@1.12.0: resolution: {integrity: sha512-NmWvPnx0F1SfrQbYwOi7OeaNGokp9XhzNioJ/CSBs8Qa4vxug81mhJEAVZwxXuBmYB5KDRfMq/F3RR0BIU7sWg==} dev: true - /axios/0.26.1: + /axios@0.26.1: resolution: {integrity: sha512-fPwcX4EvnSHuInCMItEhAGnaSEXRBjtzh9fOtsE6E1G6p7vl7edEeZe11QHf18+6+9gR5PbKV/sGKNaD8YaMeA==} dependencies: follow-redirects: 1.15.2 transitivePeerDependencies: - debug - /axobject-query/3.2.1: + /axobject-query@3.2.1: resolution: {integrity: sha512-jsyHu61e6N4Vbz/v18DHwWYKK0bSWLqn47eeDSKPB7m8tqMHF9YJ+mhIk2lVteyZrY8tnSj/jHOv4YiTCuCJgg==} dependencies: dequal: 2.0.3 dev: true - /b4a/1.6.4: + /b4a@1.6.4: resolution: {integrity: sha512-fpWrvyVHEKyeEvbKZTVOeZF3VSKKWtJxFIxX/jaVPf+cLbGUSitjb49pHLqPV2BUNNZ0LcoeEGfE/YCpyDYHIw==} dev: true - /babel-loader/8.3.0_@babel+core@7.22.8: + /babel-jest@27.5.1(@babel/core@7.22.8): + resolution: {integrity: sha512-cdQ5dXjGRd0IBRATiQ4mZGlGlRE8kJpjPOixdNRdT+m3UcNqmYWN6rK6nvtXYfY3D76cb8s/O1Ss8ea24PIwcg==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + peerDependencies: + '@babel/core': ^7.8.0 + dependencies: + '@babel/core': 7.22.8 + '@jest/transform': 27.5.1 + '@jest/types': 27.5.1 + '@types/babel__core': 7.20.1 + babel-plugin-istanbul: 6.1.1 + babel-preset-jest: 27.5.1(@babel/core@7.22.8) + chalk: 4.1.2 + graceful-fs: 4.2.11 + slash: 3.0.0 + transitivePeerDependencies: + - supports-color + dev: true + + /babel-loader@8.3.0(@babel/core@7.22.8)(webpack@4.46.0): resolution: {integrity: sha512-H8SvsMF+m9t15HNLMipppzkC+Y2Yq+v3SonZyU70RBL/h1gxPkH08Ot8pEE9Z4Kd+czyWJClmFS8qzIP9OZ04Q==} engines: {node: '>= 8.9'} peerDependencies: @@ -9204,9 +10001,10 @@ packages: loader-utils: 2.0.4 make-dir: 3.1.0 schema-utils: 2.7.1 + webpack: 4.46.0 dev: true - /babel-loader/8.3.0_n6tf3ekqtzvxjokzr6jiserpma: + /babel-loader@8.3.0(@babel/core@7.22.8)(webpack@5.88.1): resolution: {integrity: sha512-H8SvsMF+m9t15HNLMipppzkC+Y2Yq+v3SonZyU70RBL/h1gxPkH08Ot8pEE9Z4Kd+czyWJClmFS8qzIP9OZ04Q==} engines: {node: '>= 8.9'} peerDependencies: @@ -9218,14 +10016,14 @@ packages: loader-utils: 2.0.4 make-dir: 3.1.0 schema-utils: 2.7.1 - webpack: 4.46.0 + webpack: 5.88.1(esbuild@0.18.11) dev: true - /babel-plugin-add-react-displayname/0.0.5: + /babel-plugin-add-react-displayname@0.0.5: resolution: {integrity: sha512-LY3+Y0XVDYcShHHorshrDbt4KFWL4bSeniCtl4SYZbask+Syngk1uMPCeN9+nSiZo6zX5s0RTq/J9Pnaaf/KHw==} dev: true - /babel-plugin-apply-mdx-type-prop/1.6.22_@babel+core@7.12.9: + /babel-plugin-apply-mdx-type-prop@1.6.22(@babel/core@7.12.9): resolution: {integrity: sha512-VefL+8o+F/DfK24lPZMtJctrCVOfgbqLAGZSkxwhazQv4VxPg3Za/i40fu22KR2m8eEda+IfSOlPLUSIiLcnCQ==} peerDependencies: '@babel/core': ^7.11.6 @@ -9235,13 +10033,13 @@ packages: '@mdx-js/util': 1.6.22 dev: true - /babel-plugin-extract-import-names/1.6.22: + /babel-plugin-extract-import-names@1.6.22: resolution: {integrity: sha512-yJ9BsJaISua7d8zNT7oRG1ZLBJCIdZ4PZqmH8qa9N5AK01ifk3fnkc98AXhtzE7UkfCsEumvoQWgoYLhOnJ7jQ==} dependencies: '@babel/helper-plugin-utils': 7.10.4 dev: true - /babel-plugin-istanbul/6.1.1: + /babel-plugin-istanbul@6.1.1: resolution: {integrity: sha512-Y1IQok9821cC9onCx5otgFfRm7Lm+I+wwxOx738M/WLPZ9Q42m4IG5W0FNX8WLL2gYMZo3JkuXIH2DOpWM+qwA==} engines: {node: '>=8'} dependencies: @@ -9254,20 +10052,30 @@ packages: - supports-color dev: true - /babel-plugin-jsx-dom-expressions/0.36.10_@babel+core@7.22.8: + /babel-plugin-jest-hoist@27.5.1: + resolution: {integrity: sha512-50wCwD5EMNW4aRpOwtqzyZHIewTYNxLA4nhB+09d8BIssfNfzBRhkBIHiaPv1Si226TQSvp8gxAJm2iY2qs2hQ==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@babel/template': 7.22.5 + '@babel/types': 7.22.5 + '@types/babel__core': 7.20.1 + '@types/babel__traverse': 7.20.1 + dev: true + + /babel-plugin-jsx-dom-expressions@0.36.10(@babel/core@7.22.8): resolution: {integrity: sha512-QA2k/14WGw+RgcGGnEuLWwnu4em6CGhjeXtjvgOYyFHYS2a+CzPeaVQHDOlfuiBcjq/3hWMspHMIMnPEOIzdBg==} peerDependencies: '@babel/core': ^7.20.12 dependencies: '@babel/core': 7.22.8 '@babel/helper-module-imports': 7.18.6 - '@babel/plugin-syntax-jsx': 7.22.5_@babel+core@7.22.8 + '@babel/plugin-syntax-jsx': 7.22.5(@babel/core@7.22.8) '@babel/types': 7.22.5 html-entities: 2.3.3 validate-html-nesting: 1.2.2 dev: true - /babel-plugin-macros/3.1.0: + /babel-plugin-macros@3.1.0: resolution: {integrity: sha512-Cg7TFGpIr01vOQNODXOOaGz2NpCU5gl8x1qJFbb6hbZxR7XrcE2vtbAsTAbJ7/xwJtUuJEw8K8Zr/AE0LHlesg==} engines: {node: '>=10', npm: '>=6'} dependencies: @@ -9275,55 +10083,55 @@ packages: cosmiconfig: 7.1.0 resolve: 1.22.2 - /babel-plugin-polyfill-corejs2/0.4.4_@babel+core@7.22.8: + /babel-plugin-polyfill-corejs2@0.4.4(@babel/core@7.22.8): resolution: {integrity: sha512-9WeK9snM1BfxB38goUEv2FLnA6ja07UMfazFHzCXUb3NyDZAwfXvQiURQ6guTTMeHcOsdknULm1PDhs4uWtKyA==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: '@babel/compat-data': 7.22.6 '@babel/core': 7.22.8 - '@babel/helper-define-polyfill-provider': 0.4.1_@babel+core@7.22.8 + '@babel/helper-define-polyfill-provider': 0.4.1(@babel/core@7.22.8) '@nicolo-ribaudo/semver-v6': 6.3.3 transitivePeerDependencies: - supports-color dev: true - /babel-plugin-polyfill-corejs3/0.1.7_@babel+core@7.22.8: + /babel-plugin-polyfill-corejs3@0.1.7(@babel/core@7.22.8): resolution: {integrity: sha512-u+gbS9bbPhZWEeyy1oR/YaaSpod/KDT07arZHb80aTpl8H5ZBq+uN1nN9/xtX7jQyfLdPfoqI4Rue/MQSWJquw==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: '@babel/core': 7.22.8 - '@babel/helper-define-polyfill-provider': 0.1.5_@babel+core@7.22.8 + '@babel/helper-define-polyfill-provider': 0.1.5(@babel/core@7.22.8) core-js-compat: 3.31.1 transitivePeerDependencies: - supports-color dev: true - /babel-plugin-polyfill-corejs3/0.8.2_@babel+core@7.22.8: + /babel-plugin-polyfill-corejs3@0.8.2(@babel/core@7.22.8): resolution: {integrity: sha512-Cid+Jv1BrY9ReW9lIfNlNpsI53N+FN7gE+f73zLAUbr9C52W4gKLWSByx47pfDJsEysojKArqOtOKZSVIIUTuQ==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: '@babel/core': 7.22.8 - '@babel/helper-define-polyfill-provider': 0.4.1_@babel+core@7.22.8 + '@babel/helper-define-polyfill-provider': 0.4.1(@babel/core@7.22.8) core-js-compat: 3.31.1 transitivePeerDependencies: - supports-color dev: true - /babel-plugin-polyfill-regenerator/0.5.1_@babel+core@7.22.8: + /babel-plugin-polyfill-regenerator@0.5.1(@babel/core@7.22.8): resolution: {integrity: sha512-L8OyySuI6OSQ5hFy9O+7zFjyr4WhAfRjLIOkhQGYl+emwJkd/S4XXT1JpfrgR1jrQ1NcGiOh+yAdGlF8pnC3Jw==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: '@babel/core': 7.22.8 - '@babel/helper-define-polyfill-provider': 0.4.1_@babel+core@7.22.8 + '@babel/helper-define-polyfill-provider': 0.4.1(@babel/core@7.22.8) transitivePeerDependencies: - supports-color dev: true - /babel-plugin-react-docgen/4.2.1: + /babel-plugin-react-docgen@4.2.1: resolution: {integrity: sha512-UQ0NmGHj/HAqi5Bew8WvNfCk8wSsmdgNd8ZdMjBCICtyCJCq9LiqgqvjCYe570/Wg7AQArSq1VQ60Dd/CHN7mQ==} dependencies: ast-types: 0.14.2 @@ -9333,23 +10141,58 @@ packages: - supports-color dev: true - /babel-preset-solid/1.7.7_@babel+core@7.22.8: + /babel-preset-current-node-syntax@1.0.1(@babel/core@7.22.8): + resolution: {integrity: sha512-M7LQ0bxarkxQoN+vz5aJPsLBn77n8QgTFmo8WK0/44auK2xlCXrYcUxHFxgU7qW5Yzw/CjmLRK2uJzaCd7LvqQ==} + peerDependencies: + '@babel/core': ^7.0.0 + dependencies: + '@babel/core': 7.22.8 + '@babel/plugin-syntax-async-generators': 7.8.4(@babel/core@7.22.8) + '@babel/plugin-syntax-bigint': 7.8.3(@babel/core@7.22.8) + '@babel/plugin-syntax-class-properties': 7.12.13(@babel/core@7.22.8) + '@babel/plugin-syntax-import-meta': 7.10.4(@babel/core@7.22.8) + '@babel/plugin-syntax-json-strings': 7.8.3(@babel/core@7.22.8) + '@babel/plugin-syntax-logical-assignment-operators': 7.10.4(@babel/core@7.22.8) + '@babel/plugin-syntax-nullish-coalescing-operator': 7.8.3(@babel/core@7.22.8) + '@babel/plugin-syntax-numeric-separator': 7.10.4(@babel/core@7.22.8) + '@babel/plugin-syntax-object-rest-spread': 7.8.3(@babel/core@7.22.8) + '@babel/plugin-syntax-optional-catch-binding': 7.8.3(@babel/core@7.22.8) + '@babel/plugin-syntax-optional-chaining': 7.8.3(@babel/core@7.22.8) + '@babel/plugin-syntax-top-level-await': 7.14.5(@babel/core@7.22.8) + dev: true + + /babel-preset-jest@27.5.1(@babel/core@7.22.8): + resolution: {integrity: sha512-Nptf2FzlPCWYuJg41HBqXVT8ym6bXOevuCTbhxlUpjwtysGaIWFvDEjp4y+G7fl13FgOdjs7P/DmErqH7da0Ag==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + peerDependencies: + '@babel/core': ^7.0.0 + dependencies: + '@babel/core': 7.22.8 + babel-plugin-jest-hoist: 27.5.1 + babel-preset-current-node-syntax: 1.0.1(@babel/core@7.22.8) + dev: true + + /babel-preset-solid@1.7.7(@babel/core@7.22.8): resolution: {integrity: sha512-tdxVzx3kgcIjNXAOmGRbzIhFBPeJjSakiN9yM+IYdL/+LtXNnbGqb0Va5tJb8Sjbk+QVEriovCyuzB5T7jeTvg==} peerDependencies: '@babel/core': ^7.0.0 dependencies: '@babel/core': 7.22.8 - babel-plugin-jsx-dom-expressions: 0.36.10_@babel+core@7.22.8 + babel-plugin-jsx-dom-expressions: 0.36.10(@babel/core@7.22.8) dev: true - /bail/1.0.5: + /bail@1.0.5: resolution: {integrity: sha512-xFbRxM1tahm08yHBP16MMjVUAvDaBMD38zsM9EMAUN61omwLmKlOpB/Zku5QkjZ8TZ4vn53pj+t518cH0S03RQ==} dev: true - /balanced-match/1.0.2: + /balanced-match@1.0.2: resolution: {integrity: sha512-3oSeUO0TMV67hN1AmbXsK4yaqU7tjiHlbxRDZOpH0KW9+CeX4bRAaX0Anxt0tx2MrpRpWwQaPwIlISEJhYU5Pw==} - /base/0.11.2: + /base64-js@1.5.1: + resolution: {integrity: sha512-AKpaYlHn8t4SVbOHCy+b5+KKgvR4vrsD8vbvrbiQJps7fKDTkjkDry6ji0rUJjC0kzbNePLwzxq8iypo41qeWA==} + dev: true + + /base@0.11.2: resolution: {integrity: sha512-5T6P4xPgpp0YDFvSWwEZ4NoE3aM4QBQXDzmVbraCkFj8zHM+mba8SyqB5DbZWyR7mYHo6Y7BdQo3MoA4m0TeQg==} engines: {node: '>=0.10.0'} dependencies: @@ -9362,53 +10205,49 @@ packages: pascalcase: 0.1.1 dev: true - /base64-js/1.5.1: - resolution: {integrity: sha512-AKpaYlHn8t4SVbOHCy+b5+KKgvR4vrsD8vbvrbiQJps7fKDTkjkDry6ji0rUJjC0kzbNePLwzxq8iypo41qeWA==} - dev: true - - /bcrypt-pbkdf/1.0.2: + /bcrypt-pbkdf@1.0.2: resolution: {integrity: sha512-qeFIXtP4MSoi6NLqO12WfqARWWuCKi2Rn/9hJLEmtB5yTNr9DqFWkJRCf2qShWzPeAMRnOgCrq0sg/KLv5ES9w==} dependencies: tweetnacl: 0.14.5 dev: true - /better-opn/2.1.1: + /better-opn@2.1.1: resolution: {integrity: sha512-kIPXZS5qwyKiX/HcRvDYfmBQUa8XP17I0mYZZ0y4UhpYOSvtsLHDYqmomS+Mj20aDvD3knEiQ0ecQy2nhio3yA==} engines: {node: '>8.0.0'} dependencies: open: 7.4.2 dev: true - /big-integer/1.6.51: + /big-integer@1.6.51: resolution: {integrity: sha512-GPEid2Y9QU1Exl1rpO9B2IPJGHPSupF5GnVIP0blYvNOMer2bTvSWs1jGOUg04hTmu67nmLsQ9TBo1puaotBHg==} engines: {node: '>=0.6'} - /big.js/5.2.2: + /big.js@5.2.2: resolution: {integrity: sha512-vyL2OymJxmarO8gxMr0mhChsO9QGwhynfuu4+MHTAW6czfq9humCB7rKpUjDd9YUiDPU4mzpyupFSvOClAwbmQ==} dev: true - /binary-extensions/1.13.1: + /binary-extensions@1.13.1: resolution: {integrity: sha512-Un7MIEDdUC5gNpcGDV97op1Ywk748MpHcFTHoYs6qnj1Z3j7I53VG3nwZhKzoBZmbdRNnb6WRdFlwl7tSDuZGw==} engines: {node: '>=0.10.0'} dev: true optional: true - /binary-extensions/2.2.0: + /binary-extensions@2.2.0: resolution: {integrity: sha512-jDctJ/IVQbZoJykoeHbhXpOlNBqGNcwXJKJog42E5HDPUwQTSdjCHdihjj0DlnheQ7blbT6dHOafNAiS8ooQKA==} engines: {node: '>=8'} dev: true - /bindings/1.5.0: + /bindings@1.5.0: resolution: {integrity: sha512-p2q/t/mhvuOj/UeLlV6566GD/guowlr0hHxClI0W9m7MWYkL1F0hLo+0Aexs9HSPCtR1SXQ0TD3MMKrXZajbiQ==} dependencies: file-uri-to-path: 1.0.0 dev: true optional: true - /birpc/0.2.12: + /birpc@0.2.12: resolution: {integrity: sha512-6Wz9FXuJ/FE4gDH+IGQhrYdalAvAQU1Yrtcu1UlMk3+9mMXxIRXiL+MxUcGokso42s+Fy+YoUXGLOdOs0siV3A==} - /bl/4.1.0: + /bl@4.1.0: resolution: {integrity: sha512-1W07cM9gS6DcLperZfFSj+bWLtaPGSOHWhPiGzXmvVJbRLdG82sH/Kn8EtW1VqWVA54AKf2h5k5BbnIbwF3h6w==} dependencies: buffer: 5.7.1 @@ -9416,23 +10255,23 @@ packages: readable-stream: 3.6.2 dev: true - /blob-util/2.0.2: + /blob-util@2.0.2: resolution: {integrity: sha512-T7JQa+zsXXEa6/8ZhHcQEW1UFfVM49Ts65uBkFL6fz2QmrElqmbajIDJvuA0tEhRe5eIjpV9ZF+0RfZR9voJFQ==} dev: true - /bluebird/3.7.2: + /bluebird@3.7.2: resolution: {integrity: sha512-XpNj6GDQzdfW+r2Wnn7xiSAd7TM3jzkxGXBGTtWKuSXv1xUV+azxAm8jdWZN06QTQk+2N2XB9jRDkvbmQmcRtg==} dev: true - /bn.js/4.12.0: + /bn.js@4.12.0: resolution: {integrity: sha512-c98Bf3tPniI+scsdk237ku1Dc3ujXQTSgyiPUDEOe7tRkhrqridvh8klBv0HCEso1OLOYcHuCv/cS6DNxKH+ZA==} dev: true - /bn.js/5.2.1: + /bn.js@5.2.1: resolution: {integrity: sha512-eXRvHzWyYPBuB4NBy0cmYQjGitUrtqwbvlzP3G6VFnNRbsZQIxQ10PbKKHt8gZ/HW/D/747aDl+QkDqg3KQLMQ==} dev: true - /body-parser/1.20.1: + /body-parser@1.20.1: resolution: {integrity: sha512-jWi7abTbYwajOytWCQc37VulmWiRae5RyTpaCyDcS5/lMdtwSz5lOpDE67srw/HYe35f1z3fDQw+3txg7gNtWw==} engines: {node: '>= 0.8', npm: 1.2.8000 || >= 1.4.16} dependencies: @@ -9452,15 +10291,15 @@ packages: - supports-color dev: true - /body-scroll-lock/4.0.0-beta.0: + /body-scroll-lock@4.0.0-beta.0: resolution: {integrity: sha512-a7tP5+0Mw3YlUJcGAKUqIBkYYGlYxk2fnCasq/FUph1hadxlTRjF+gAcZksxANnaMnALjxEddmSi/H3OR8ugcQ==} dev: true - /boolbase/1.0.0: + /boolbase@1.0.0: resolution: {integrity: sha512-JZOSA7Mo9sNGB8+UjSgzdLtokWAky1zbztM3WRLCbZ70/3cTANmQmOdR7y2g+J0e2WXywy1yS468tY+IruqEww==} dev: true - /boxen/5.1.2: + /boxen@5.1.2: resolution: {integrity: sha512-9gYgQKXx+1nP8mP7CzFyaUARhg7D3n1dF/FnErWmu9l6JvGpNUN278h0aSb+QjoiKSWG+iZ3uHrcqk0qrY9RQQ==} engines: {node: '>=10'} dependencies: @@ -9474,26 +10313,26 @@ packages: wrap-ansi: 7.0.0 dev: true - /bplist-parser/0.1.1: + /bplist-parser@0.1.1: resolution: {integrity: sha512-2AEM0FXy8ZxVLBuqX0hqt1gDwcnz2zygEkQ6zaD5Wko/sB9paUNwlpawrFtKeHUAQUOzjVy9AO4oeonqIHKA9Q==} dependencies: big-integer: 1.6.51 dev: true optional: true - /brace-expansion/1.1.11: + /brace-expansion@1.1.11: resolution: {integrity: sha512-iCuPHDFgrHX7H2vEI/5xpz07zSHB00TpugqhmYtVmMO6518mCuRMoOYFldEBl0g187ufozdaHgWKcYFb61qGiA==} dependencies: balanced-match: 1.0.2 concat-map: 0.0.1 - /brace-expansion/2.0.1: + /brace-expansion@2.0.1: resolution: {integrity: sha512-XnAIvQ8eM+kC6aULx6wuQiwVsnzsi9d3WxzV3FpWTGA19F621kwdbsAcFKXgKUHZWsy+mY6iL1sHTxWEFCytDA==} dependencies: balanced-match: 1.0.2 dev: true - /braces/2.3.2: + /braces@2.3.2: resolution: {integrity: sha512-aNdbnj9P8PjdXU4ybaWLK2IF3jc/EoDYbC7AazW6to3TRsfXxscC9UXOB5iDiEQrkyIbWp2SLQda4+QAa7nc3w==} engines: {node: '>=0.10.0'} dependencies: @@ -9511,13 +10350,13 @@ packages: - supports-color dev: true - /braces/3.0.2: + /braces@3.0.2: resolution: {integrity: sha512-b8um+L1RzM3WDSzvhm6gIz1yfTbBt6YTlcEKAvsmqCZZFw46z626lVj9j1yEPW33H5H+lBQpZMP1k8l+78Ha0A==} engines: {node: '>=8'} dependencies: fill-range: 7.0.1 - /broadcast-channel/3.7.0: + /broadcast-channel@3.7.0: resolution: {integrity: sha512-cIAKJXAxGJceNZGTZSBzMxzyOn72cVgPnKx4dc6LRjQgbaJUQqhy5rzL3zbMxkMWsGKkv2hSFkPRMEXfoMZ2Mg==} dependencies: '@babel/runtime': 7.22.6 @@ -9530,11 +10369,15 @@ packages: unload: 2.2.0 dev: false - /brorand/1.1.0: + /brorand@1.1.0: resolution: {integrity: sha512-cKV8tMCEpQs4hK/ik71d6LrPOnpkpGBR0wzxqr68g2m/LB2GxVYQroAjMJZRVM1Y4BCjCKc3vAamxSzOY2RP+w==} dev: true - /browserify-aes/1.2.0: + /browser-process-hrtime@1.0.0: + resolution: {integrity: sha512-9o5UecI3GhkpM6DrXr69PblIuWxPKk9Y0jHBRhdocZ2y7YECBFCsHm79Pr3OyR2AvjhDkabFJaDJMYRazHgsow==} + dev: true + + /browserify-aes@1.2.0: resolution: {integrity: sha512-+7CHXqGuspUn/Sl5aO7Ea0xWGAtETPXNSAjHo48JfLdPWcMng33Xe4znFvQweqc/uzk5zSOI3H52CYnjCfb5hA==} dependencies: buffer-xor: 1.0.3 @@ -9545,7 +10388,7 @@ packages: safe-buffer: 5.2.1 dev: true - /browserify-cipher/1.0.1: + /browserify-cipher@1.0.1: resolution: {integrity: sha512-sPhkz0ARKbf4rRQt2hTpAHqn47X3llLkUGn+xEJzLjwY8LRs2p0v7ljvI5EyoRO/mexrNunNECisZs+gw2zz1w==} dependencies: browserify-aes: 1.2.0 @@ -9553,7 +10396,7 @@ packages: evp_bytestokey: 1.0.3 dev: true - /browserify-des/1.0.2: + /browserify-des@1.0.2: resolution: {integrity: sha512-BioO1xf3hFwz4kc6iBhI3ieDFompMhrMlnDFC4/0/vd5MokpuAc3R+LYbwTA9A5Yc9pq9UYPqffKpW2ObuwX5A==} dependencies: cipher-base: 1.0.4 @@ -9562,14 +10405,14 @@ packages: safe-buffer: 5.2.1 dev: true - /browserify-rsa/4.1.0: + /browserify-rsa@4.1.0: resolution: {integrity: sha512-AdEER0Hkspgno2aR97SAf6vi0y0k8NuOpGnVH3O99rcA5Q6sh8QxcngtHuJ6uXwnfAXNM4Gn1Gb7/MV1+Ymbog==} dependencies: bn.js: 5.2.1 randombytes: 2.1.0 dev: true - /browserify-sign/4.2.1: + /browserify-sign@4.2.1: resolution: {integrity: sha512-/vrA5fguVAKKAVTNJjgSm1tRQDHUU6DbwO9IROu/0WAzC8PKhucDSh18J0RMvVeHAn5puMd+QHC2erPRNf8lmg==} dependencies: bn.js: 5.2.1 @@ -9583,13 +10426,13 @@ packages: safe-buffer: 5.2.1 dev: true - /browserify-zlib/0.2.0: + /browserify-zlib@0.2.0: resolution: {integrity: sha512-Z942RysHXmJrhqk88FmKBVq/v5tqmSkDz7p54G/MGyjMnCFFnC79XWNbg+Vta8W6Wb2qtSZTSxIGkJrRpCFEiA==} dependencies: pako: 1.0.11 dev: true - /browserslist/4.21.9: + /browserslist@4.21.9: resolution: {integrity: sha512-M0MFoZzbUrRU4KNfCrDLnvyE7gub+peetoTid3TBIqtunaDJyXlwhakT+/VkvSXcfIzFfK/nkCs4nmyTmxdNSg==} engines: {node: ^6 || ^7 || ^8 || ^9 || ^10 || ^11 || ^12 || >=13.7} hasBin: true @@ -9597,27 +10440,27 @@ packages: caniuse-lite: 1.0.30001515 electron-to-chromium: 1.4.457 node-releases: 2.0.13 - update-browserslist-db: 1.0.11_browserslist@4.21.9 + update-browserslist-db: 1.0.11(browserslist@4.21.9) - /bser/2.1.1: + /bser@2.1.1: resolution: {integrity: sha512-gQxTNE/GAfIIrmHLUE3oJyp5FO6HRBfhjnw4/wMmA63ZGDJnWBmgY/lyQBpnDUkGmAhbSe39tx2d/iTOAfglwQ==} dependencies: node-int64: 0.4.0 dev: true - /buffer-crc32/0.2.13: + /buffer-crc32@0.2.13: resolution: {integrity: sha512-VO9Ht/+p3SN7SKWqcrgEzjGbRSJYTx+Q1pTQC0wrWqHx0vpJraQ6GtHx8tvcg1rlK1byhU5gccxgOgj7B0TDkQ==} dev: true - /buffer-from/1.1.2: + /buffer-from@1.1.2: resolution: {integrity: sha512-E+XQCRwSbaaiChtv6k6Dwgc+bx+Bs6vuKJHHl5kox/BaKbhiXzqQOwK4cO22yElGp2OCmjwVhT3HmxgyPGnJfQ==} dev: true - /buffer-xor/1.0.3: + /buffer-xor@1.0.3: resolution: {integrity: sha512-571s0T7nZWK6vB67HI5dyUF7wXiNcfaPPPTl6zYCNApANjIvYJTg7hlud/+cJpdAhS7dVzqMLmfhfHR3rAcOjQ==} dev: true - /buffer/4.9.2: + /buffer@4.9.2: resolution: {integrity: sha512-xq+q3SRMOxGivLhBNaUdC64hDTQwejJ+H0T/NB1XMtTVEwNTrfFF3gAxiyW0Bu/xWEGhjVKgUcMhCrUy2+uCWg==} dependencies: base64-js: 1.5.1 @@ -9625,36 +10468,36 @@ packages: isarray: 1.0.0 dev: true - /buffer/5.7.1: + /buffer@5.7.1: resolution: {integrity: sha512-EHcyIPBQ4BSGlvjB16k5KgAJ27CIsHY/2JBmCRReo48y9rQ3MaUzWX3KVlBa4U7MyX02HdVj0K7C3WaB3ju7FQ==} dependencies: base64-js: 1.5.1 ieee754: 1.2.1 dev: true - /buffer/6.0.3: + /buffer@6.0.3: resolution: {integrity: sha512-FTiCpNxtwiZZHEZbcbTIcZjERVICn9yq/pDFkTl95/AxzD1naBctN7YO68riM/gLSDY7sdrMby8hofADYuuqOA==} dependencies: base64-js: 1.5.1 ieee754: 1.2.1 dev: true - /builtin-modules/3.3.0: + /builtin-modules@3.3.0: resolution: {integrity: sha512-zhaCDicdLuWN5UbN5IMnFqNMhNfo919sH85y2/ea+5Yg9TsTkeZxpL+JLbp6cgYFS4sRLp3YV4S6yDuqVWHYOw==} engines: {node: '>=6'} dev: true - /builtin-status-codes/3.0.0: + /builtin-status-codes@3.0.0: resolution: {integrity: sha512-HpGFw18DgFWlncDfjTa2rcQ4W88O1mC8e8yZ2AvQY5KDaktSTwo+KRf6nHK6FRI5FyRyb/5T6+TSxfP7QyGsmQ==} dev: true - /builtins/5.0.1: + /builtins@5.0.1: resolution: {integrity: sha512-qwVpFEHNfhYJIzNRBvd2C1kyo6jz3ZSMPyyuR47OPdiKWlbYnZNyDWuyR175qDnAJLiCo5fBBqPb3RiXgWlkOQ==} dependencies: semver: 7.5.4 dev: true - /bumpp/9.1.1: + /bumpp@9.1.1: resolution: {integrity: sha512-T7/2QmRNhHRkH2+HgDs/xk4keom3nlCjwQn6kHdz0I0dQMVrs+YMOH5HyuhV0R3tha/tTYP030RG9uQKpQ9CRg==} engines: {node: '>=10'} hasBin: true @@ -9669,7 +10512,7 @@ packages: - supports-color dev: true - /bundle-require/4.0.1_esbuild@0.17.19: + /bundle-require@4.0.1(esbuild@0.17.19): resolution: {integrity: sha512-9NQkRHlNdNpDBGmLpngF3EFDcwodhMUuLz9PaWYciVcQF9SE4LFjM2DB/xV1Li5JiuDMv7ZUWuC3rGbqR0MAXQ==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} peerDependencies: @@ -9679,24 +10522,24 @@ packages: load-tsconfig: 0.2.5 dev: true - /busboy/1.6.0: + /busboy@1.6.0: resolution: {integrity: sha512-8SFQbg/0hQ9xy3UNTB0YEnsNBbWfhf7RtnzpL7TkBiTBRfrQ9Fxcnz7VJsleJpyp6rVLvXiuORqjlHi5q+PYuA==} engines: {node: '>=10.16.0'} dependencies: streamsearch: 1.1.0 dev: true - /bytes/3.0.0: + /bytes@3.0.0: resolution: {integrity: sha512-pMhOfFDPiv9t5jjIXkHosWmkSyQbvsgEVNkz0ERHbuLh2T/7j4Mqqpz523Fe8MVY89KC6Sh/QfS2sM+SjgFDcw==} engines: {node: '>= 0.8'} dev: true - /bytes/3.1.2: + /bytes@3.1.2: resolution: {integrity: sha512-/Nf7TyzTx6S3yRJObOAV7956r8cr2+Oj8AC5dt8wSP3BQAoeX58NoHyCU8P8zGkNXStjTSi6fzO6F0pBdcYbEg==} engines: {node: '>= 0.8'} dev: true - /c12/1.4.2: + /c12@1.4.2: resolution: {integrity: sha512-3IP/MuamSVRVw8W8+CHWAz9gKN4gd+voF2zm/Ln6D25C2RhytEZ1ABbC8MjKr4BR9rhoV1JQ7jJA158LDiTkLg==} dependencies: chokidar: 3.5.3 @@ -9714,7 +10557,7 @@ packages: - supports-color dev: true - /c8/7.14.0: + /c8@7.14.0: resolution: {integrity: sha512-i04rtkkcNcCf7zsQcSv/T9EbUn4RXQ6mropeMcjFOsQXQ0iGLAr/xT6TImQg4+U9hmNpN9XdvPkjUL1IzbgxJw==} engines: {node: '>=10.12.0'} hasBin: true @@ -9733,11 +10576,11 @@ packages: yargs-parser: 20.2.9 dev: true - /cac/6.7.14: + /cac@6.7.14: resolution: {integrity: sha512-b6Ilus+c3RrdDk+JhLKUAQfzzgLEPy6wcXqS7f/xe1EETvsDP6GORG7SFuOs6cID5YkqchW/LXZbX5bc8j7ZcQ==} engines: {node: '>=8'} - /cacache/12.0.4: + /cacache@12.0.4: resolution: {integrity: sha512-a0tMB40oefvuInr4Cwb3GerbL9xTj1D5yg0T5xrjGCGyfvbxseIXX7BAO/u/hIXdafzOI5JC3wDwHyf24buOAQ==} dependencies: bluebird: 3.7.2 @@ -9750,14 +10593,14 @@ packages: mississippi: 3.0.0 mkdirp: 0.5.6 move-concurrently: 1.0.1 - promise-inflight: 1.0.1_bluebird@3.7.2 + promise-inflight: 1.0.1(bluebird@3.7.2) rimraf: 2.7.1 ssri: 6.0.2 unique-filename: 1.1.1 y18n: 4.0.3 dev: true - /cacache/15.3.0: + /cacache@15.3.0: resolution: {integrity: sha512-VVdYzXEn+cnbXpFgWs5hTT7OScegHVmLhJIR8Ufqk3iFD6A6j5iSX1KuBTfNEv4tdJWE2PzA6IVFtcLC7fN9wQ==} engines: {node: '>= 10'} dependencies: @@ -9774,7 +10617,7 @@ packages: minipass-pipeline: 1.2.4 mkdirp: 1.0.4 p-map: 4.0.0 - promise-inflight: 1.0.1 + promise-inflight: 1.0.1(bluebird@3.7.2) rimraf: 3.0.2 ssri: 8.0.1 tar: 6.1.15 @@ -9783,7 +10626,7 @@ packages: - bluebird dev: true - /cache-base/1.0.1: + /cache-base@1.0.1: resolution: {integrity: sha512-AKcdTnFSWATd5/GCPRxr2ChwIJ85CeyrEyjRHlKxQ56d4XJMGym0uAiKn0xbLOGOl3+yRpOTi484dVCEc5AUzQ==} engines: {node: '>=0.10.0'} dependencies: @@ -9798,12 +10641,12 @@ packages: unset-value: 1.0.0 dev: true - /cacheable-lookup/7.0.0: + /cacheable-lookup@7.0.0: resolution: {integrity: sha512-+qJyx4xiKra8mZrcwhjMRMUhD5NR1R8esPkzIYxX96JiecFoxAXFuz/GpR3+ev4PE1WamHip78wV0vcmPQtp8w==} engines: {node: '>=14.16'} dev: true - /cacheable-request/10.2.12: + /cacheable-request@10.2.12: resolution: {integrity: sha512-qtWGB5kn2OLjx47pYUkWicyOpK1vy9XZhq8yRTXOy+KAmjjESSRLx6SiExnnaGGUP1NM6/vmygMu0fGylNh9tw==} engines: {node: '>=14.16'} dependencies: @@ -9816,39 +10659,39 @@ packages: responselike: 3.0.0 dev: true - /cachedir/2.3.0: + /cachedir@2.3.0: resolution: {integrity: sha512-A+Fezp4zxnit6FanDmv9EqXNAi3vt9DWp51/71UEhXukb7QUuvtv9344h91dyAxuTLoSYJFU299qzR3tzwPAhw==} engines: {node: '>=6'} dev: true - /call-bind/1.0.2: + /call-bind@1.0.2: resolution: {integrity: sha512-7O+FbCihrB5WGbFYesctwmTKae6rOiIzmz1icreWJ+0aA7LJfuqhEso2T9ncpcFtzMQtzXf2QGGueWJGTYsqrA==} dependencies: function-bind: 1.1.1 get-intrinsic: 1.2.1 dev: true - /call-me-maybe/1.0.2: + /call-me-maybe@1.0.2: resolution: {integrity: sha512-HpX65o1Hnr9HH25ojC1YGs7HCQLq0GCOibSaWER0eNpgJ/Z1MZv2mTc7+xh6WOPxbRVcmgbv4hGU+uSQ/2xFZQ==} dev: true - /callsites/3.1.0: + /callsites@3.1.0: resolution: {integrity: sha512-P8BjAsXvZS+VIDUI11hHCQEv74YT67YUi5JJFNWIqL235sBmjX4+qx9Muvls5ivyNENctx46xQLQ3aTuE7ssaQ==} engines: {node: '>=6'} - /camel-case/4.1.2: + /camel-case@4.1.2: resolution: {integrity: sha512-gxGWBrTT1JuMx6R+o5PTXMmUnhnVzLQ9SNutD4YqKtI6ap897t3tKECYla6gCWEkplXnlNybEkZg9GEGxKFCgw==} dependencies: pascal-case: 3.1.2 tslib: 2.6.0 dev: true - /camelcase-css/2.0.1: + /camelcase-css@2.0.1: resolution: {integrity: sha512-QOSvevhslijgYwRx6Rv7zKdMF8lbRmx+uQGx2+vDc+KI/eBnsy9kit5aj23AgGu3pa4t9AgwbnXWqS+iOY+2aA==} engines: {node: '>= 6'} dev: true - /camelcase-keys/2.1.0: + /camelcase-keys@2.1.0: resolution: {integrity: sha512-bA/Z/DERHKqoEOrp+qeGKw1QlvEQkGZSc0XaY6VnTxZr+Kv1G5zFwttpjv8qxZ/sBPT4nthwZaAcsAZTJlSKXQ==} engines: {node: '>=0.10.0'} dependencies: @@ -9857,51 +10700,51 @@ packages: dev: true optional: true - /camelcase/2.1.1: + /camelcase@2.1.1: resolution: {integrity: sha512-DLIsRzJVBQu72meAKPkWQOLcujdXT32hwdfnkI1frSiSRMK1MofjKHf+MEx0SB6fjEFXL8fBDv1dKymBlOp4Qw==} engines: {node: '>=0.10.0'} dev: true optional: true - /camelcase/5.3.1: + /camelcase@5.3.1: resolution: {integrity: sha512-L28STB170nwWS63UjtlEOE3dldQApaJXZkOI1uMFfzf3rRuPegHaHesyee+YxQ+W6SvRDQV6UrdOdRiR153wJg==} engines: {node: '>=6'} dev: true - /camelcase/6.3.0: + /camelcase@6.3.0: resolution: {integrity: sha512-Gmy6FhYlCY7uOElZUSbxo2UCDH8owEk996gkbrpsgGtrJLM3J7jGxl9Ic7Qwwj4ivOE5AWZWRMecDdF7hqGjFA==} engines: {node: '>=10'} dev: true - /caniuse-lite/1.0.30001515: + /caniuse-lite@1.0.30001515: resolution: {integrity: sha512-eEFDwUOZbE24sb+Ecsx3+OvNETqjWIdabMy52oOkIgcUtAsQifjUG9q4U9dgTHJM2mfk4uEPxc0+xuFdJ629QA==} - /capture-exit/2.0.0: + /capture-exit@2.0.0: resolution: {integrity: sha512-PiT/hQmTonHhl/HFGN+Lx3JJUznrVYJ3+AQsnthneZbvW7x+f08Tk7yLJTLEOUvBTbduLeeBkxEaYXUOUrRq6g==} engines: {node: 6.* || 8.* || >= 10.*} dependencies: rsvp: 4.8.5 dev: true - /case-sensitive-paths-webpack-plugin/2.4.0: + /case-sensitive-paths-webpack-plugin@2.4.0: resolution: {integrity: sha512-roIFONhcxog0JSSWbvVAh3OocukmSgpqOH6YpMkCvav/ySIV3JKg4Dc8vYtQjYi/UxpNE36r/9v+VqTQqgkYmw==} engines: {node: '>=4'} dev: true - /caseless/0.12.0: + /caseless@0.12.0: resolution: {integrity: sha512-4tYFyifaFfGacoiObjJegolkwSU4xQNGbVgUiNYVUxbQ2x2lUsFvY4hVgVzGiIe6WLOPqycWXA40l+PWsxthUw==} dev: true - /ccount/1.1.0: + /ccount@1.1.0: resolution: {integrity: sha512-vlNK021QdI7PNeiUh/lKkC/mNHHfV0m/Ad5JoI0TYtlBnJAslM/JIkm/tGC88bkLIwO6OQ5uV6ztS6kVAtCDlg==} dev: true - /chai-subset/1.6.0: + /chai-subset@1.6.0: resolution: {integrity: sha512-K3d+KmqdS5XKW5DWPd5sgNffL3uxdDe+6GdnJh3AYPhwnBGRY5urfvfcbRtWIvvpz+KxkL9FeBB6MZewLUNwug==} engines: {node: '>=4'} dev: true - /chai/4.3.7: + /chai@4.3.7: resolution: {integrity: sha512-HLnAzZ2iupm25PlN0xFreAlBA5zaBSv3og0DdeGA4Ar6h6rJ3A0rolRUKJhSF2V10GZKDgWF/VmAEsNWjCRB+A==} engines: {node: '>=4'} dependencies: @@ -9914,7 +10757,7 @@ packages: type-detect: 4.0.8 dev: false - /chalk/1.1.3: + /chalk@1.1.3: resolution: {integrity: sha512-U3lRVLMSlsCfjqYPbLyVv11M9CPW4I728d6TCKMAOJueEeB9/8o+eSsMnxPJD+Q+K909sdESg7C+tIkoH6on1A==} engines: {node: '>=0.10.0'} dependencies: @@ -9925,7 +10768,7 @@ packages: supports-color: 2.0.0 dev: true - /chalk/2.4.2: + /chalk@2.4.2: resolution: {integrity: sha512-Mti+f9lpJNcwF4tWV8/OrTTtF1gZi+f8FqlyAdouralcFWFQWF2+NgCHShjkCb+IFBLq9buZwE1xckQU4peSuQ==} engines: {node: '>=4'} dependencies: @@ -9933,7 +10776,7 @@ packages: escape-string-regexp: 1.0.5 supports-color: 5.5.0 - /chalk/3.0.0: + /chalk@3.0.0: resolution: {integrity: sha512-4D3B6Wf41KOYRFdszmDqMCGq5VV/uMAB273JILmO+3jAlh8X4qDtdtgCR3fxtbLEMzSx22QdhnDcJvu2u1fVwg==} engines: {node: '>=8'} dependencies: @@ -9941,7 +10784,7 @@ packages: supports-color: 7.2.0 dev: true - /chalk/4.1.1: + /chalk@4.1.1: resolution: {integrity: sha512-diHzdDKxcU+bAsUboHLPEDQiw0qEe0qd7SYUn3HgcFlWgbDcfLGswOHYeGrHKzG9z6UYf01d9VFMfZxPM1xZSg==} engines: {node: '>=10'} dependencies: @@ -9949,7 +10792,7 @@ packages: supports-color: 7.2.0 dev: true - /chalk/4.1.2: + /chalk@4.1.2: resolution: {integrity: sha512-oKnbhFyRIXpUuez8iBMmyEa4nbj4IOQyuhc/wy9kY7/WVPcwIO9VA668Pu8RkO7+0G76SLROeyw9CpQ061i4mA==} engines: {node: '>=10'} dependencies: @@ -9957,42 +10800,47 @@ packages: supports-color: 7.2.0 dev: true - /chalk/5.2.0: + /chalk@5.2.0: resolution: {integrity: sha512-ree3Gqw/nazQAPuJJEy+avdl7QfZMcUvmHIKgEZkGL+xOBzRvup5Hxo6LHuMceSxOabuJLJm5Yp/92R9eMmMvA==} engines: {node: ^12.17.0 || ^14.13 || >=16.0.0} dev: true - /chalk/5.3.0: + /chalk@5.3.0: resolution: {integrity: sha512-dLitG79d+GV1Nb/VYcCDFivJeK1hiukt9QjRNVOsUtTy1rR1YJsmpGGTZ3qJos+uw7WmWF4wUwBd9jxjocFC2w==} engines: {node: ^12.17.0 || ^14.13 || >=16.0.0} dev: true - /character-entities-legacy/1.1.4: + /char-regex@1.0.2: + resolution: {integrity: sha512-kWWXztvZ5SBQV+eRgKFeh8q5sLuZY2+8WUIzlxWVTg+oGwY14qylx1KbKzHd8P6ZYkAg0xyIDU9JMHhyJMZ1jw==} + engines: {node: '>=10'} + dev: true + + /character-entities-legacy@1.1.4: resolution: {integrity: sha512-3Xnr+7ZFS1uxeiUDvV02wQ+QDbc55o97tIV5zHScSPJpcLm/r0DFPcoY3tYRp+VZukxuMeKgXYmsXQHO05zQeA==} dev: true - /character-entities/1.2.4: + /character-entities@1.2.4: resolution: {integrity: sha512-iBMyeEHxfVnIakwOuDXpVkc54HijNgCyQB2w0VfGQThle6NXn50zU6V/u+LDhxHcDUPojn6Kpga3PTAD8W1bQw==} dev: true - /character-reference-invalid/1.1.4: + /character-reference-invalid@1.1.4: resolution: {integrity: sha512-mKKUkUbhPpQlCOfIuZkvSEgktjPFIsZKRRbC6KWVEMvlzblj3i3asQv5ODsrwt0N3pHAEvjP8KTQPHkp0+6jOg==} dev: true - /chardet/0.7.0: + /chardet@0.7.0: resolution: {integrity: sha512-mT8iDcrh03qDGRRmoA2hmBJnxpllMR+0/0qlzjqZES6NdiWDcZkCNAk4rPFZ9Q85r27unkiNNg8ZOiwZXBHwcA==} dev: true - /check-error/1.0.2: + /check-error@1.0.2: resolution: {integrity: sha512-BrgHpW9NURQgzoNyjfq0Wu6VFO6D7IZEmJNdtgNqpzGG8RuNFHt2jQxWlAs4HMe119chBnv+34syEZtc6IhLtA==} dev: false - /check-more-types/2.24.0: + /check-more-types@2.24.0: resolution: {integrity: sha512-Pj779qHxV2tuapviy1bSZNEL1maXr13bPYpsvSDB68HlYcYuhlDrmGd63i0JHMCLKzc7rUSNIrpdJlhVlNwrxA==} engines: {node: '>= 0.8.0'} dev: true - /cheerio-select/2.1.0: + /cheerio-select@2.1.0: resolution: {integrity: sha512-9v9kG0LvzrlcungtnJtpGNxY+fzECQKhK4EGJX2vByejiMX84MFNQw4UxPJl3bFbTMw+Dfs37XaIkCwTZfLh4g==} dependencies: boolbase: 1.0.0 @@ -10003,7 +10851,7 @@ packages: domutils: 3.1.0 dev: true - /cheerio/1.0.0-rc.12: + /cheerio@1.0.0-rc.12: resolution: {integrity: sha512-VqR8m68vM46BNnuZ5NtnGBKIE/DfN0cRIzg9n40EIq9NOv90ayxLBXA8fXC5gquFRGJSTRqBq25Jt2ECLR431Q==} engines: {node: '>= 6'} dependencies: @@ -10016,7 +10864,7 @@ packages: parse5-htmlparser2-tree-adapter: 7.0.0 dev: true - /chokidar/2.1.8: + /chokidar@2.1.8: resolution: {integrity: sha512-ZmZUazfOzf0Nve7duiCKD23PFSCs4JPoYyccjUFF3aQkQadqBhfzhjkwBH2mNOG9cTBwhamM37EIsIkZw3nRgg==} deprecated: Chokidar 2 does not receive security updates since 2019. Upgrade to chokidar 3 with 15x fewer dependencies dependencies: @@ -10038,7 +10886,7 @@ packages: dev: true optional: true - /chokidar/3.5.3: + /chokidar@3.5.3: resolution: {integrity: sha512-Dr3sfKRP6oTcjf2JmUmFJfeVMvXBdegxB0iVQ5eb2V10uFJUCAS8OByZdVAyVb8xXNz3GjjTgj9kLWsZTqE6kw==} engines: {node: '>= 8.10.0'} dependencies: @@ -10053,16 +10901,16 @@ packages: fsevents: 2.3.2 dev: true - /chownr/1.1.4: + /chownr@1.1.4: resolution: {integrity: sha512-jJ0bqzaylmJtVnNgzTeSOs8DPavpbYgEr/b0YL8/2GO3xJEhInFmhKMUnEJQjZumK7KXGFhUy89PrsJWlakBVg==} dev: true - /chownr/2.0.0: + /chownr@2.0.0: resolution: {integrity: sha512-bIomtDF5KGpdogkLd9VspvFzk9KfpyyGlS8YFVZl7TGPBHL5snIOnxeshwVgPteQ9b4Eydl+pVbIyE1DcvCWgQ==} engines: {node: '>=10'} dev: true - /chrome-launcher/0.15.2: + /chrome-launcher@0.15.2: resolution: {integrity: sha512-zdLEwNo3aUVzIhKhTtXfxhdvZhUghrnmkvcAq2NoDd+LeOHKf03H5jwZ8T/STsAlzyALkBVK552iaG1fGf1xVQ==} engines: {node: '>=12.13.0'} hasBin: true @@ -10075,12 +10923,12 @@ packages: - supports-color dev: true - /chrome-trace-event/1.0.3: + /chrome-trace-event@1.0.3: resolution: {integrity: sha512-p3KULyQg4S7NIHixdwbGX+nFHkoBiA4YQmyWtjb8XngSKV124nJmRysgAeujbUVb15vh+RvFUfCPqU7rXk+hZg==} engines: {node: '>=6.0'} dev: true - /chromium-bidi/0.4.9_5222unh4tkeylqma7dhccidrk4: + /chromium-bidi@0.4.9(devtools-protocol@0.0.1120988): resolution: {integrity: sha512-u3DC6XwgLCA9QJ5ak1voPslCmacQdulZNCPsI3qNXxSnEcZS7DFIbww+5RM2bznMEje7cc0oydavRLRvOIZtHw==} peerDependencies: devtools-protocol: '*' @@ -10089,23 +10937,27 @@ packages: mitt: 3.0.0 dev: true - /ci-info/2.0.0: + /ci-info@2.0.0: resolution: {integrity: sha512-5tK7EtrZ0N+OLFMthtqOj4fI2Jeb88C4CAZPu25LDVUgXJ0A3Js4PMGqrn0JU1W0Mh1/Z8wZzYPxqUrXeBboCQ==} dev: true - /ci-info/3.8.0: + /ci-info@3.8.0: resolution: {integrity: sha512-eXTggHWSooYhq49F2opQhuHWgzucfF2YgODK4e1566GQs5BIfP30B0oenwBJHfWxAs2fyPB1s7Mg949zLf61Yw==} engines: {node: '>=8'} dev: true - /cipher-base/1.0.4: + /cipher-base@1.0.4: resolution: {integrity: sha512-Kkht5ye6ZGmwv40uUDZztayT2ThLQGfnj/T71N/XzeZeo3nf8foyW7zGTsPYkEya3m5f3cAypH+qe7YOrM1U2Q==} dependencies: inherits: 2.0.4 safe-buffer: 5.2.1 dev: true - /class-utils/0.3.6: + /cjs-module-lexer@1.2.3: + resolution: {integrity: sha512-0TNiGstbQmCFwt4akjjBg5pLRTSyj/PkWQ1ZoO2zntmg9yLqSRxwEa4iCfQLGjqhiqBfOJa7W/E8wfGrTDmlZQ==} + dev: true + + /class-utils@0.3.6: resolution: {integrity: sha512-qOhPa/Fj7s6TY8H8esGu5QNpMMQxz79h+urzrNYN6mn+9BnxlDGf5QZ+XeCDsxSjPqsSR56XOZOJmpeurnLMeg==} engines: {node: '>=0.10.0'} dependencies: @@ -10115,54 +10967,54 @@ packages: static-extend: 0.1.2 dev: true - /classnames/2.3.2: + /classnames@2.3.2: resolution: {integrity: sha512-CSbhY4cFEJRe6/GQzIk5qXZ4Jeg5pcsP7b5peFSDpffpe1cqjASH/n9UTjBwOp6XpMSTwQ8Za2K5V02ueA7Tmw==} dev: false - /clean-css/4.2.4: + /clean-css@4.2.4: resolution: {integrity: sha512-EJUDT7nDVFDvaQgAo2G/PJvxmp1o/c6iXLbswsBbUFXi1Nr+AjA2cKmfbKDMjMvzEe75g3P6JkaDDAKk96A85A==} engines: {node: '>= 4.0'} dependencies: source-map: 0.6.1 dev: true - /clean-regexp/1.0.0: + /clean-regexp@1.0.0: resolution: {integrity: sha512-GfisEZEJvzKrmGWkvfhgzcz/BllN1USeqD2V6tg14OAOgaCD2Z/PUEuxnAZ/nPvmaHRG7a8y77p1T/IRQ4D1Hw==} engines: {node: '>=4'} dependencies: escape-string-regexp: 1.0.5 dev: true - /clean-stack/2.2.0: + /clean-stack@2.2.0: resolution: {integrity: sha512-4diC9HaTE+KRAMWhDhrGOECgWZxoevMc5TlkObMqNSsVU62PYzXZ/SMTjzyGAFF1YusgxGcSWTEXBhp0CPwQ1A==} engines: {node: '>=6'} dev: true - /cli-boxes/2.2.1: + /cli-boxes@2.2.1: resolution: {integrity: sha512-y4coMcylgSCdVinjiDBuR8PCC2bLjyGTwEmPb9NHR/QaNU6EUOXcTY/s6VjGMD6ENSEaeQYHCY0GNGS5jfMwPw==} engines: {node: '>=6'} dev: true - /cli-cursor/3.1.0: + /cli-cursor@3.1.0: resolution: {integrity: sha512-I/zHAwsKf9FqGoXM4WWRACob9+SNukZTd94DWF57E4toouRulbCxcUh6RKUEOQlYTHJnzkPMySvPNaaSLNfLZw==} engines: {node: '>=8'} dependencies: restore-cursor: 3.1.0 dev: true - /cli-cursor/4.0.0: + /cli-cursor@4.0.0: resolution: {integrity: sha512-VGtlMu3x/4DOtIUwEkRezxUZ2lBacNJCHash0N0WeZDBS+7Ux1dm3XWAgWYxLJFMMdOeXMHXorshEFhbMSGelg==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dependencies: restore-cursor: 4.0.0 dev: true - /cli-spinners/2.9.0: + /cli-spinners@2.9.0: resolution: {integrity: sha512-4/aL9X3Wh0yiMQlE+eeRhWP6vclO3QRtw1JHKIT0FFUs5FjpFmESqtMvYZ0+lbzBw900b95mS0hohy+qn2VK/g==} engines: {node: '>=6'} dev: true - /cli-table3/0.6.3: + /cli-table3@0.6.3: resolution: {integrity: sha512-w5Jac5SykAeZJKntOxJCrm63Eg5/4dhMWIcuTbo9rpE+brgaSZo0RuNJZeOyMgsUdhDeojvgyQLmjI+K50ZGyg==} engines: {node: 10.* || >= 12.*} dependencies: @@ -10171,7 +11023,7 @@ packages: '@colors/colors': 1.5.0 dev: true - /cli-truncate/2.1.0: + /cli-truncate@2.1.0: resolution: {integrity: sha512-n8fOixwDD6b/ObinzTrp1ZKFzbgvKZvuz/TvejnLn1aQfC6r52XEx85FmuC+3HI+JM7coBRXUvNqEU2PHVrHpg==} engines: {node: '>=8'} dependencies: @@ -10179,7 +11031,7 @@ packages: string-width: 4.2.3 dev: true - /cli-truncate/3.1.0: + /cli-truncate@3.1.0: resolution: {integrity: sha512-wfOBkjXteqSnI59oPcJkcPl/ZmwvMMOj340qUIY1SKZCv0B9Cf4D4fAucRkIKQmsIuYK3x1rrgU7MeGRruiuiA==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dependencies: @@ -10187,17 +11039,17 @@ packages: string-width: 5.1.2 dev: true - /cli-width/3.0.0: + /cli-width@3.0.0: resolution: {integrity: sha512-FxqpkPPwu1HjuN93Omfm4h8uIanXofW0RxVEW3k5RKx+mJJYSthzNhp32Kzxxy3YAEZ/Dc/EWN1vZRY0+kOhbw==} engines: {node: '>= 10'} dev: true - /cli-width/4.0.0: + /cli-width@4.0.0: resolution: {integrity: sha512-ZksGS2xpa/bYkNzN3BAw1wEjsLV/ZKOf/CCrJ/QOBsxx6fOARIkwTutxp1XIOIohi6HKmOFjMoK/XaqDVUpEEw==} engines: {node: '>= 12'} dev: true - /cliui/7.0.4: + /cliui@7.0.4: resolution: {integrity: sha512-OcRE68cOsVMXp1Yvonl/fzkQOyjLSu/8bhPDfQt0e0/Eb283TKP20Fs2MqoPsr9SwA595rRCA+QMzYc9nBP+JQ==} dependencies: string-width: 4.2.3 @@ -10205,7 +11057,7 @@ packages: wrap-ansi: 7.0.0 dev: true - /cliui/8.0.1: + /cliui@8.0.1: resolution: {integrity: sha512-BSeNnyus75C4//NQ9gQt1/csTXyo/8Sb+afLAkzAptFuMsod9HFokGNudZpi/oQV73hnVK+sR+5PVRMd+Dr7YQ==} engines: {node: '>=12'} dependencies: @@ -10214,7 +11066,7 @@ packages: wrap-ansi: 7.0.0 dev: true - /clone-deep/4.0.1: + /clone-deep@4.0.1: resolution: {integrity: sha512-neHB9xuzh/wk0dIHweyAXv2aPGZIVk3pLMe+/RNzINf17fe0OG96QroktYAUm7SM1PBnzTabaLboqqxDyMU+SQ==} engines: {node: '>=6'} dependencies: @@ -10223,17 +11075,22 @@ packages: shallow-clone: 3.0.1 dev: true - /clone/1.0.4: + /clone@1.0.4: resolution: {integrity: sha512-JQHZ2QMW6l3aH/j6xCqQThY/9OH4D/9ls34cgkUBiEeocRTU04tHfKPBsUK1PqZCUQM7GiA0IIXJSuXHI64Kbg==} engines: {node: '>=0.8'} dev: true - /clsx/1.2.1: + /clsx@1.2.1: resolution: {integrity: sha512-EcR6r5a8bj6pu3ycsa/E/cKVGuTgZJZdsyUYHOksG/UHIiKfjxzRxYJpyVBwYaQeOvghal9fcc4PidlgzugAQg==} engines: {node: '>=6'} dev: false - /code-red/1.0.3: + /co@4.6.0: + resolution: {integrity: sha512-QVb0dM5HvG+uaxitm8wONl7jltx8dqhfU33DcqtOZcLSVIKSDDLDi7+0LbAKiyI8hD9u42m2YxXSkMGWThaecQ==} + engines: {iojs: '>= 1.0.0', node: '>= 0.12.0'} + dev: true + + /code-red@1.0.3: resolution: {integrity: sha512-kVwJELqiILQyG5aeuyKFbdsI1fmQy1Cmf7dQ8eGmVuJoaRVdwey7WaMknr2ZFeVSYSKT0rExsa8EGw0aoI/1QQ==} dependencies: '@jridgewell/sourcemap-codec': 1.4.15 @@ -10243,19 +11100,23 @@ packages: periscopic: 3.1.0 dev: true - /codemirror-theme-vars/0.1.2: + /codemirror-theme-vars@0.1.2: resolution: {integrity: sha512-WTau8X2q58b0SOAY9DO+iQVw8JKVEgyQIqArp2D732tcc+pobbMta3bnVMdQdmgwuvNrOFFr6HoxPRoQOgooFA==} dev: true - /codemirror/5.65.13: + /codemirror@5.65.13: resolution: {integrity: sha512-SVWEzKXmbHmTQQWaz03Shrh4nybG0wXx2MEu3FO4ezbPW8IbnZEd5iGHGEffSUaitKYa3i+pHpBsSvw8sPHtzg==} dev: true - /collapse-white-space/1.0.6: + /collapse-white-space@1.0.6: resolution: {integrity: sha512-jEovNnrhMuqyCcjfEJA56v0Xq8SkIoPKDyaHahwo3POf4qcSXqMYuwNcOTzp74vTsR9Tn08z4MxWqAhcekogkQ==} dev: true - /collection-visit/1.0.0: + /collect-v8-coverage@1.0.2: + resolution: {integrity: sha512-lHl4d5/ONEbLlJvaJNtsF/Lz+WvB07u2ycqTYbdrq7UypDXailES4valYb2eWiJFxZlVmpGekfqoxQhzyFdT4Q==} + dev: true + + /collection-visit@1.0.0: resolution: {integrity: sha512-lNkKvzEeMBBjUGHZ+q6z9pSJla0KWAQPvtzhEV9+iGyQYG+pBpl7xKDhxoNSOZH2hhv0v5k0y2yAM4o4SjoSkw==} engines: {node: '>=0.10.0'} dependencies: @@ -10263,38 +11124,38 @@ packages: object-visit: 1.0.1 dev: true - /color-convert/1.9.3: + /color-convert@1.9.3: resolution: {integrity: sha512-QfAUtd+vFdAtFQcC8CCyYt1fYWxSqAiK2cSD6zDB8N3cpsEBAvRxp9zOGg6G/SHHJYAT88/az/IuDGALsNVbGg==} dependencies: color-name: 1.1.3 - /color-convert/2.0.1: + /color-convert@2.0.1: resolution: {integrity: sha512-RRECPsj7iu/xb5oKYcsFHSppFNnsj/52OVTRKb4zP5onXwVF3zVmmToNcOfGC+CRDpfK/U584fMg38ZHCaElKQ==} engines: {node: '>=7.0.0'} dependencies: color-name: 1.1.4 dev: true - /color-name/1.1.3: + /color-name@1.1.3: resolution: {integrity: sha512-72fSenhMw2HZMTVHeCA9KCmpEIbzWiQsjN+BHcBbS9vr1mtt+vJjPdksIBNUmKAW8TFUDPJK5SUU3QhE9NEXDw==} - /color-name/1.1.4: + /color-name@1.1.4: resolution: {integrity: sha512-dOy+3AuW3a2wNbZHIuMZpTcgjGuLU/uBL/ubcZF9OXbDo8ff4O8yVp5Bf0efS8uEoYo5q4Fx7dY9OgQGXgAsQA==} dev: true - /color-string/1.9.1: + /color-string@1.9.1: resolution: {integrity: sha512-shrVawQFojnZv6xM40anx4CkoDP+fZsw/ZerEMsW/pyzsRbElpsL/DBVW7q3ExxwusdNXI3lXpuhEZkzs8p5Eg==} dependencies: color-name: 1.1.4 simple-swizzle: 0.2.2 dev: true - /color-support/1.1.3: + /color-support@1.1.3: resolution: {integrity: sha512-qiBjkpbMLO/HL68y+lh4q0/O1MZFj2RX6X/KmMa3+gJD3z+WwI1ZzDHysvqHGS3mP6mznPckpXmw1nI9cJjyRg==} hasBin: true dev: true - /color/4.2.3: + /color@4.2.3: resolution: {integrity: sha512-1rXeuUUiGGrykh+CeBdu5Ie7OJwinCgQY0bc7GCRxy5xVHy+moaqkpL/jqQq0MtQOeYcrqEz4abc5f0KtU7W4A==} engines: {node: '>=12.5.0'} dependencies: @@ -10302,62 +11163,62 @@ packages: color-string: 1.9.1 dev: true - /colorette/2.0.20: + /colorette@2.0.20: resolution: {integrity: sha512-IfEDxwoWIjkeXL1eXcDiow4UbKjhLdq6/EuSVR9GMN7KVH3r9gQ83e73hsz1Nd1T3ijd5xv1wcWRYO+D6kCI2w==} dev: true - /combined-stream/1.0.8: + /combined-stream@1.0.8: resolution: {integrity: sha512-FQN4MRfuJeHf7cBbBMJFXhKSDq+2kAArBlmRBvcvFE5BB1HZKXtSFASDhdlz9zOYwxh8lDdnvmMOe/+5cdoEdg==} engines: {node: '>= 0.8'} dependencies: delayed-stream: 1.0.0 dev: true - /comma-separated-tokens/1.0.8: + /comma-separated-tokens@1.0.8: resolution: {integrity: sha512-GHuDRO12Sypu2cV70d1dkA2EUmXHgntrzbpvOB+Qy+49ypNfGgFQIC2fhhXbnyrJRynDCAARsT7Ou0M6hirpfw==} dev: true - /commander/10.0.1: + /commander@10.0.1: resolution: {integrity: sha512-y4Mg2tXshplEbSGzx7amzPwKKOCGuoSRP/CjEdwwk0FOGlUbq6lKuoyDZTNZkmxHdJtp54hdfY/JUrdL7Xfdug==} engines: {node: '>=14'} dev: true - /commander/2.20.3: + /commander@2.20.3: resolution: {integrity: sha512-GpVkmM8vF2vQUkj2LvZmD35JxeJOLCwJ9cUkugyk2nuhbv3+mJvpLYYt+0+USMxE+oj+ey/lJEnhZw75x/OMcQ==} dev: true - /commander/4.1.1: + /commander@4.1.1: resolution: {integrity: sha512-NOKm8xhkzAjzFx8B2v5OAHT+u5pRQc2UCa2Vq9jYL/31o2wi9mxBA7LIFs3sV5VSC49z6pEhfbMULvShKj26WA==} engines: {node: '>= 6'} dev: true - /commander/6.2.1: + /commander@6.2.1: resolution: {integrity: sha512-U7VdrJFnJgo4xjrHpTzu0yrHPGImdsmD95ZlgYSEajAn2JKzDhDTPG9kBTefmObL2w/ngeZnilk+OV9CG3d7UA==} engines: {node: '>= 6'} dev: true - /commenting/1.1.0: + /commenting@1.1.0: resolution: {integrity: sha512-YeNK4tavZwtH7jEgK1ZINXzLKm6DZdEMfsaaieOsCAN0S8vsY7UeuO3Q7d/M018EFgE+IeUAuBOKkFccBZsUZA==} dev: true - /common-path-prefix/3.0.0: + /common-path-prefix@3.0.0: resolution: {integrity: sha512-QE33hToZseCH3jS0qN96O/bSh3kaw/h+Tq7ngyY9eWDUnTlTNUyqfqvCXioLe5Na5jFsL78ra/wuBU4iuEgd4w==} dev: true - /common-tags/1.8.2: + /common-tags@1.8.2: resolution: {integrity: sha512-gk/Z852D2Wtb//0I+kRFNKKE9dIIVirjoqPoA1wJU+XePVXZfGeBpk45+A1rKO4Q43prqWBNY/MiIeRLbPWUaA==} engines: {node: '>=4.0.0'} dev: true - /commondir/1.0.1: + /commondir@1.0.1: resolution: {integrity: sha512-W9pAhw0ja1Edb5GVdIF1mjZw/ASI0AlShXM83UUGe2DVr5TdAPEA1OA8m/g8zWp9x6On7gqufY+FatDbC3MDQg==} dev: true - /component-emitter/1.3.0: + /component-emitter@1.3.0: resolution: {integrity: sha512-Rd3se6QB+sO1TwqZjscQrurpEPIfO0/yYnSin6Q/rD3mOutHvUrCAhJub3r90uNb+SESBuE0QYoB90YdfatsRg==} dev: true - /compress-commons/4.1.1: + /compress-commons@4.1.1: resolution: {integrity: sha512-QLdDLCKNV2dtoTorqgxngQCMA+gWXkM/Nwu7FpeBhk/RdkzimqC3jueb/FDmaZeXh+uby1jkBqE3xArsLBE5wQ==} engines: {node: '>= 10'} dependencies: @@ -10367,14 +11228,14 @@ packages: readable-stream: 3.6.2 dev: true - /compressible/2.0.18: + /compressible@2.0.18: resolution: {integrity: sha512-AF3r7P5dWxL8MxyITRMlORQNaOA2IkAFaTr4k7BUumjPtRpGDTZpl0Pb1XCO6JeDCBdp126Cgs9sMxqSjgYyRg==} engines: {node: '>= 0.6'} dependencies: mime-db: 1.52.0 dev: true - /compression/1.7.4: + /compression@1.7.4: resolution: {integrity: sha512-jaSIDzP9pZVS4ZfQ+TzvtiWhdpFhE2RDHz8QJkpX9SIpLq88VueF5jJw6t+6CUQcAoA6t+x89MLrWAqpfDE8iQ==} engines: {node: '>= 0.8.0'} dependencies: @@ -10389,10 +11250,10 @@ packages: - supports-color dev: true - /concat-map/0.0.1: + /concat-map@0.0.1: resolution: {integrity: sha512-/Srv4dswyQNBfohGpz9o6Yb3Gz3SrUDqBH5rTuhGR7ahtlbYKnVxw2bCFMRljaA7EXHaXZ8wsHdodFvbkhKmqg==} - /concat-stream/1.6.2: + /concat-stream@1.6.2: resolution: {integrity: sha512-27HBghJxjiZtIk3Ycvn/4kbJk/1uZuJFfuPEns6LaEvpvG1f0hTea8lilrouyo9mVc2GWdcEZ8OLoGmSADlrCw==} engines: {'0': node >= 0.8} dependencies: @@ -10402,7 +11263,7 @@ packages: typedarray: 0.0.6 dev: true - /condense-newlines/0.2.1: + /condense-newlines@0.2.1: resolution: {integrity: sha512-P7X+QL9Hb9B/c8HI5BFFKmjgBu2XpQuF98WZ9XkO+dBGgk5XgwiQz7o1SmpglNWId3581UcS0SFAWfoIhMHPfg==} engines: {node: '>=0.10.0'} dependencies: @@ -10411,64 +11272,64 @@ packages: kind-of: 3.2.2 dev: true - /config-chain/1.1.13: + /config-chain@1.1.13: resolution: {integrity: sha512-qj+f8APARXHrM0hraqXYb2/bOVSV4PvJQlNZ/DVj0QrmNM2q2euizkeuVckQ57J+W0mRH6Hvi+k50M4Jul2VRQ==} dependencies: ini: 1.3.8 proto-list: 1.2.4 dev: true - /consola/3.2.3: + /consola@3.2.3: resolution: {integrity: sha512-I5qxpzLv+sJhTVEoLYNcTW+bThDCPsit0vLNKShZx6rLtpilNpmmeTPaeqJb9ZE9dV3DGaeby6Vuhrw38WjeyQ==} engines: {node: ^14.18.0 || >=16.10.0} dev: true - /console-browserify/1.2.0: + /console-browserify@1.2.0: resolution: {integrity: sha512-ZMkYO/LkF17QvCPqM0gxw8yUzigAOZOSWSHg91FH6orS7vcEj5dVZTidN2fQ14yBSdg97RqhSNwLUXInd52OTA==} dev: true - /console-control-strings/1.1.0: + /console-control-strings@1.1.0: resolution: {integrity: sha512-ty/fTekppD2fIwRvnZAVdeOiGd1c7YXEixbgJTNzqcxJWKQnjJ/V1bNEEE6hygpM3WjwHFUVK6HTjWSzV4a8sQ==} dev: true - /constants-browserify/1.0.0: + /constants-browserify@1.0.0: resolution: {integrity: sha512-xFxOwqIzR/e1k1gLiWEophSCMqXcwVHIH7akf7b/vxcUeGunlj3hvZaaqxwHsTgn+IndtkQJgSztIDWeumWJDQ==} dev: true - /content-disposition/0.5.4: + /content-disposition@0.5.4: resolution: {integrity: sha512-FveZTNuGw04cxlAiWbzi6zTAL/lhehaWbTtgluJh4/E95DqMwTmha3KZN1aAWA8cFIhHzMZUvLevkw5Rqk+tSQ==} engines: {node: '>= 0.6'} dependencies: safe-buffer: 5.2.1 dev: true - /content-type/1.0.5: + /content-type@1.0.5: resolution: {integrity: sha512-nTjqfcBFEipKdXCv4YDQWCfmcLZKm81ldF0pAopTvyrFGVbcR6P/VAAd5G7N+0tTr8QqiU0tFadD6FK4NtJwOA==} engines: {node: '>= 0.6'} dev: true - /convert-source-map/1.9.0: + /convert-source-map@1.9.0: resolution: {integrity: sha512-ASFBup0Mz1uyiIjANan1jzLQami9z1PoYSZCiiYW2FczPbenXc45FZdBZLzOT+r6+iciuEModtmCti+hjaAk0A==} - /cookie-signature/1.0.6: + /cookie-signature@1.0.6: resolution: {integrity: sha512-QADzlaHc8icV8I7vbaJXJwod9HWYp8uCqf1xa4OfNu1T7JVxQIrUgOWtHdNDtPiywmFbiS12VjotIXLrKM3orQ==} dev: true - /cookie/0.4.2: + /cookie@0.4.2: resolution: {integrity: sha512-aSWTXFzaKWkvHO1Ny/s+ePFpvKsPnjc551iI41v3ny/ow6tBG5Vd+FuqGNhh1LxOmVzOlGUriIlOaokOvhaStA==} engines: {node: '>= 0.6'} dev: true - /cookie/0.5.0: + /cookie@0.5.0: resolution: {integrity: sha512-YZ3GUyn/o8gfKJlnlX7g7xq4gyO6OSuhGPKaaGssGB2qgDUS0gPgtTvoyZLTt9Ab6dC4hfc9dV5arkvc/OCmrw==} engines: {node: '>= 0.6'} dev: true - /cookiejar/2.1.4: + /cookiejar@2.1.4: resolution: {integrity: sha512-LDx6oHrK+PhzLKJU9j5S7/Y3jM/mUHvD/DeI1WQmJn652iPC5Y4TBzC9l+5OMOXlyTTA+SmVUPm0HQUwpD5Jqw==} dev: true - /copy-concurrently/1.0.5: + /copy-concurrently@1.0.5: resolution: {integrity: sha512-f2domd9fsVDFtaFcbaRZuYXwtdmnzqbADSwhSWYxYB/Q8zsdUUFMXVRwXGDMWmbEzAn1kdRrtI1T/KTFOL4X2A==} dependencies: aproba: 1.2.0 @@ -10479,36 +11340,36 @@ packages: run-queue: 1.0.3 dev: true - /copy-descriptor/0.1.1: + /copy-descriptor@0.1.1: resolution: {integrity: sha512-XgZ0pFcakEUlbwQEVNg3+QAis1FyTL3Qel9FYy8pSkQqoG3PNoT0bOCQtOXcOkur21r2Eq2kI+IE+gsmAEVlYw==} engines: {node: '>=0.10.0'} dev: true - /core-js-compat/3.31.1: + /core-js-compat@3.31.1: resolution: {integrity: sha512-wIDWd2s5/5aJSdpOJHfSibxNODxoGoWOBHt8JSPB41NOE94M7kuTPZCYLOlTtuoXTsBPKobpJ6T+y0SSy5L9SA==} dependencies: browserslist: 4.21.9 dev: true - /core-js-pure/3.31.1: + /core-js-pure@3.31.1: resolution: {integrity: sha512-w+C62kvWti0EPs4KPMCMVv9DriHSXfQOCQ94bGGBiEW5rrbtt/Rz8n5Krhfw9cpFyzXBjf3DB3QnPdEzGDY4Fw==} requiresBuild: true dev: true - /core-js/3.31.1: + /core-js@3.31.1: resolution: {integrity: sha512-2sKLtfq1eFST7l7v62zaqXacPc7uG8ZAya8ogijLhTtaKNcpzpB4TMoTw2Si+8GYKRwFPMMtUT0263QFWFfqyQ==} requiresBuild: true dev: true - /core-util-is/1.0.2: + /core-util-is@1.0.2: resolution: {integrity: sha512-3lqz5YjWTYnW6dlDa5TLaTCcShfar1e40rmcJVwCBJC6mWlFuj0eCHIElmG1g5kyuJ/GD+8Wn4FFCcz4gJPfaQ==} dev: true - /core-util-is/1.0.3: + /core-util-is@1.0.3: resolution: {integrity: sha512-ZQBvi1DcpJ4GDqanjucZ2Hj3wEO5pZDS89BWbkcrvdxksJorwUDDZamX9ldFkp9aw2lmBDLgkObEA4DWNJ9FYQ==} dev: true - /cors/2.8.5: + /cors@2.8.5: resolution: {integrity: sha512-KIHbLJqu73RGr/hnbrO9uBeixNGuvSQjul/jdFvS/KFSIH1hWVd1ng7zOHx+YrEfInLG7q4n6GHQ9cDtxv/P6g==} engines: {node: '>= 0.10'} dependencies: @@ -10516,7 +11377,7 @@ packages: vary: 1.1.2 dev: true - /cosmiconfig/6.0.0: + /cosmiconfig@6.0.0: resolution: {integrity: sha512-xb3ZL6+L8b9JLLCx3ZdoZy4+2ECphCMo2PwqgP1tlfVq6M6YReyzBJtvWWtbDSpNr9hn96pkCiZqUcFEc+54Qg==} engines: {node: '>=8'} dependencies: @@ -10527,7 +11388,7 @@ packages: yaml: 1.10.2 dev: true - /cosmiconfig/7.1.0: + /cosmiconfig@7.1.0: resolution: {integrity: sha512-AdmX6xUzdNASswsFtmwSt7Vj8po9IuqXm0UXz7QKPuEUmPB4XyjGfaAr2PSuELMwkRMVH1EpIkX5bTZGRB3eCA==} engines: {node: '>=10'} dependencies: @@ -10537,7 +11398,7 @@ packages: path-type: 4.0.0 yaml: 1.10.2 - /cp-file/7.0.0: + /cp-file@7.0.0: resolution: {integrity: sha512-0Cbj7gyvFVApzpK/uhCtQ/9kE9UnYpxMzaq5nQQC/Dh4iaj5fxp7iEFIullrYwzj8nf0qnsI1Qsx34hAeAebvw==} engines: {node: '>=8'} dependencies: @@ -10547,7 +11408,7 @@ packages: p-event: 4.2.0 dev: true - /cpy/8.1.2: + /cpy@8.1.2: resolution: {integrity: sha512-dmC4mUesv0OYH2kNFEidtf/skUwv4zePmGeepjyyJ0qTo5+8KhA1o99oIAwVVLzQMAeDJml74d6wPPKb6EZUTg==} engines: {node: '>=8'} dependencies: @@ -10564,13 +11425,13 @@ packages: - supports-color dev: true - /crc-32/1.2.2: + /crc-32@1.2.2: resolution: {integrity: sha512-ROmzCKrTnOwybPcJApAA6WBWij23HVfGVNKqqrZpuyZOHqK2CwHSvpGuyt/UNNvaIjEd8X5IFGp4Mh+Ie1IHJQ==} engines: {node: '>=0.8'} hasBin: true dev: true - /crc32-stream/4.0.2: + /crc32-stream@4.0.2: resolution: {integrity: sha512-DxFZ/Hk473b/muq1VJ///PMNLj0ZMnzye9thBpmjpJKCc5eMgB95aK8zCGrGfQ90cWo561Te6HK9D+j4KPdM6w==} engines: {node: '>= 10'} dependencies: @@ -10578,14 +11439,14 @@ packages: readable-stream: 3.6.2 dev: true - /create-ecdh/4.0.4: + /create-ecdh@4.0.4: resolution: {integrity: sha512-mf+TCx8wWc9VpuxfP2ht0iSISLZnt0JgWlrOKZiNqyUZWnjIaCIVNQArMHnCZKfEYRg6IM7A+NeJoN8gf/Ws0A==} dependencies: bn.js: 4.12.0 elliptic: 6.5.4 dev: true - /create-hash/1.2.0: + /create-hash@1.2.0: resolution: {integrity: sha512-z00bCGNHDG8mHAkP7CtT1qVu+bFQUPjYq/4Iv3C3kWjTFV10zIjfSoeqXo9Asws8gwSHDGj/hl2u4OGIjapeCg==} dependencies: cipher-base: 1.0.4 @@ -10595,7 +11456,7 @@ packages: sha.js: 2.4.11 dev: true - /create-hmac/1.1.7: + /create-hmac@1.1.7: resolution: {integrity: sha512-MJG9liiZ+ogc4TzUwuvbER1JRdgvUFSB5+VR/g5h82fGaIRWMWddtKBHi7/sVhfjQZ6SehlyhvQYrcYkaUIpLg==} dependencies: cipher-base: 1.0.4 @@ -10606,11 +11467,11 @@ packages: sha.js: 2.4.11 dev: true - /create-require/1.1.1: + /create-require@1.1.1: resolution: {integrity: sha512-dcKFX3jn0MpIaXjisoRvexIJVEKzaq7z2rZKxf+MSr9TkdmHmsU4m2lcLojrj/FHl8mk5VxMmYA+ftRkP/3oKQ==} dev: true - /cross-fetch/3.1.5: + /cross-fetch@3.1.5: resolution: {integrity: sha512-lvb1SBsI0Z7GDwmuid+mU3kWVBwTVUbe7S0H52yaaAdQOXq2YktTCZdlAcNKFzE6QtRz0snpw9bNiPeOIkkQvw==} dependencies: node-fetch: 2.6.7 @@ -10618,7 +11479,7 @@ packages: - encoding dev: true - /cross-fetch/3.1.6: + /cross-fetch@3.1.6: resolution: {integrity: sha512-riRvo06crlE8HiqOwIpQhxwdOk4fOeR7FVM/wXoxchFEqMNUjvbs3bfo4OTgMEMHzppd4DxFBDbyySj8Cv781g==} dependencies: node-fetch: 2.6.12 @@ -10626,14 +11487,14 @@ packages: - encoding dev: true - /cross-fetch/3.1.8: + /cross-fetch@3.1.8: resolution: {integrity: sha512-cvA+JwZoU0Xq+h6WkMvAUqPEYy92Obet6UdKLfW60qn99ftItKjB5T+BkyWOFWe2pUyfQ+IJHmpOTznqk1M6Kg==} dependencies: node-fetch: 2.6.12 transitivePeerDependencies: - encoding - /cross-spawn/5.1.0: + /cross-spawn@5.1.0: resolution: {integrity: sha512-pTgQJ5KC0d2hcY8eyL1IzlBPYjTkyH72XRZPnLyKus2mBfNjQs3klqbJU2VILqZryAZUt9JOb3h/mWMy23/f5A==} dependencies: lru-cache: 4.1.5 @@ -10641,7 +11502,7 @@ packages: which: 1.3.1 dev: true - /cross-spawn/6.0.5: + /cross-spawn@6.0.5: resolution: {integrity: sha512-eTVLrBSt7fjbDygz805pMnstIs2VTBNkRm0qxZd+M7A5XDdxVRWO5MxGBXZhjY4cqLYLdtrGqRf8mBPmzwSpWQ==} engines: {node: '>=4.8'} dependencies: @@ -10652,7 +11513,7 @@ packages: which: 1.3.1 dev: true - /cross-spawn/7.0.3: + /cross-spawn@7.0.3: resolution: {integrity: sha512-iRDPJKUPVEND7dHPO8rkbOnPpyDygcDFtWjpeWNCgy8WP2rXcxXL8TskReQl6OrB2G7+UJrags1q15Fudc7G6w==} engines: {node: '>= 8'} dependencies: @@ -10661,7 +11522,7 @@ packages: which: 2.0.2 dev: true - /crypto-browserify/3.12.0: + /crypto-browserify@3.12.0: resolution: {integrity: sha512-fz4spIh+znjO2VjL+IdhEpRJ3YN6sMzITSBijk6FK2UvTqruSQW+/cCZTSNsMiZNvUeq0CqurF+dAbyiGOY6Wg==} dependencies: browserify-cipher: 1.0.1 @@ -10677,12 +11538,12 @@ packages: randomfill: 1.0.4 dev: true - /crypto-random-string/2.0.0: + /crypto-random-string@2.0.0: resolution: {integrity: sha512-v1plID3y9r/lPhviJ1wrXpLeyUIGAZ2SHNYTEapm7/8A9nLPoyvVp3RK/EPFqn5kEznyWgYZNsRtYYIWbuG8KA==} engines: {node: '>=8'} dev: true - /css-loader/3.6.0_webpack@4.46.0: + /css-loader@3.6.0(webpack@4.46.0): resolution: {integrity: sha512-M5lSukoWi1If8dhQAUCvj4H8vUt3vOnwbQBH9DdTm/s4Ym2B/3dPMtYZeJmq7Q3S3Pa+I94DcZ7pc9bP14cWIQ==} engines: {node: '>= 8.9.0'} peerDependencies: @@ -10704,7 +11565,7 @@ packages: webpack: 4.46.0 dev: true - /css-select/4.3.0: + /css-select@4.3.0: resolution: {integrity: sha512-wPpOYtnsVontu2mODhA19JrqWxNsfdatRKd64kmpRbQgh1KtItko5sTnEpPdpSaJszTOhEMlF/RPz28qj4HqhQ==} dependencies: boolbase: 1.0.0 @@ -10714,7 +11575,7 @@ packages: nth-check: 2.1.1 dev: true - /css-select/5.1.0: + /css-select@5.1.0: resolution: {integrity: sha512-nwoRF1rvRRnnCqqY7updORDsuqKzqYJ28+oSMaJMMgOauh3fvwHqMS7EZpIPqK8GL+g9mKxF1vP/ZjSeNjEVHg==} dependencies: boolbase: 1.0.0 @@ -10724,11 +11585,11 @@ packages: nth-check: 2.1.1 dev: true - /css-shorthand-properties/1.1.1: + /css-shorthand-properties@1.1.1: resolution: {integrity: sha512-Md+Juc7M3uOdbAFwOYlTrccIZ7oCFuzrhKYQjdeUEW/sE1hv17Jp/Bws+ReOPpGVBTYCBoYo+G17V5Qo8QQ75A==} dev: true - /css-tree/2.3.1: + /css-tree@2.3.1: resolution: {integrity: sha512-6Fv1DV/TYw//QF5IzQdqsNDjx/wc8TrMBZsqjL9eW01tWb7R7k/mq+/VXfJCl7SoD5emsJop9cOByJZfs8hYIw==} engines: {node: ^10 || ^12.20.0 || ^14.13.0 || >=15.0.0} dependencies: @@ -10736,54 +11597,58 @@ packages: source-map-js: 1.0.2 dev: true - /css-unit-converter/1.1.2: + /css-unit-converter@1.1.2: resolution: {integrity: sha512-IiJwMC8rdZE0+xiEZHeru6YoONC4rfPMqGm2W85jMIbkFvv5nFTwJVFHam2eFrN6txmoUYFAFXiv8ICVeTO0MA==} dev: false - /css-value/0.0.1: + /css-value@0.0.1: resolution: {integrity: sha512-FUV3xaJ63buRLgHrLQVlVgQnQdR4yqdLGaDu7g8CQcWjInDfM9plBTPI9FRfpahju1UBSaMckeb2/46ApS/V1Q==} dev: true - /css-what/6.1.0: + /css-what@6.1.0: resolution: {integrity: sha512-HTUrgRJ7r4dsZKU6GjmpfRK1O76h97Z8MfS1G0FozR+oF2kG6Vfe8JE6zwrkbxigziPHinCJ+gCPjA9EaBDtRw==} engines: {node: '>= 6'} - /css.escape/1.5.1: + /css.escape@1.5.1: resolution: {integrity: sha512-YUifsXXuknHlUsmlgyY0PKzgPOr7/FjCePfHNt0jxm83wHZi44VDMQ7/fGNkjY3/jV1MC+1CmZbaHzugyeRtpg==} dev: true - /cssesc/3.0.0: + /cssesc@3.0.0: resolution: {integrity: sha512-/Tb/JcjK111nNScGob5MNtsntNM1aCNUDipB/TkwZFhyDrrE47SOx/18wF2bbjgc3ZzCSKW1T5nt5EbFoAz/Vg==} engines: {node: '>=4'} hasBin: true dev: true - /cssom/0.3.8: + /cssom@0.3.8: resolution: {integrity: sha512-b0tGHbfegbhPJpxpiBPU2sCkigAqtM9O121le6bbOlgyV+NyGyCmVfJ6QW9eRjz8CpNfWEOYBIMIGRYkLwsIYg==} dev: true - /cssom/0.5.0: + /cssom@0.4.4: + resolution: {integrity: sha512-p3pvU7r1MyyqbTk+WbNJIgJjG2VmTIaB10rI93LzVPrmDJKkzKYMtxxyAvQXR/NS6otuzveI7+7BBq3SjBS2mw==} + dev: true + + /cssom@0.5.0: resolution: {integrity: sha512-iKuQcq+NdHqlAcwUY0o/HL69XQrUaQdMjmStJ8JFmUaiiQErlhrmuigkg/CU4E2J0IyUKUrMAgl36TvN67MqTw==} dev: true - /cssstyle/2.3.0: + /cssstyle@2.3.0: resolution: {integrity: sha512-AZL67abkUzIuvcHqk7c09cezpGNcxUxU4Ioi/05xHk4DQeTkWmGYftIE6ctU6AEt+Gn4n1lDStOtj7FKycP71A==} engines: {node: '>=8'} dependencies: cssom: 0.3.8 dev: true - /cssstyle/3.0.0: + /cssstyle@3.0.0: resolution: {integrity: sha512-N4u2ABATi3Qplzf0hWbVCdjenim8F3ojEXpBDF5hBpjzW182MjNGLqfmQ0SkSPeQ+V86ZXgeH8aXj6kayd4jgg==} engines: {node: '>=14'} dependencies: rrweb-cssom: 0.6.0 dev: true - /csstype/3.1.2: + /csstype@3.1.2: resolution: {integrity: sha512-I7K1Uu0MBPzaFKg4nI5Q7Vs2t+3gWWW648spaF+Rg7pI9ds18Ugn+lvg4SHczUdKlHI5LWBXyqfS8+DufyBsgQ==} - /currently-unhandled/0.4.1: + /currently-unhandled@0.4.1: resolution: {integrity: sha512-/fITjgjGU50vjQ4FH6eUoYu+iUoUKIXws2hL15JJpIR+BbTxaXQsMuuyjtNh2WqsSBS5nsaZHFsFecyw5CCAng==} engines: {node: '>=0.10.0'} dependencies: @@ -10791,18 +11656,18 @@ packages: dev: true optional: true - /cyclist/1.0.2: + /cyclist@1.0.2: resolution: {integrity: sha512-0sVXIohTfLqVIW3kb/0n6IiWF3Ifj5nm2XaSrLq2DI6fKIGa2fYAZdk917rUneaeLVpYfFcyXE2ft0fe3remsA==} dev: true - /cypress/12.17.1: + /cypress@12.17.1: resolution: {integrity: sha512-eKfBgO6t8waEyhegL4gxD7tcI6uTCGttu+ZU7y9Hq8BlpMztd7iLeIF4AJFAnbZH1xjX+wwgg4cRKFNSvv3VWQ==} engines: {node: ^14.0.0 || ^16.0.0 || >=18.0.0} hasBin: true requiresBuild: true dependencies: '@cypress/request': 2.88.11 - '@cypress/xvfb': 1.2.4_supports-color@8.1.1 + '@cypress/xvfb': 1.2.4(supports-color@8.1.1) '@types/node': 14.18.53 '@types/sinonjs__fake-timers': 8.1.1 '@types/sizzle': 2.3.3 @@ -10818,19 +11683,19 @@ packages: commander: 6.2.1 common-tags: 1.8.2 dayjs: 1.11.9 - debug: 4.3.4_supports-color@8.1.1 + debug: 4.3.4(supports-color@8.1.1) enquirer: 2.3.6 eventemitter2: 6.4.7 execa: 4.1.0 executable: 4.1.1 - extract-zip: 2.0.1_supports-color@8.1.1 + extract-zip: 2.0.1(supports-color@8.1.1) figures: 3.2.0 fs-extra: 9.1.0 getos: 3.2.1 is-ci: 3.0.1 is-installed-globally: 0.4.0 lazy-ass: 1.6.0 - listr2: 3.14.0_enquirer@2.3.6 + listr2: 3.14.0(enquirer@2.3.6) lodash: 4.17.21 log-symbols: 4.1.0 minimist: 1.2.8 @@ -10845,23 +11710,23 @@ packages: yauzl: 2.10.0 dev: true - /d3-array/3.2.4: + /d3-array@3.2.4: resolution: {integrity: sha512-tdQAmyA18i4J7wprpYq8ClcxZy3SC31QMeByyCFyRt7BVHdREQZ5lpzoe5mFEYZUWe+oq8HBvk9JjpibyEV4Jg==} engines: {node: '>=12'} dependencies: internmap: 2.0.3 dev: false - /d3-color/3.1.0: + /d3-color@3.1.0: resolution: {integrity: sha512-zg/chbXyeBtMQ1LbD/WSoW2DpC3I0mpmPdW+ynRTj/x2DAWYrIY7qeZIHidozwV24m4iavr15lNwIwLxRmOxhA==} engines: {node: '>=12'} - /d3-dispatch/3.0.1: + /d3-dispatch@3.0.1: resolution: {integrity: sha512-rzUyPU/S7rwUflMyLc1ETDeBj0NRuHKKAcvukozwhshr6g6c5d8zh4c2gQjY2bZ0dXeGLWc1PF174P2tVvKhfg==} engines: {node: '>=12'} dev: true - /d3-drag/3.0.0: + /d3-drag@3.0.0: resolution: {integrity: sha512-pWbUJLdETVA8lQNJecMxoXfH6x+mO2UQo8rSmZ+QqxcbyA3hfeprFgIT//HW2nlHChWeIIMwS2Fq+gEARkhTkg==} engines: {node: '>=12'} dependencies: @@ -10869,11 +11734,11 @@ packages: d3-selection: 3.0.0 dev: true - /d3-ease/3.0.1: + /d3-ease@3.0.1: resolution: {integrity: sha512-wR/XK3D3XcLIZwpbvQwQ5fK+8Ykds1ip7A2Txe0yxncXSdq1L9skcG7blcedkOX+ZcgxGAmLX1FrRGbADwzi0w==} engines: {node: '>=12'} - /d3-force/3.0.0: + /d3-force@3.0.0: resolution: {integrity: sha512-zxV/SsA+U4yte8051P4ECydjD/S+qeYtnaIyAs9tgHCqfguma/aAQDjo85A9Z6EKhBirHRJHXIgJUlffT4wdLg==} engines: {node: '>=12'} dependencies: @@ -10882,12 +11747,12 @@ packages: d3-timer: 3.0.1 dev: true - /d3-format/3.1.0: + /d3-format@3.1.0: resolution: {integrity: sha512-YyUI6AEuY/Wpt8KWLgZHsIU86atmikuoOmCfommt0LYHiQSPjvX2AcFc38PX0CBpr2RCyZhjex+NS/LPOv6YqA==} engines: {node: '>=12'} dev: false - /d3-graph-controller/2.5.2: + /d3-graph-controller@2.5.2: resolution: {integrity: sha512-s8qJCEWuQKoE2uwkD1HpE3bpPHxG/30d7u1Dp5YT8modzc0Nbeh1iiqb0clxEHmNOAJd4vbDWkKtYhX58lycug==} dependencies: '@yeger/debounce': 1.0.66 @@ -10898,23 +11763,23 @@ packages: vecti: 2.1.40 dev: true - /d3-interpolate/3.0.1: + /d3-interpolate@3.0.1: resolution: {integrity: sha512-3bYs1rOD33uo8aqJfKP3JWPAibgw8Zm2+L9vBKEHJ2Rg+viTR7o5Mmv5mZcieN+FRYaAOWX5SJATX6k1PWz72g==} engines: {node: '>=12'} dependencies: d3-color: 3.1.0 - /d3-path/3.1.0: + /d3-path@3.1.0: resolution: {integrity: sha512-p3KP5HCf/bvjBSSKuXid6Zqijx7wIfNW+J/maPs+iwR35at5JCbLUT0LzF1cnjbCHWhqzQTIN2Jpe8pRebIEFQ==} engines: {node: '>=12'} dev: false - /d3-quadtree/3.0.1: + /d3-quadtree@3.0.1: resolution: {integrity: sha512-04xDrxQTDTCFwP5H6hRhsRcb9xxv2RzkcsygFzmkSIOJy3PeRJP7sNk3VRIbKXcog561P9oU0/rVH6vDROAgUw==} engines: {node: '>=12'} dev: true - /d3-scale/4.0.2: + /d3-scale@4.0.2: resolution: {integrity: sha512-GZW464g1SH7ag3Y7hXjf8RoUuAFIqklOAq3MRl4OaWabTFJY9PN/E1YklhXLh+OQ3fM9yS2nOkCoS+WLZ6kvxQ==} engines: {node: '>=12'} dependencies: @@ -10925,37 +11790,37 @@ packages: d3-time-format: 4.1.0 dev: false - /d3-selection/3.0.0: + /d3-selection@3.0.0: resolution: {integrity: sha512-fmTRWbNMmsmWq6xJV8D19U/gw/bwrHfNXxrIN+HfZgnzqTHp9jOmKMhsTUjXOJnZOdZY9Q28y4yebKzqDKlxlQ==} engines: {node: '>=12'} dev: true - /d3-shape/3.2.0: + /d3-shape@3.2.0: resolution: {integrity: sha512-SaLBuwGm3MOViRq2ABk3eLoxwZELpH6zhl3FbAoJ7Vm1gofKx6El1Ib5z23NUEhF9AsGl7y+dzLe5Cw2AArGTA==} engines: {node: '>=12'} dependencies: d3-path: 3.1.0 dev: false - /d3-time-format/4.1.0: + /d3-time-format@4.1.0: resolution: {integrity: sha512-dJxPBlzC7NugB2PDLwo9Q8JiTR3M3e4/XANkreKSUxF8vvXKqm1Yfq4Q5dl8budlunRVlUUaDUgFt7eA8D6NLg==} engines: {node: '>=12'} dependencies: d3-time: 3.1.0 dev: false - /d3-time/3.1.0: + /d3-time@3.1.0: resolution: {integrity: sha512-VqKjzBLejbSMT4IgbmVgDjpkYrNWUYJnbCGo874u7MMKIWsILRX+OpX/gTk8MqjpT1A/c6HY2dCA77ZN0lkQ2Q==} engines: {node: '>=12'} dependencies: d3-array: 3.2.4 dev: false - /d3-timer/3.0.1: + /d3-timer@3.0.1: resolution: {integrity: sha512-ndfJ/JxxMd3nw31uyKoY2naivF+r29V+Lc0svZxe1JvvIRmi8hUsrMvdOwgS1o6uBHmiz91geQ0ylPP0aj1VUA==} engines: {node: '>=12'} - /d3-transition/3.0.1_d3-selection@3.0.0: + /d3-transition@3.0.1(d3-selection@3.0.0): resolution: {integrity: sha512-ApKvfjsSR6tg06xrL434C0WydLr7JewBB3V+/39RMHsaXTOG0zmt/OAXeng5M5LBm0ojmxJrpomQVZ1aPvBL4w==} engines: {node: '>=12'} peerDependencies: @@ -10969,7 +11834,7 @@ packages: d3-timer: 3.0.1 dev: true - /d3-zoom/3.0.0: + /d3-zoom@3.0.0: resolution: {integrity: sha512-b8AmV3kfQaqWAuacbPuNbL6vahnOJflOhexLzMMNLga62+/nh0JzvJ0aO/5a5MVgUFGS7Hu1P9P03o3fJkDCyw==} engines: {node: '>=12'} dependencies: @@ -10977,17 +11842,26 @@ packages: d3-drag: 3.0.0 d3-interpolate: 3.0.1 d3-selection: 3.0.0 - d3-transition: 3.0.1_d3-selection@3.0.0 + d3-transition: 3.0.1(d3-selection@3.0.0) dev: true - /dashdash/1.14.1: + /dashdash@1.14.1: resolution: {integrity: sha512-jRFi8UDGo6j+odZiEpjazZaWqEal3w/basFjQHQEwVtZJGDpxbH1MeYluwCS8Xq5wmLJooDlMgvVarmWfGM44g==} engines: {node: '>=0.10'} dependencies: assert-plus: 1.0.0 dev: true - /data-urls/3.0.2: + /data-urls@2.0.0: + resolution: {integrity: sha512-X5eWTSXO/BJmpdIKCRuKUgSCgAN0OwliVK3yPKbwIWU1Tdw5BRajxlzMidvh+gwko9AfQ9zIj52pzF91Q3YAvQ==} + engines: {node: '>=10'} + dependencies: + abab: 2.0.6 + whatwg-mimetype: 2.3.0 + whatwg-url: 8.7.0 + dev: true + + /data-urls@3.0.2: resolution: {integrity: sha512-Jy/tj3ldjZJo63sVAvg6LHt2mHvl4V6AgRAmNDtLdm7faqtsx+aJG42rsyCo9JCoRVKwPFzKlIPx3DIibwSIaQ==} engines: {node: '>=12'} dependencies: @@ -10996,7 +11870,7 @@ packages: whatwg-url: 11.0.0 dev: true - /data-urls/4.0.0: + /data-urls@4.0.0: resolution: {integrity: sha512-/mMTei/JXPqvFqQtfyTowxmJVwr2PVAeCcDxyFf6LhoOu/09TX2OX3kb2wzi4DMXcfj4OItwDOnhl5oziPnT6g==} engines: {node: '>=14'} dependencies: @@ -11005,21 +11879,21 @@ packages: whatwg-url: 12.0.1 dev: true - /date-fns/2.30.0: + /date-fns@2.30.0: resolution: {integrity: sha512-fnULvOpxnC5/Vg3NCiWelDsLiUc9bRwAPs/+LfTLNvetFCtCTN+yQz15C/fs4AwX1R9K5GLtLfn8QW+dWisaAw==} engines: {node: '>=0.11'} dependencies: '@babel/runtime': 7.22.6 - /dayjs/1.11.9: + /dayjs@1.11.9: resolution: {integrity: sha512-QvzAURSbQ0pKdIye2txOzNaHmxtUBXerpY0FJsFXUMKbIZeFm5ht1LS/jFsrncjnmtv8HsG0W2g6c0zUjZWmpA==} dev: true - /de-indent/1.0.2: + /de-indent@1.0.2: resolution: {integrity: sha512-e/1zu3xH5MQryN2zdVaF0OrdNLUbvWxzMbi+iNA6Bky7l1RoP8a2fIbRocyHclXt/arDrrR6lL3TqFD9pMQTsg==} dev: true - /debug/2.6.9: + /debug@2.6.9: resolution: {integrity: sha512-bC7ElrdJaJnPbAP+1EotYvqZsb3ecl5wi6Bfi6BJTUcNowp6cvspg0jXznRTKDjm/E7AdgFBVeAPVMNcKGsHMA==} peerDependencies: supports-color: '*' @@ -11030,18 +11904,7 @@ packages: ms: 2.0.0 dev: true - /debug/3.2.7: - resolution: {integrity: sha512-CFjzYYAi4ThfiQvizrFQevTTXHtnCqWfe7x1AhgEscTz6ZbLbfoLRLPugTQyBth6f8ZERVUSyWHFD/7Wu4t1XQ==} - peerDependencies: - supports-color: '*' - peerDependenciesMeta: - supports-color: - optional: true - dependencies: - ms: 2.1.3 - dev: true - - /debug/3.2.7_supports-color@8.1.1: + /debug@3.2.7(supports-color@8.1.1): resolution: {integrity: sha512-CFjzYYAi4ThfiQvizrFQevTTXHtnCqWfe7x1AhgEscTz6ZbLbfoLRLPugTQyBth6f8ZERVUSyWHFD/7Wu4t1XQ==} peerDependencies: supports-color: '*' @@ -11053,18 +11916,7 @@ packages: supports-color: 8.1.1 dev: true - /debug/4.3.4: - resolution: {integrity: sha512-PRWFHuSU3eDtQJPvnNY7Jcket1j0t5OuOsFzPPzsekD52Zl8qUfFIPEiswXqIvHWGVHOgX+7G/vCNNhehwxfkQ==} - engines: {node: '>=6.0'} - peerDependencies: - supports-color: '*' - peerDependenciesMeta: - supports-color: - optional: true - dependencies: - ms: 2.1.2 - - /debug/4.3.4_supports-color@8.1.1: + /debug@4.3.4(supports-color@8.1.1): resolution: {integrity: sha512-PRWFHuSU3eDtQJPvnNY7Jcket1j0t5OuOsFzPPzsekD52Zl8qUfFIPEiswXqIvHWGVHOgX+7G/vCNNhehwxfkQ==} engines: {node: '>=6.0'} peerDependencies: @@ -11075,28 +11927,27 @@ packages: dependencies: ms: 2.1.2 supports-color: 8.1.1 - dev: true - /decamelize/1.2.0: + /decamelize@1.2.0: resolution: {integrity: sha512-z2S+W9X73hAUUki+N+9Za2lBlun89zigOyGrsax+KUQ6wKW4ZoWpEYBkGhQjwAjjDCkWxhY0VKEhk8wzY7F5cA==} engines: {node: '>=0.10.0'} dev: true optional: true - /decamelize/6.0.0: + /decamelize@6.0.0: resolution: {integrity: sha512-Fv96DCsdOgB6mdGl67MT5JaTNKRzrzill5OH5s8bjYJXVlcXyPYGyPsUkWyGV5p1TXI5esYIYMMeDJL0hEIwaA==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dev: true - /decimal.js-light/2.5.1: + /decimal.js-light@2.5.1: resolution: {integrity: sha512-qIMFpTMZmny+MMIitAB6D7iVPEorVw6YQRWkvarTkT4tBeSLLiHzcwj6q0MmYSFCiVpiqPJTJEYIrpcPzVEIvg==} dev: false - /decimal.js/10.4.3: + /decimal.js@10.4.3: resolution: {integrity: sha512-VBBaLc1MgL5XpzgIP7ny5Z6Nx3UrRkIViUkPUdtl9aya5amy3De1gsUUSB1g3+3sExYNjCAsAznmukyxCb1GRA==} dev: true - /decode-bmp/0.2.1: + /decode-bmp@0.2.1: resolution: {integrity: sha512-NiOaGe+GN0KJqi2STf24hfMkFitDUaIoUU3eKvP/wAbLe8o6FuW5n/x7MHPR0HKvBokp6MQY/j7w8lewEeVCIA==} engines: {node: '>=8.6.0'} dependencies: @@ -11104,7 +11955,7 @@ packages: to-data-view: 1.1.0 dev: true - /decode-ico/0.4.1: + /decode-ico@0.4.1: resolution: {integrity: sha512-69NZfbKIzux1vBOd31al3XnMnH+2mqDhEgLdpygErm4d60N+UwA5Sq5WFjmEDQzumgB9fElojGwWG0vybVfFmA==} engines: {node: '>=8.6'} dependencies: @@ -11113,30 +11964,30 @@ packages: to-data-view: 1.1.0 dev: true - /decode-uri-component/0.2.2: + /decode-uri-component@0.2.2: resolution: {integrity: sha512-FqUYQ+8o158GyGTrMFJms9qh3CqTKvAqgqsTnkLI8sKu0028orqBhxNMFkFen0zGyg6epACD32pjVk58ngIErQ==} engines: {node: '>=0.10'} dev: true - /decompress-response/6.0.0: + /decompress-response@6.0.0: resolution: {integrity: sha512-aW35yZM6Bb/4oJlZncMH2LCoZtJXTRxES17vE3hoRiowU2kWHaJKFkSBDnDR+cm9J+9QhXmREyIfv0pji9ejCQ==} engines: {node: '>=10'} dependencies: mimic-response: 3.1.0 dev: true - /dedent/0.7.0: + /dedent@0.7.0: resolution: {integrity: sha512-Q6fKUPqnAHAyhiUgFU7BUzLiv0kd8saH9al7tnu5Q/okj6dnupxyTgFIBjVzJATdfIAm9NAsvXNzjaKa+bxVyA==} dev: true - /deep-eql/4.1.3: + /deep-eql@4.1.3: resolution: {integrity: sha512-WaEtAOpRA1MQ0eohqZjpGD8zdI0Ovsm8mmFhaDN8dvDZzyoUMcYDnf5Y6iu7HTXxf8JDS23qWa4a+hKCDyOPzw==} engines: {node: '>=6'} dependencies: type-detect: 4.0.8 dev: false - /deep-equal/2.2.2: + /deep-equal@2.2.2: resolution: {integrity: sha512-xjVyBf0w5vH0I42jdAZzOKVldmPgSulmiyPRywoyq7HXC9qdgo17kxJE+rdnif5Tz6+pIrpJI8dCpMNLIGkUiA==} dependencies: array-buffer-byte-length: 1.0.0 @@ -11159,26 +12010,26 @@ packages: which-typed-array: 1.1.10 dev: true - /deep-extend/0.6.0: + /deep-extend@0.6.0: resolution: {integrity: sha512-LOHxIOaPYdHlJRtCQfDIVZtfw/ufM8+rVj649RIHzcm/vGwQRXFt6OPqIFWsm2XEMrNIEtWR64sY1LEKD2vAOA==} engines: {node: '>=4.0.0'} dev: true - /deep-is/0.1.4: + /deep-is@0.1.4: resolution: {integrity: sha512-oIPzksmTg4/MriiaYGO+okXDT7ztn/w3Eptv/+gSIdMdKsJo0u4CfYNFJPy+4SKMuCqGw2wxnA+URMg3t8a/bQ==} dev: true - /deepmerge-ts/5.1.0: + /deepmerge-ts@5.1.0: resolution: {integrity: sha512-eS8dRJOckyo9maw9Tu5O5RUi/4inFLrnoLkBe3cPfDMx3WZioXtmOew4TXQaxq7Rhl4xjDtR7c6x8nNTxOvbFw==} engines: {node: '>=16.0.0'} dev: true - /deepmerge/4.3.1: + /deepmerge@4.3.1: resolution: {integrity: sha512-3sUqbMEc77XqpdNO7FRyRog+eW3ph+GYCbj+rK+uYyRMuwsVy0rMiVtPn+QJlKFvWP/1PYpapqYn0Me2knFn+A==} engines: {node: '>=0.10.0'} dev: true - /default-browser-id/1.0.4: + /default-browser-id@1.0.4: resolution: {integrity: sha512-qPy925qewwul9Hifs+3sx1ZYn14obHxpkX+mPD369w4Rzg+YkJBgi3SOvwUq81nWSjqGUegIgEPwD8u+HUnxlw==} engines: {node: '>=0.10.0'} hasBin: true @@ -11190,23 +12041,23 @@ packages: dev: true optional: true - /defaults/1.0.4: + /defaults@1.0.4: resolution: {integrity: sha512-eFuaLoy/Rxalv2kr+lqMlUnrDWV+3j4pljOIJgLIhI058IQfWJ7vXhyEIHu+HtC738klGALYxOKDO0bQP3tg8A==} dependencies: clone: 1.0.4 dev: true - /defer-to-connect/2.0.1: + /defer-to-connect@2.0.1: resolution: {integrity: sha512-4tvttepXG1VaYGrRibk5EwJd1t4udunSOVMdLSAL6mId1ix438oPwPZMALY41FCijukO1L0twNcGsdzS7dHgDg==} engines: {node: '>=10'} dev: true - /define-lazy-prop/2.0.0: + /define-lazy-prop@2.0.0: resolution: {integrity: sha512-Ds09qNh8yw3khSjiJjiUInaGX9xlqZDY7JVryGxdxV7NPeuqQfplOpQ66yJFZut3jLa5zOwkXw1g9EI2uKh4Og==} engines: {node: '>=8'} dev: true - /define-properties/1.2.0: + /define-properties@1.2.0: resolution: {integrity: sha512-xvqAVKGfT1+UAvPwKTVw/njhdQ8ZhXK4lI0bCIuCMrp2up9nPnaDftrLtmpTazqd1o+UY4zgzU+avtMbDP+ldA==} engines: {node: '>= 0.4'} dependencies: @@ -11214,21 +12065,21 @@ packages: object-keys: 1.1.1 dev: true - /define-property/0.2.5: + /define-property@0.2.5: resolution: {integrity: sha512-Rr7ADjQZenceVOAKop6ALkkRAmH1A4Gx9hV/7ZujPUN2rkATqFO0JZLZInbAjpZYoJ1gUx8MRMQVkYemcbMSTA==} engines: {node: '>=0.10.0'} dependencies: is-descriptor: 0.1.6 dev: true - /define-property/1.0.0: + /define-property@1.0.0: resolution: {integrity: sha512-cZTYKFWspt9jZsMscWo8sc/5lbPC9Q0N5nBLgb+Yd915iL3udB1uFgS3B8YCx66UVHq018DAVFoee7x+gxggeA==} engines: {node: '>=0.10.0'} dependencies: is-descriptor: 1.0.2 dev: true - /define-property/2.0.2: + /define-property@2.0.2: resolution: {integrity: sha512-jwK2UV4cnPpbcG7+VRARKTZPUWowwXA8bzH5NP6ud0oeAxyYPuGZUAC7hMugpCdz4BeSZl2Dl9k66CHJ/46ZYQ==} engines: {node: '>=0.10.0'} dependencies: @@ -11236,102 +12087,107 @@ packages: isobject: 3.0.1 dev: true - /defu/6.1.2: + /defu@6.1.2: resolution: {integrity: sha512-+uO4+qr7msjNNWKYPHqN/3+Dx3NFkmIzayk2L1MyZQlvgZb/J1A0fo410dpKrN2SnqFjt8n4JL8fDJE0wIgjFQ==} dev: true - /delayed-stream/1.0.0: + /delayed-stream@1.0.0: resolution: {integrity: sha512-ZySD7Nf91aLB0RxL4KGrKHBXl7Eds1DAmEdcoVawXnLD7SDhpNgtuII2aAkg7a7QS41jxPSZ17p4VdGnMHk3MQ==} engines: {node: '>=0.4.0'} dev: true - /delegates/1.0.0: + /delegates@1.0.0: resolution: {integrity: sha512-bd2L678uiWATM6m5Z1VzNCErI3jiGzt6HGY8OVICs40JQq/HALfbyNJmp0UDakEY4pMMaN0Ly5om/B1VI/+xfQ==} dev: true - /depd/2.0.0: + /depd@2.0.0: resolution: {integrity: sha512-g7nH6P6dyDioJogAAGprGpCtVImJhpPk/roCzdb3fIh61/s/nPsfR6onyMwkCAR/OlC3yBC0lESvUoQEAssIrw==} engines: {node: '>= 0.8'} dev: true - /dequal/2.0.3: + /dequal@2.0.3: resolution: {integrity: sha512-0je+qPKHEMohvfRTCEo3CrPG6cAzAYgmzKyxRiYSSDkS6eGJdyVJm7WaYA5ECaAD9wLB2T4EEeymA5aFVcYXCA==} engines: {node: '>=6'} dev: true - /des.js/1.1.0: + /des.js@1.1.0: resolution: {integrity: sha512-r17GxjhUCjSRy8aiJpr8/UadFIzMzJGexI3Nmz4ADi9LYSFx4gTBp80+NaX/YsXWWLhpZ7v/v/ubEc/bCNfKwg==} dependencies: inherits: 2.0.4 minimalistic-assert: 1.0.1 dev: true - /destr/1.2.2: + /destr@1.2.2: resolution: {integrity: sha512-lrbCJwD9saUQrqUfXvl6qoM+QN3W7tLV5pAOs+OqOmopCCz/JkE05MHedJR1xfk4IAnZuJXPVuN5+7jNA2ZCiA==} dev: true - /destr/2.0.0: + /destr@2.0.0: resolution: {integrity: sha512-FJ9RDpf3GicEBvzI3jxc2XhHzbqD8p4ANw/1kPsFBfTvP1b7Gn/Lg1vO7R9J4IVgoMbyUmFrFGZafJ1hPZpvlg==} dev: true - /destroy/1.2.0: + /destroy@1.2.0: resolution: {integrity: sha512-2sJGJTaXIIaR1w4iJSNoN0hnMY7Gpc/n8D4qSCJw8QqFWXf7cuAgnEHxBpweaVcPevC2l3KpjYCx3NypQQgaJg==} engines: {node: '>= 0.8', npm: 1.2.8000 || >= 1.4.16} dev: true - /detab/2.0.4: + /detab@2.0.4: resolution: {integrity: sha512-8zdsQA5bIkoRECvCrNKPla84lyoR7DSAyf7p0YgXzBO9PDJx8KntPUay7NS6yp+KdxdVtiE5SpHKtbp2ZQyA9g==} dependencies: repeat-string: 1.6.1 dev: true - /detect-indent/6.1.0: + /detect-indent@6.1.0: resolution: {integrity: sha512-reYkTUJAZb9gUuZ2RvVCNhVHdg62RHnJ7WJl8ftMi4diZ6NWlciOzQN88pUhSELEwflJht4oQDv0F0BMlwaYtA==} engines: {node: '>=8'} dev: true - /detect-libc/2.0.1: + /detect-libc@2.0.1: resolution: {integrity: sha512-463v3ZeIrcWtdgIg6vI6XUncguvr2TnGl4SzDXinkt9mSLpBJKXT3mW6xT3VQdDN11+WVs29pgvivTc4Lp8v+w==} engines: {node: '>=8'} dev: true - /detect-node/2.1.0: + /detect-newline@3.1.0: + resolution: {integrity: sha512-TLz+x/vEXm/Y7P7wn1EJFNLxYpUD4TgMosxY6fAVJUnJMbupHBOncxyWUG9OpTaH9EBD7uFI5LfEgmMOc54DsA==} + engines: {node: '>=8'} + dev: true + + /detect-node@2.1.0: resolution: {integrity: sha512-T0NIuQpnTvFDATNuHN5roPwSBG83rFsuO+MXXH9/3N1eFbn4wcPjttvjMLEPWJ0RGUYgQE7cGgS3tNxbqCGM7g==} - /detect-package-manager/2.0.1: + /detect-package-manager@2.0.1: resolution: {integrity: sha512-j/lJHyoLlWi6G1LDdLgvUtz60Zo5GEj+sVYtTVXnYLDPuzgC3llMxonXym9zIwhhUII8vjdw0LXxavpLqTbl1A==} engines: {node: '>=12'} dependencies: execa: 5.1.1 dev: true - /detect-port/1.5.1: + /detect-port@1.5.1: resolution: {integrity: sha512-aBzdj76lueB6uUst5iAs7+0H/oOjqI5D16XUWxlWMIMROhcM0rfsNVk93zTngq1dDNpoXRr++Sus7ETAExppAQ==} hasBin: true dependencies: address: 1.2.2 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) transitivePeerDependencies: - supports-color dev: true - /devalue/4.3.2: + /devalue@4.3.2: resolution: {integrity: sha512-KqFl6pOgOW+Y6wJgu80rHpo2/3H07vr8ntR9rkkFIRETewbf5GaYYcakYfiKz89K+sLsuPkQIZaXDMjUObZwWg==} dev: true - /devtools-protocol/0.0.1120988: + /devtools-protocol@0.0.1120988: resolution: {integrity: sha512-39fCpE3Z78IaIPChJsP6Lhmkbf4dWXOmzLk/KFTdRkNk/0JymRIfUynDVRndV9HoDz8PyalK1UH21ST/ivwW5Q==} dev: true - /devtools-protocol/0.0.1161598: + /devtools-protocol@0.0.1161598: resolution: {integrity: sha512-MQNeVRDiJ9yAfHUlumx7OCweu15GgMIqEIvz/DTZwpZKjT7oGo9FcwUqS7PyH0mDJsWnuJIn41BZ4SPoQbZfew==} dev: true - /devtools-protocol/0.0.981744: + /devtools-protocol@0.0.981744: resolution: {integrity: sha512-0cuGS8+jhR67Fy7qG3i3Pc7Aw494sb9yG9QgpG97SFVWwolgYjlhJg7n+UaHxOQT30d1TYu/EYe9k01ivLErIg==} dev: true - /devtools/8.12.1: + /devtools@8.12.1(typescript@5.1.6): resolution: {integrity: sha512-R72raQLN1lDSqbr2DVj9SRh07JRyojzmrcLa33VBa2nw3cf5ZyHOHe0DgxlJ/5c2Dfs1+wGNJy16gWKGBq+xgg==} engines: {node: ^16.13 || >=18} dependencies: @@ -11344,7 +12200,7 @@ packages: chrome-launcher: 0.15.2 edge-paths: 3.0.5 import-meta-resolve: 3.0.0 - puppeteer-core: 20.3.0 + puppeteer-core: 20.3.0(typescript@5.1.6) query-selector-shadow-dom: 1.0.1 ua-parser-js: 1.0.35 uuid: 9.0.0 @@ -11357,23 +12213,28 @@ packages: - utf-8-validate dev: true - /dezalgo/1.0.4: + /dezalgo@1.0.4: resolution: {integrity: sha512-rXSP0bf+5n0Qonsb+SVVfNfIsimO4HEtmnIpPHY8Q1UCzKlQrDMfdobr8nJOOsRgWCyMRqeSBQzmWUMq7zvVig==} dependencies: asap: 2.0.6 wrappy: 1.0.2 dev: true - /diff-sequences/29.4.3: + /diff-sequences@27.5.1: + resolution: {integrity: sha512-k1gCAXAsNgLwEL+Y8Wvl+M6oEFj5bgazfZULpS5CneoPPXRaCCW7dm+q21Ky2VEE5X+VeRDBVg1Pcvvsr4TtNQ==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dev: true + + /diff-sequences@29.4.3: resolution: {integrity: sha512-ofrBgwpPhCD85kMKtE9RYFFq6OC1A89oW2vvgWZNCwxrUpRUILopY7lsYyMDSjc8g6U6aiO0Qubg6r4Wgt5ZnA==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} - /diff/4.0.2: + /diff@4.0.2: resolution: {integrity: sha512-58lmxKSA4BNyLz+HHMUzlOEpg09FV+ev6ZMe3vJihgdxzgcwZ8VoEEPmALCZG9LmqfVoNMMKpttIYTVG6uDY7A==} engines: {node: '>=0.3.1'} dev: true - /diffie-hellman/5.0.3: + /diffie-hellman@5.0.3: resolution: {integrity: sha512-kqag/Nl+f3GwyK25fhUMYj81BUOrZ9IuJsjIcDE5icNM9FJHAVm3VcUDxdLPoQtTuUylWm6ZIknYJwwaPxsUzg==} dependencies: bn.js: 4.12.0 @@ -11381,66 +12242,66 @@ packages: randombytes: 2.1.0 dev: true - /dir-glob/2.2.2: + /dir-glob@2.2.2: resolution: {integrity: sha512-f9LBi5QWzIW3I6e//uxZoLBlUt9kcp66qo0sSCxL6YZKc75R1c4MFCoe/LaZiBGmgujvQdxc5Bn3QhfyvK5Hsw==} engines: {node: '>=4'} dependencies: path-type: 3.0.0 dev: true - /dir-glob/3.0.1: + /dir-glob@3.0.1: resolution: {integrity: sha512-WkrWp9GR4KXfKGYzOLmTuGVi1UWFfws377n9cc55/tb6DuqyF6pcQ5AbiHEshaDpY9v6oaSr2XCDidGmMwdzIA==} engines: {node: '>=8'} dependencies: path-type: 4.0.0 dev: true - /discontinuous-range/1.0.0: + /discontinuous-range@1.0.0: resolution: {integrity: sha512-c68LpLbO+7kP/b1Hr1qs8/BJ09F5khZGTxqxZuhzxpmwJKOgRFHJWIb9/KmqnqHhLdO55aOxFH/EGBvUQbL/RQ==} dev: true - /doctrine/2.1.0: + /doctrine@2.1.0: resolution: {integrity: sha512-35mSku4ZXK0vfCuHEDAwt55dg2jNajHZ1odvF+8SSr82EsZY4QmXfuWso8oEd8zRhVObSN18aM0CjSdoBX7zIw==} engines: {node: '>=0.10.0'} dependencies: esutils: 2.0.3 dev: true - /doctrine/3.0.0: + /doctrine@3.0.0: resolution: {integrity: sha512-yS+Q5i3hBf7GBkd4KG8a7eBNNWNGLTaEwwYWUijIYM7zrlYDM0BFXHjjPWlWZ1Rg7UaddZeIDmi9jF3HmqiQ2w==} engines: {node: '>=6.0.0'} dependencies: esutils: 2.0.3 dev: true - /dom-accessibility-api/0.5.16: + /dom-accessibility-api@0.5.16: resolution: {integrity: sha512-X7BJ2yElsnOJ30pZF4uIIDfBEVgF4XEBxL9Bxhy6dnrm5hkzqmsWHGTiHqRiITNhMyFLyAiWndIJP7Z1NTteDg==} dev: true - /dom-converter/0.2.0: + /dom-converter@0.2.0: resolution: {integrity: sha512-gd3ypIPfOMr9h5jIKq8E3sHOTCjeirnl0WK5ZdS1AW0Odt0b1PaWaHdJ4Qk4klv+YB9aJBS7mESXjFoDQPu6DA==} dependencies: utila: 0.4.0 dev: true - /dom-event-types/1.1.0: + /dom-event-types@1.1.0: resolution: {integrity: sha512-jNCX+uNJ3v38BKvPbpki6j5ItVlnSqVV6vDWGS6rExzCMjsc39frLjm1n91o6YaKK6AZl0wLloItW6C6mr61BQ==} dev: true - /dom-helpers/3.4.0: + /dom-helpers@3.4.0: resolution: {integrity: sha512-LnuPJ+dwqKDIyotW1VzmOZ5TONUN7CwkCR5hrgawTUbkBGYdeoNLZo6nNfGkCrjtE1nXXaj7iMMpDa8/d9WoIA==} dependencies: '@babel/runtime': 7.22.6 dev: false - /dom-helpers/5.2.1: + /dom-helpers@5.2.1: resolution: {integrity: sha512-nRCa7CK3VTrM2NmGkIy4cbK7IZlgBE/PYMn55rrXefr5xXDP0LdtfPnblFDoVdcAfslJ7or6iqAUnx0CCGIWQA==} dependencies: '@babel/runtime': 7.22.6 csstype: 3.1.2 dev: false - /dom-serializer/1.4.1: + /dom-serializer@1.4.1: resolution: {integrity: sha512-VHwB3KfrcOOkelEG2ZOfxqLZdfkil8PtJi4P8N2MMXucZq2yLp75ClViUlOVwyoHEDjYU433Aq+5zWP61+RGag==} dependencies: domelementtype: 2.3.0 @@ -11448,7 +12309,7 @@ packages: entities: 2.2.0 dev: true - /dom-serializer/2.0.0: + /dom-serializer@2.0.0: resolution: {integrity: sha512-wIkAryiqt/nV5EQKqQpo3SToSOV9J0DnbJqwK7Wv/Trc92zIAYZ4FlMu+JPFW1DfGFt81ZTCGgDEabffXeLyJg==} dependencies: domelementtype: 2.3.0 @@ -11456,48 +12317,55 @@ packages: entities: 4.5.0 dev: true - /dom-walk/0.1.2: + /dom-walk@0.1.2: resolution: {integrity: sha512-6QvTW9mrGeIegrFXdtQi9pk7O/nSK6lSdXW2eqUspN5LWD7UTji2Fqw5V2YLjBpHEoU9Xl/eUWNpDeZvoyOv2w==} dev: true - /domain-browser/1.2.0: + /domain-browser@1.2.0: resolution: {integrity: sha512-jnjyiM6eRyZl2H+W8Q/zLMA481hzi0eszAaBUzIVnmYVDBbnLxVNnfu1HgEBvCbL+71FrxMl3E6lpKH7Ge3OXA==} engines: {node: '>=0.4', npm: '>=1.2'} dev: true - /domelementtype/2.3.0: + /domelementtype@2.3.0: resolution: {integrity: sha512-OLETBj6w0OsagBwdXnPdN0cnMfF9opN69co+7ZrbfPGrdpPVNBUj02spi6B1N7wChLQiPn4CSH/zJvXw56gmHw==} dev: true - /domexception/4.0.0: + /domexception@2.0.1: + resolution: {integrity: sha512-yxJ2mFy/sibVQlu5qHjOkf9J3K6zgmCxgJ94u2EdvDOV09H+32LtRswEcUsmUWN72pVLOEnTSRaIVVzVQgS0dg==} + engines: {node: '>=8'} + dependencies: + webidl-conversions: 5.0.0 + dev: true + + /domexception@4.0.0: resolution: {integrity: sha512-A2is4PLG+eeSfoTMA95/s4pvAoSo2mKtiM5jlHkAVewmiO8ISFTFKZjH7UAM1Atli/OT/7JHOrJRJiMKUZKYBw==} engines: {node: '>=12'} dependencies: webidl-conversions: 7.0.0 dev: true - /domhandler/3.3.0: + /domhandler@3.3.0: resolution: {integrity: sha512-J1C5rIANUbuYK+FuFL98650rihynUOEzRLxW+90bKZRWB6A1X1Tf82GxR1qAWLyfNPRvjqfip3Q5tdYlmAa9lA==} engines: {node: '>= 4'} dependencies: domelementtype: 2.3.0 dev: true - /domhandler/4.3.1: + /domhandler@4.3.1: resolution: {integrity: sha512-GrwoxYN+uWlzO8uhUXRl0P+kHE4GtVPfYzVLcUxPL7KNdHKj66vvlhiweIHqYYXWlw+T8iLMp42Lm67ghw4WMQ==} engines: {node: '>= 4'} dependencies: domelementtype: 2.3.0 dev: true - /domhandler/5.0.3: + /domhandler@5.0.3: resolution: {integrity: sha512-cgwlv/1iFQiFnU96XXgROh8xTeetsnJiDsTc7TYCLFd9+/WNkIqPTxiM/8pSd8VIrhXGTf1Ny1q1hquVqDJB5w==} engines: {node: '>= 4'} dependencies: domelementtype: 2.3.0 dev: true - /domutils/2.8.0: + /domutils@2.8.0: resolution: {integrity: sha512-w96Cjofp72M5IIhpjgobBimYEfoPjx1Vx0BSX9P30WBdZW2WIKU0T1Bd0kz2eNZ9ikjKgHbEyKx8BB6H1L3h3A==} dependencies: dom-serializer: 1.4.1 @@ -11505,7 +12373,7 @@ packages: domhandler: 4.3.1 dev: true - /domutils/3.1.0: + /domutils@3.1.0: resolution: {integrity: sha512-H78uMmQtI2AhgDJjWeQmHwJJ2bLPD3GMmO7Zja/ZZh84wkm+4ut+IUnUdRa8uCGX88DiVx1j6FRe1XfxEgjEZA==} dependencies: dom-serializer: 2.0.0 @@ -11513,32 +12381,32 @@ packages: domhandler: 5.0.3 dev: true - /dot-case/3.0.4: + /dot-case@3.0.4: resolution: {integrity: sha512-Kv5nKlh6yRrdrGvxeJ2e5y2eRUpkUosIW4A2AS38zwSz27zu7ufDwQPi5Jhs3XAlGNetl3bmnGhQsMtkKJnj3w==} dependencies: no-case: 3.0.4 tslib: 2.6.0 dev: true - /dotenv-expand/5.1.0: + /dotenv-expand@5.1.0: resolution: {integrity: sha512-YXQl1DSa4/PQyRfgrv6aoNjhasp/p4qs9FjJ4q4cQk+8m4r6k4ZSiEyytKG8f8W9gi8WsQtIObNmKd+tMzNTmA==} dev: true - /dotenv/16.3.1: + /dotenv@16.3.1: resolution: {integrity: sha512-IPzF4w4/Rd94bA9imS68tZBaYyBWSCE47V1RGuMrB94iyTOIEwRmVL2x/4An+6mETpLrKJ5hQkB8W4kFAadeIQ==} engines: {node: '>=12'} dev: true - /dotenv/8.6.0: + /dotenv@8.6.0: resolution: {integrity: sha512-IrPdXQsk2BbzvCBGBOTmmSH5SodmqZNt4ERAZDmW4CT+tL8VtvinqywuANaFu4bOMWki16nqf0e4oC0QIaDr/g==} engines: {node: '>=10'} dev: true - /duplexer/0.1.2: + /duplexer@0.1.2: resolution: {integrity: sha512-jtD6YG370ZCIi/9GTaJKQxWTZD045+4R4hTk/x1UyoqadyJ9x9CgSi1RlVDQF8U2sxLLSnFkCaMihqljHIWgMg==} dev: true - /duplexify/3.7.1: + /duplexify@3.7.1: resolution: {integrity: sha512-07z8uv2wMyS51kKhD1KsdXJg5WQ6t93RneqRxUHnskXVtlYYkLqM0gqStQZ3pj073g687jPCHrqNfCzawLYh5g==} dependencies: end-of-stream: 1.4.4 @@ -11547,18 +12415,18 @@ packages: stream-shift: 1.0.1 dev: true - /eastasianwidth/0.2.0: + /eastasianwidth@0.2.0: resolution: {integrity: sha512-I88TYZWc9XiYHRQ4/3c5rjjfgkjhLyW2luGIheGERbNQ6OY7yTybanSpDXZa8y7VUP9YmDcYa+eyq4ca7iLqWA==} dev: true - /ecc-jsbn/0.1.2: + /ecc-jsbn@0.1.2: resolution: {integrity: sha512-eh9O+hwRHNbG4BLTjEl3nw044CkGm5X6LoaCf7LPp7UU8Qrt47JYNi6nPX8xjW97TKGKm1ouctg0QSpZe9qrnw==} dependencies: jsbn: 0.1.1 safer-buffer: 2.1.2 dev: true - /edge-paths/3.0.5: + /edge-paths@3.0.5: resolution: {integrity: sha512-sB7vSrDnFa4ezWQk9nZ/n0FdpdUuC6R1EOrlU3DL+bovcNFK28rqu2emmAUjujYEJTWIgQGqgVVWUZXMnc8iWg==} engines: {node: '>=14.0.0'} dependencies: @@ -11566,7 +12434,7 @@ packages: which: 2.0.2 dev: true - /editorconfig/0.15.3: + /editorconfig@0.15.3: resolution: {integrity: sha512-M9wIMFx96vq0R4F+gRpY3o2exzb8hEj/n9S8unZtHSvYjibBp/iMufSzvmOcV/laG0ZtuTVGtiJggPOSW2r93g==} hasBin: true dependencies: @@ -11576,11 +12444,11 @@ packages: sigmund: 1.0.1 dev: true - /ee-first/1.1.1: + /ee-first@1.1.1: resolution: {integrity: sha512-WMwm9LhRUo+WUaRN+vRuETqG89IgZphVSNkdFgeb6sS/E4OrDIN7t48CAewSHXc6C8lefD8KKfr5vY61brQlow==} dev: true - /ejs/3.1.9: + /ejs@3.1.9: resolution: {integrity: sha512-rC+QVNMJWv+MtPgkt0y+0rVEIdbtxVADApW9JXrUVlzHetgcyczP/E7DJmWJ4fJCZF2cPcBk0laWO9ZHMG3DmQ==} engines: {node: '>=0.10.0'} hasBin: true @@ -11588,10 +12456,10 @@ packages: jake: 10.8.7 dev: true - /electron-to-chromium/1.4.457: + /electron-to-chromium@1.4.457: resolution: {integrity: sha512-/g3UyNDmDd6ebeWapmAoiyy+Sy2HyJ+/X8KyvNeHfKRFfHaA2W8oF5fxD5F3tjBDcjpwo0iek6YNgxNXDBoEtA==} - /elliptic/6.5.4: + /elliptic@6.5.4: resolution: {integrity: sha512-iLhC6ULemrljPZb+QutR5TQGB+pdW6KGD5RSegS+8sorOZT+rdQFbsQFJgvN3eRqNALqJer4oQ16YvJHlU8hzQ==} dependencies: bn.js: 4.12.0 @@ -11603,31 +12471,36 @@ packages: minimalistic-crypto-utils: 1.0.1 dev: true - /emoji-regex/8.0.0: + /emittery@0.8.1: + resolution: {integrity: sha512-uDfvUjVrfGJJhymx/kz6prltenw1u7WrCg1oa94zYY8xxVpLLUu045LAT0dhDZdXG58/EpPL/5kA180fQ/qudg==} + engines: {node: '>=10'} + dev: true + + /emoji-regex@8.0.0: resolution: {integrity: sha512-MSjYzcWNOA0ewAHpz0MxpYFvwg6yjy1NG3xteoqz644VCo/RPgnr1/GGt+ic3iJTzQ8Eu3TdM14SawnVUmGE6A==} dev: true - /emoji-regex/9.2.2: + /emoji-regex@9.2.2: resolution: {integrity: sha512-L18DaJsXSUk2+42pv8mLs5jJT2hqFkFE4j21wOmgbUqsZ2hL72NsUU785g9RXgo3s0ZNgVl42TiHp3ZtOv/Vyg==} dev: true - /emojis-list/3.0.0: + /emojis-list@3.0.0: resolution: {integrity: sha512-/kyM18EfinwXZbno9FyUGeFh87KC8HRQBQGildHZbEuRyWFOmv1U10o9BBp8XVZDVNNuQKyIGIu5ZYAAXJ0V2Q==} engines: {node: '>= 4'} dev: true - /encodeurl/1.0.2: + /encodeurl@1.0.2: resolution: {integrity: sha512-TPJXq8JqFaVYm2CWmPvnP2Iyo4ZSM7/QKcSmuMLDObfpH5fi7RUGmd/rTDf+rut/saiDiQEeVTNgAmJEdAOx0w==} engines: {node: '>= 0.8'} dev: true - /end-of-stream/1.4.4: + /end-of-stream@1.4.4: resolution: {integrity: sha512-+uw1inIHVPQoaVuHzRyXd21icM+cnt4CzD5rW+NC1wjOUSTOs+Te7FOv7AhN7vS9x/oIyhLP5PR1H+phQAHu5Q==} dependencies: once: 1.4.0 dev: true - /endent/2.1.0: + /endent@2.1.0: resolution: {integrity: sha512-r8VyPX7XL8U01Xgnb1CjZ3XV+z90cXIJ9JPE/R9SEC9vpw2P6CfsRPJmp20DppC5N7ZAMCmjYkJIa744Iyg96w==} dependencies: dedent: 0.7.0 @@ -11635,7 +12508,7 @@ packages: objectorarray: 1.0.5 dev: true - /enhanced-resolve/4.5.0: + /enhanced-resolve@4.5.0: resolution: {integrity: sha512-Nv9m36S/vxpsI+Hc4/ZGRs0n9mXqSWGGq49zxb/cJfPAQMbUtttJAlNPS4AQzaBdw/pKskw5bMbekT/Y7W/Wlg==} engines: {node: '>=6.9.0'} dependencies: @@ -11644,7 +12517,7 @@ packages: tapable: 1.1.3 dev: true - /enhanced-resolve/5.15.0: + /enhanced-resolve@5.15.0: resolution: {integrity: sha512-LXYT42KJ7lpIKECr2mAXIaMldcNCh/7E0KBKOu4KSfkHmP+mZmSs+8V5gBAqisWBy0OO4W5Oyys0GO1Y8KtdKg==} engines: {node: '>=10.13.0'} dependencies: @@ -11652,30 +12525,30 @@ packages: tapable: 2.2.1 dev: true - /enquirer/2.3.6: + /enquirer@2.3.6: resolution: {integrity: sha512-yjNnPr315/FjS4zIsUxYguYUPP2e1NK4d7E7ZOLiyYCcbFBiTMyID+2wvm2w6+pZ/odMA7cRkjhsPbltwBOrLg==} engines: {node: '>=8.6'} dependencies: ansi-colors: 4.1.3 dev: true - /entities/2.2.0: + /entities@2.2.0: resolution: {integrity: sha512-p92if5Nz619I0w+akJrLZH0MX0Pb5DX39XOwQTtXSdQQOaYH03S1uIQp4mhOZtAXrxq4ViO67YTiLBo2638o9A==} dev: true - /entities/4.5.0: + /entities@4.5.0: resolution: {integrity: sha512-V0hjH4dGPh9Ao5p0MoRY6BVqtwCjhz6vI5LT8AJ55H+4g9/4vbHx1I54fS0XuclLhDHArPQCiMjDxjaL8fPxhw==} engines: {node: '>=0.12'} dev: true - /enzyme-shallow-equal/1.0.5: + /enzyme-shallow-equal@1.0.5: resolution: {integrity: sha512-i6cwm7hN630JXenxxJFBKzgLC3hMTafFQXflvzHgPmDhOBhxUWDe8AeRv1qp2/uWJ2Y8z5yLWMzmAfkTOiOCZg==} dependencies: has: 1.0.3 object-is: 1.1.5 dev: true - /enzyme/3.11.0: + /enzyme@3.11.0: resolution: {integrity: sha512-Dw8/Gs4vRjxY6/6i9wU0V+utmQO9kvh9XLnz3LIudviOnVYDEe2ec+0k+NQoMamn1VrjKgCUOWj5jG/5M5M0Qw==} dependencies: array.prototype.flat: 1.3.1 @@ -11702,25 +12575,25 @@ packages: string.prototype.trim: 1.2.7 dev: true - /errno/0.1.8: + /errno@0.1.8: resolution: {integrity: sha512-dJ6oBr5SQ1VSd9qkk7ByRgb/1SH4JZjCHSW/mr63/QcXO9zLVxvJ6Oy13nio03rxpSnVDDjFor75SjVeZWPW/A==} hasBin: true dependencies: prr: 1.0.1 dev: true - /error-ex/1.3.2: + /error-ex@1.3.2: resolution: {integrity: sha512-7dFHNmqeFSEt2ZBsCriorKnn3Z2pj+fd9kmI6QoWw4//DL+icEBfc0U7qJCisqrTsKTjw4fNFy2pW9OqStD84g==} dependencies: is-arrayish: 0.2.1 - /error-stack-parser/2.1.4: + /error-stack-parser@2.1.4: resolution: {integrity: sha512-Sk5V6wVazPhq5MhpO+AUxJn5x7XSXGl1R93Vn7i+zS15KDVxQijejNCrz8340/2bgLBjR9GtEG8ZVKONDjcqGQ==} dependencies: stackframe: 1.3.4 dev: true - /es-abstract/1.21.2: + /es-abstract@1.21.2: resolution: {integrity: sha512-y/B5POM2iBnIxCiernH1G7rC9qQoM77lLIMQLuob0zhp8C56Po81+2Nj0WFKnd0pNReDTnkYryc+zhOzpEIROg==} engines: {node: '>= 0.4'} dependencies: @@ -11760,11 +12633,11 @@ packages: which-typed-array: 1.1.10 dev: true - /es-array-method-boxes-properly/1.0.0: + /es-array-method-boxes-properly@1.0.0: resolution: {integrity: sha512-wd6JXUmyHmt8T5a2xreUwKcGPq6f1f+WwIJkijUqiGcJz1qqnZgP6XIK+QyIWU5lT7imeNxUll48bziG+TSYcA==} dev: true - /es-get-iterator/1.1.3: + /es-get-iterator@1.1.3: resolution: {integrity: sha512-sPZmqHBe6JIiTfN5q2pEi//TwxmAFHwj/XEuYjTuse78i8KxaqMTTzxPoFKuzRpDpTJ+0NAbpfenkmH2rePtuw==} dependencies: call-bind: 1.0.2 @@ -11778,15 +12651,15 @@ packages: stop-iteration-iterator: 1.0.0 dev: true - /es-module-lexer/0.9.3: + /es-module-lexer@0.9.3: resolution: {integrity: sha512-1HQ2M2sPtxwnvOvT1ZClHyQDiggdNjURWpY2we6aMKCQiUVxTmVs2UYPLIrD84sS+kMdUwfBSylbJPwNnBrnHQ==} dev: true - /es-module-lexer/1.3.0: + /es-module-lexer@1.3.0: resolution: {integrity: sha512-vZK7T0N2CBmBOixhmjdqx2gWVbFZ4DXZ/NyRMZVlJXPa7CyFS+/a4QQsDGDQy9ZfEzxFuNEsMLeQJnKP2p5/JA==} dev: true - /es-set-tostringtag/2.0.1: + /es-set-tostringtag@2.0.1: resolution: {integrity: sha512-g3OMbtlwY3QewlqAiMLI47KywjWZoEytKr8pf6iTC8uJq5bIAH52Z9pnQ8pVL6whrCto53JZDuUIsifGeLorTg==} engines: {node: '>= 0.4'} dependencies: @@ -11795,13 +12668,13 @@ packages: has-tostringtag: 1.0.0 dev: true - /es-shim-unscopables/1.0.0: + /es-shim-unscopables@1.0.0: resolution: {integrity: sha512-Jm6GPcCdC30eMLbZ2x8z2WuRwAws3zTBBKuusffYVUrNj/GVSUAZ+xKMaUpfNDR5IbyNA5LJbaecoUVbmUcB1w==} dependencies: has: 1.0.3 dev: true - /es-to-primitive/1.2.1: + /es-to-primitive@1.2.1: resolution: {integrity: sha512-QCOllgZJtaUo9miYBcLChTUaHNjJF3PYs1VidD7AwiEj1kYxKeQTctLAezAOH5ZKRH0g2IgPn6KwB4IT8iRpvA==} engines: {node: '>= 0.4'} dependencies: @@ -11810,20 +12683,20 @@ packages: is-symbol: 1.0.4 dev: true - /es5-shim/4.6.7: + /es5-shim@4.6.7: resolution: {integrity: sha512-jg21/dmlrNQI7JyyA2w7n+yifSxBng0ZralnSfVZjoCawgNTCnS+yBCyVM9DL5itm7SUnDGgv7hcq2XCZX4iRQ==} engines: {node: '>=0.4.0'} dev: true - /es6-promise/3.3.1: + /es6-promise@3.3.1: resolution: {integrity: sha512-SOp9Phqvqn7jtEUxPWdWfWoLmyt2VaJ6MpvP9Comy1MceMXqE6bxvaTu4iaxpYYPzhny28Lc+M87/c2cPK6lDg==} dev: true - /es6-shim/0.35.8: + /es6-shim@0.35.8: resolution: {integrity: sha512-Twf7I2v4/1tLoIXMT8HlqaBSS5H2wQTs2wx3MNYCI8K1R1/clXyCazrcVCPm/FuO9cyV8+leEaZOWD5C253NDg==} dev: true - /esbuild-android-64/0.14.54: + /esbuild-android-64@0.14.54: resolution: {integrity: sha512-Tz2++Aqqz0rJ7kYBfz+iqyE3QMycD4vk7LBRyWaAVFgFtQ/O8EJOnVmTOiDWYZ/uYzB4kvP+bqejYdVKzE5lAQ==} engines: {node: '>=12'} cpu: [x64] @@ -11832,7 +12705,7 @@ packages: dev: false optional: true - /esbuild-android-arm64/0.14.54: + /esbuild-android-arm64@0.14.54: resolution: {integrity: sha512-F9E+/QDi9sSkLaClO8SOV6etqPd+5DgJje1F9lOWoNncDdOBL2YF59IhsWATSt0TLZbYCf3pNlTHvVV5VfHdvg==} engines: {node: '>=12'} cpu: [arm64] @@ -11841,7 +12714,7 @@ packages: dev: false optional: true - /esbuild-darwin-64/0.14.54: + /esbuild-darwin-64@0.14.54: resolution: {integrity: sha512-jtdKWV3nBviOd5v4hOpkVmpxsBy90CGzebpbO9beiqUYVMBtSc0AL9zGftFuBon7PNDcdvNCEuQqw2x0wP9yug==} engines: {node: '>=12'} cpu: [x64] @@ -11850,7 +12723,7 @@ packages: dev: false optional: true - /esbuild-darwin-arm64/0.14.54: + /esbuild-darwin-arm64@0.14.54: resolution: {integrity: sha512-OPafJHD2oUPyvJMrsCvDGkRrVCar5aVyHfWGQzY1dWnzErjrDuSETxwA2HSsyg2jORLY8yBfzc1MIpUkXlctmw==} engines: {node: '>=12'} cpu: [arm64] @@ -11859,7 +12732,7 @@ packages: dev: false optional: true - /esbuild-freebsd-64/0.14.54: + /esbuild-freebsd-64@0.14.54: resolution: {integrity: sha512-OKwd4gmwHqOTp4mOGZKe/XUlbDJ4Q9TjX0hMPIDBUWWu/kwhBAudJdBoxnjNf9ocIB6GN6CPowYpR/hRCbSYAg==} engines: {node: '>=12'} cpu: [x64] @@ -11868,7 +12741,7 @@ packages: dev: false optional: true - /esbuild-freebsd-arm64/0.14.54: + /esbuild-freebsd-arm64@0.14.54: resolution: {integrity: sha512-sFwueGr7OvIFiQT6WeG0jRLjkjdqWWSrfbVwZp8iMP+8UHEHRBvlaxL6IuKNDwAozNUmbb8nIMXa7oAOARGs1Q==} engines: {node: '>=12'} cpu: [arm64] @@ -11877,7 +12750,7 @@ packages: dev: false optional: true - /esbuild-linux-32/0.14.54: + /esbuild-linux-32@0.14.54: resolution: {integrity: sha512-1ZuY+JDI//WmklKlBgJnglpUL1owm2OX+8E1syCD6UAxcMM/XoWd76OHSjl/0MR0LisSAXDqgjT3uJqT67O3qw==} engines: {node: '>=12'} cpu: [ia32] @@ -11886,7 +12759,7 @@ packages: dev: false optional: true - /esbuild-linux-64/0.14.54: + /esbuild-linux-64@0.14.54: resolution: {integrity: sha512-EgjAgH5HwTbtNsTqQOXWApBaPVdDn7XcK+/PtJwZLT1UmpLoznPd8c5CxqsH2dQK3j05YsB3L17T8vE7cp4cCg==} engines: {node: '>=12'} cpu: [x64] @@ -11895,25 +12768,25 @@ packages: dev: false optional: true - /esbuild-linux-arm/0.14.54: - resolution: {integrity: sha512-qqz/SjemQhVMTnvcLGoLOdFpCYbz4v4fUo+TfsWG+1aOu70/80RV6bgNpR2JCrppV2moUQkww+6bWxXRL9YMGw==} + /esbuild-linux-arm64@0.14.54: + resolution: {integrity: sha512-WL71L+0Rwv+Gv/HTmxTEmpv0UgmxYa5ftZILVi2QmZBgX3q7+tDeOQNqGtdXSdsL8TQi1vIaVFHUPDe0O0kdig==} engines: {node: '>=12'} - cpu: [arm] + cpu: [arm64] os: [linux] requiresBuild: true dev: false optional: true - /esbuild-linux-arm64/0.14.54: - resolution: {integrity: sha512-WL71L+0Rwv+Gv/HTmxTEmpv0UgmxYa5ftZILVi2QmZBgX3q7+tDeOQNqGtdXSdsL8TQi1vIaVFHUPDe0O0kdig==} + /esbuild-linux-arm@0.14.54: + resolution: {integrity: sha512-qqz/SjemQhVMTnvcLGoLOdFpCYbz4v4fUo+TfsWG+1aOu70/80RV6bgNpR2JCrppV2moUQkww+6bWxXRL9YMGw==} engines: {node: '>=12'} - cpu: [arm64] + cpu: [arm] os: [linux] requiresBuild: true dev: false optional: true - /esbuild-linux-mips64le/0.14.54: + /esbuild-linux-mips64le@0.14.54: resolution: {integrity: sha512-qTHGQB8D1etd0u1+sB6p0ikLKRVuCWhYQhAHRPkO+OF3I/iSlTKNNS0Lh2Oc0g0UFGguaFZZiPJdJey3AGpAlw==} engines: {node: '>=12'} cpu: [mips64el] @@ -11922,7 +12795,7 @@ packages: dev: false optional: true - /esbuild-linux-ppc64le/0.14.54: + /esbuild-linux-ppc64le@0.14.54: resolution: {integrity: sha512-j3OMlzHiqwZBDPRCDFKcx595XVfOfOnv68Ax3U4UKZ3MTYQB5Yz3X1mn5GnodEVYzhtZgxEBidLWeIs8FDSfrQ==} engines: {node: '>=12'} cpu: [ppc64] @@ -11931,7 +12804,7 @@ packages: dev: false optional: true - /esbuild-linux-riscv64/0.14.54: + /esbuild-linux-riscv64@0.14.54: resolution: {integrity: sha512-y7Vt7Wl9dkOGZjxQZnDAqqn+XOqFD7IMWiewY5SPlNlzMX39ocPQlOaoxvT4FllA5viyV26/QzHtvTjVNOxHZg==} engines: {node: '>=12'} cpu: [riscv64] @@ -11940,7 +12813,7 @@ packages: dev: false optional: true - /esbuild-linux-s390x/0.14.54: + /esbuild-linux-s390x@0.14.54: resolution: {integrity: sha512-zaHpW9dziAsi7lRcyV4r8dhfG1qBidQWUXweUjnw+lliChJqQr+6XD71K41oEIC3Mx1KStovEmlzm+MkGZHnHA==} engines: {node: '>=12'} cpu: [s390x] @@ -11949,7 +12822,7 @@ packages: dev: false optional: true - /esbuild-netbsd-64/0.14.54: + /esbuild-netbsd-64@0.14.54: resolution: {integrity: sha512-PR01lmIMnfJTgeU9VJTDY9ZerDWVFIUzAtJuDHwwceppW7cQWjBBqP48NdeRtoP04/AtO9a7w3viI+PIDr6d+w==} engines: {node: '>=12'} cpu: [x64] @@ -11958,7 +12831,7 @@ packages: dev: false optional: true - /esbuild-openbsd-64/0.14.54: + /esbuild-openbsd-64@0.14.54: resolution: {integrity: sha512-Qyk7ikT2o7Wu76UsvvDS5q0amJvmRzDyVlL0qf5VLsLchjCa1+IAvd8kTBgUxD7VBUUVgItLkk609ZHUc1oCaw==} engines: {node: '>=12'} cpu: [x64] @@ -11967,7 +12840,7 @@ packages: dev: false optional: true - /esbuild-sunos-64/0.14.54: + /esbuild-sunos-64@0.14.54: resolution: {integrity: sha512-28GZ24KmMSeKi5ueWzMcco6EBHStL3B6ubM7M51RmPwXQGLe0teBGJocmWhgwccA1GeFXqxzILIxXpHbl9Q/Kw==} engines: {node: '>=12'} cpu: [x64] @@ -11976,7 +12849,7 @@ packages: dev: false optional: true - /esbuild-windows-32/0.14.54: + /esbuild-windows-32@0.14.54: resolution: {integrity: sha512-T+rdZW19ql9MjS7pixmZYVObd9G7kcaZo+sETqNH4RCkuuYSuv9AGHUVnPoP9hhuE1WM1ZimHz1CIBHBboLU7w==} engines: {node: '>=12'} cpu: [ia32] @@ -11985,7 +12858,7 @@ packages: dev: false optional: true - /esbuild-windows-64/0.14.54: + /esbuild-windows-64@0.14.54: resolution: {integrity: sha512-AoHTRBUuYwXtZhjXZbA1pGfTo8cJo3vZIcWGLiUcTNgHpJJMC1rVA44ZereBHMJtotyN71S8Qw0npiCIkW96cQ==} engines: {node: '>=12'} cpu: [x64] @@ -11994,7 +12867,7 @@ packages: dev: false optional: true - /esbuild-windows-arm64/0.14.54: + /esbuild-windows-arm64@0.14.54: resolution: {integrity: sha512-M0kuUvXhot1zOISQGXwWn6YtS+Y/1RT9WrVIOywZnJHo3jCDyewAc79aKNQWFCQm+xNHVTq9h8dZKvygoXQQRg==} engines: {node: '>=12'} cpu: [arm64] @@ -12003,7 +12876,7 @@ packages: dev: false optional: true - /esbuild/0.14.54: + /esbuild@0.14.54: resolution: {integrity: sha512-Cy9llcy8DvET5uznocPyqL3BFRrFXSVqbgpMJ9Wz8oVjZlh/zUSNbPRbov0VX7VxN2JH1Oa0uNxZ7eLRb62pJA==} engines: {node: '>=12'} hasBin: true @@ -12032,7 +12905,7 @@ packages: esbuild-windows-arm64: 0.14.54 dev: false - /esbuild/0.17.19: + /esbuild@0.17.19: resolution: {integrity: sha512-XQ0jAPFkK/u3LcVRcvVHQcTIqD6E2H1fvZMA5dQPSOWb3suUbWbfbRf94pjc0bNzRYLfIrDRQXr7X+LHIm5oHw==} engines: {node: '>=12'} hasBin: true @@ -12062,7 +12935,7 @@ packages: '@esbuild/win32-x64': 0.17.19 dev: true - /esbuild/0.18.11: + /esbuild@0.18.11: resolution: {integrity: sha512-i8u6mQF0JKJUlGR3OdFLKldJQMMs8OqM9Cc3UCi9XXziJ9WERM5bfkHaEAy0YAvPRMgqSW55W7xYn84XtEFTtA==} engines: {node: '>=12'} hasBin: true @@ -12091,33 +12964,33 @@ packages: '@esbuild/win32-ia32': 0.18.11 '@esbuild/win32-x64': 0.18.11 - /escalade/3.1.1: + /escalade@3.1.1: resolution: {integrity: sha512-k0er2gUkLf8O0zKJiAhmkTnJlTvINGv7ygDNPbeIsX/TJjGJZHuh9B2UxbsaEkmlEo9MfhrSzmhIlhRlI2GXnw==} engines: {node: '>=6'} - /escape-html/1.0.3: + /escape-html@1.0.3: resolution: {integrity: sha512-NiSupZ4OeuGwr68lGIeym/ksIZMJodUGOSCZ/FSnTxcrekbvqrgdUxlJOMpijaKZVjAJrWrGs/6Jy8OMuyj9ow==} dev: true - /escape-string-regexp/1.0.5: + /escape-string-regexp@1.0.5: resolution: {integrity: sha512-vbRorB5FUQWvla16U8R/qgaFIya2qGzwDrNmCZuYKrbdSUMG6I1ZCGQRefkRVhuOkIGVne7BQ35DSfo1qvJqFg==} engines: {node: '>=0.8.0'} - /escape-string-regexp/2.0.0: + /escape-string-regexp@2.0.0: resolution: {integrity: sha512-UpzcLCXolUWcNu5HtVMHYdXJjArjsF9C0aNnquZYY4uW/Vu0miy5YoWvbV345HauVvcAUnpRuhMMcqTcGOY2+w==} engines: {node: '>=8'} dev: true - /escape-string-regexp/4.0.0: + /escape-string-regexp@4.0.0: resolution: {integrity: sha512-TtpcNJ3XAzx3Gq8sWRzJaVajRs0uVxA2YAkdb1jm2YkPz4G6egUFAyA3n5vtEIZefPk5Wa4UXbKuS5fKkJWdgA==} engines: {node: '>=10'} - /escape-string-regexp/5.0.0: + /escape-string-regexp@5.0.0: resolution: {integrity: sha512-/veY75JbMK4j1yjvuUxuVsiS/hr/4iHs9FTT6cgTexxdE0Ly/glccBAkloH/DofkjRbZU3bnoj38mOmhkZ0lHw==} engines: {node: '>=12'} dev: true - /escodegen/2.1.0: + /escodegen@2.1.0: resolution: {integrity: sha512-2NlIDTwUWJN0mRPQOdtQBzbUHvdGY2P1VXSyU83Q3xKxM7WHX2Ql8dKq782Q9TgQUNOLEzEYu9bzLNj1q88I5w==} engines: {node: '>=6.0'} hasBin: true @@ -12129,17 +13002,17 @@ packages: source-map: 0.6.1 dev: true - /eslint-import-resolver-node/0.3.7: + /eslint-import-resolver-node@0.3.7: resolution: {integrity: sha512-gozW2blMLJCeFpBwugLTGyvVjNoeo1knonXAcatC6bjPBZitotxdWf7Gimr25N4c0AAOo4eOUfaG82IJPDpqCA==} dependencies: - debug: 3.2.7 + debug: 3.2.7(supports-color@8.1.1) is-core-module: 2.12.1 - resolve: 1.22.3 + resolve: 1.22.2 transitivePeerDependencies: - supports-color dev: true - /eslint-module-utils/2.8.0_obwxlbvpmtyn54zwezzu2ooh6u: + /eslint-module-utils@2.8.0(@typescript-eslint/parser@5.62.0)(eslint-import-resolver-node@0.3.7)(eslint@8.44.0): resolution: {integrity: sha512-aWajIYfsqCKRDgUfjEXNN/JlrzauMuSEy5sbd7WXbtW3EH6A6MpwEh42c7qD+MqQo9QMJ6fWLAeIJynx0g6OAw==} engines: {node: '>=4'} peerDependencies: @@ -12160,36 +13033,36 @@ packages: eslint-import-resolver-webpack: optional: true dependencies: - '@typescript-eslint/parser': 5.62.0_iqf7tbmerllfqanu4l3d6aqdn4 - debug: 3.2.7 + '@typescript-eslint/parser': 5.62.0(eslint@8.44.0)(typescript@5.1.6) + debug: 3.2.7(supports-color@8.1.1) eslint: 8.44.0 eslint-import-resolver-node: 0.3.7 transitivePeerDependencies: - supports-color dev: true - /eslint-plugin-antfu/0.39.7_iqf7tbmerllfqanu4l3d6aqdn4: + /eslint-plugin-antfu@0.39.7(eslint@8.44.0)(typescript@5.1.6): resolution: {integrity: sha512-z+xqVTnneKogHuJLTSmIbFb8Ll0TVGeghufz56hAVa6JCKOsVpvqOkVjJDZ+R/JGnzqvA+GTBh1fugxlspq3Rw==} dependencies: - '@typescript-eslint/utils': 5.62.0_iqf7tbmerllfqanu4l3d6aqdn4 + '@typescript-eslint/utils': 5.62.0(eslint@8.44.0)(typescript@5.1.6) transitivePeerDependencies: - eslint - supports-color - typescript dev: true - /eslint-plugin-es-x/7.1.0_eslint@8.44.0: + /eslint-plugin-es-x@7.1.0(eslint@8.44.0): resolution: {integrity: sha512-AhiaF31syh4CCQ+C5ccJA0VG6+kJK8+5mXKKE7Qs1xcPRg02CDPOj3mWlQxuWS/AYtg7kxrDNgW9YW3vc0Q+Mw==} engines: {node: ^14.18.0 || >=16.0.0} peerDependencies: eslint: '>=8' dependencies: - '@eslint-community/eslint-utils': 4.4.0_eslint@8.44.0 + '@eslint-community/eslint-utils': 4.4.0(eslint@8.44.0) '@eslint-community/regexpp': 4.5.1 eslint: 8.44.0 dev: true - /eslint-plugin-eslint-comments/3.2.0_eslint@8.44.0: + /eslint-plugin-eslint-comments@3.2.0(eslint@8.44.0): resolution: {integrity: sha512-0jkOl0hfojIHHmEHgmNdqv4fmh7300NdpA9FFpF7zaoLvB/QeXOGNLIo86oAveJFrfB1p05kC8hpEMHM8DwWVQ==} engines: {node: '>=6.5.0'} peerDependencies: @@ -12200,13 +13073,13 @@ packages: ignore: 5.2.4 dev: true - /eslint-plugin-html/7.1.0: + /eslint-plugin-html@7.1.0: resolution: {integrity: sha512-fNLRraV/e6j8e3XYOC9xgND4j+U7b1Rq+OygMlLcMg+wI/IpVbF+ubQa3R78EjKB9njT6TQOlcK5rFKBVVtdfg==} dependencies: htmlparser2: 8.0.2 dev: true - /eslint-plugin-i/2.27.5-3_owyyv4y74swggqrdagvp7hd7n4: + /eslint-plugin-i@2.27.5-3(@typescript-eslint/parser@5.62.0)(eslint@8.44.0): resolution: {integrity: sha512-fxJkCgJmJ1j/4fQwoonVtXT9nwF/MZ5GTUm9bzFvJQIauJgkkaPblqiMox+2pFjXN+2F7xUeq+UzCDJGBJ+vOA==} engines: {node: '>=4'} peerDependencies: @@ -12215,11 +13088,11 @@ packages: array-includes: 3.1.6 array.prototype.flat: 1.3.1 array.prototype.flatmap: 1.3.1 - debug: 3.2.7 + debug: 3.2.7(supports-color@8.1.1) doctrine: 2.1.0 eslint: 8.44.0 eslint-import-resolver-node: 0.3.7 - eslint-module-utils: 2.8.0_obwxlbvpmtyn54zwezzu2ooh6u + eslint-module-utils: 2.8.0(@typescript-eslint/parser@5.62.0)(eslint-import-resolver-node@0.3.7)(eslint@8.44.0) get-tsconfig: 4.6.2 has: 1.0.3 is-core-module: 2.12.1 @@ -12235,7 +13108,7 @@ packages: - supports-color dev: true - /eslint-plugin-jest/27.2.2_qtrczavcy63fstz24hwardykcu: + /eslint-plugin-jest@27.2.2(@typescript-eslint/eslint-plugin@5.62.0)(eslint@8.44.0)(typescript@5.1.6): resolution: {integrity: sha512-euzbp06F934Z7UDl5ZUaRPLAc9MKjh0rMPERrHT7UhlCEwgb25kBj37TvMgWeHZVkR5I9CayswrpoaqZU1RImw==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} peerDependencies: @@ -12248,27 +13121,27 @@ packages: jest: optional: true dependencies: - '@typescript-eslint/eslint-plugin': 5.62.0_l3h7p4bxv72z3fumgmc6kvfciu - '@typescript-eslint/utils': 5.62.0_iqf7tbmerllfqanu4l3d6aqdn4 + '@typescript-eslint/eslint-plugin': 5.62.0(@typescript-eslint/parser@5.62.0)(eslint@8.44.0)(typescript@5.1.6) + '@typescript-eslint/utils': 5.62.0(eslint@8.44.0)(typescript@5.1.6) eslint: 8.44.0 transitivePeerDependencies: - supports-color - typescript dev: true - /eslint-plugin-jsonc/2.9.0_eslint@8.44.0: + /eslint-plugin-jsonc@2.9.0(eslint@8.44.0): resolution: {integrity: sha512-RK+LeONVukbLwT2+t7/OY54NJRccTXh/QbnXzPuTLpFMVZhPuq1C9E07+qWenGx7rrQl0kAalAWl7EmB+RjpGA==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: eslint: '>=6.0.0' dependencies: - '@eslint-community/eslint-utils': 4.4.0_eslint@8.44.0 + '@eslint-community/eslint-utils': 4.4.0(eslint@8.44.0) eslint: 8.44.0 jsonc-eslint-parser: 2.3.0 natural-compare: 1.4.0 dev: true - /eslint-plugin-markdown/3.0.0_eslint@8.44.0: + /eslint-plugin-markdown@3.0.0(eslint@8.44.0): resolution: {integrity: sha512-hRs5RUJGbeHDLfS7ELanT0e29Ocyssf/7kBM+p7KluY5AwngGkDf8Oyu4658/NZSGTTq05FZeWbkxXtbVyHPwg==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: @@ -12280,16 +13153,16 @@ packages: - supports-color dev: true - /eslint-plugin-n/16.0.1_eslint@8.44.0: + /eslint-plugin-n@16.0.1(eslint@8.44.0): resolution: {integrity: sha512-CDmHegJN0OF3L5cz5tATH84RPQm9kG+Yx39wIqIwPR2C0uhBGMWfbbOtetR83PQjjidA5aXMu+LEFw1jaSwvTA==} engines: {node: '>=16.0.0'} peerDependencies: eslint: '>=7.0.0' dependencies: - '@eslint-community/eslint-utils': 4.4.0_eslint@8.44.0 + '@eslint-community/eslint-utils': 4.4.0(eslint@8.44.0) builtins: 5.0.1 eslint: 8.44.0 - eslint-plugin-es-x: 7.1.0_eslint@8.44.0 + eslint-plugin-es-x: 7.1.0(eslint@8.44.0) ignore: 5.2.4 is-core-module: 2.12.1 minimatch: 3.1.2 @@ -12297,12 +13170,12 @@ packages: semver: 7.5.4 dev: true - /eslint-plugin-no-only-tests/3.1.0: + /eslint-plugin-no-only-tests@3.1.0: resolution: {integrity: sha512-Lf4YW/bL6Un1R6A76pRZyE1dl1vr31G/ev8UzIc/geCgFWyrKil8hVjYqWVKGB/UIGmb6Slzs9T0wNezdSVegw==} engines: {node: '>=5.0.0'} dev: true - /eslint-plugin-promise/6.1.1_eslint@8.44.0: + /eslint-plugin-promise@6.1.1(eslint@8.44.0): resolution: {integrity: sha512-tjqWDwVZQo7UIPMeDReOpUgHCmCiH+ePnVT+5zVapL0uuHnegBUs2smM13CzOs2Xb5+MHMRFTs9v24yjba4Oig==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: @@ -12311,14 +13184,14 @@ packages: eslint: 8.44.0 dev: true - /eslint-plugin-unicorn/47.0.0_eslint@8.44.0: + /eslint-plugin-unicorn@47.0.0(eslint@8.44.0): resolution: {integrity: sha512-ivB3bKk7fDIeWOUmmMm9o3Ax9zbMz1Bsza/R2qm46ufw4T6VBFBaJIR1uN3pCKSmSXm8/9Nri8V+iUut1NhQGA==} engines: {node: '>=16'} peerDependencies: eslint: '>=8.38.0' dependencies: '@babel/helper-validator-identifier': 7.22.5 - '@eslint-community/eslint-utils': 4.4.0_eslint@8.44.0 + '@eslint-community/eslint-utils': 4.4.0(eslint@8.44.0) ci-info: 3.8.0 clean-regexp: 1.0.0 eslint: 8.44.0 @@ -12336,7 +13209,7 @@ packages: strip-indent: 3.0.0 dev: true - /eslint-plugin-unused-imports/2.0.0_fjgzgq23hjlrbj45h2rdrfisla: + /eslint-plugin-unused-imports@2.0.0(@typescript-eslint/eslint-plugin@5.62.0)(eslint@8.44.0): resolution: {integrity: sha512-3APeS/tQlTrFa167ThtP0Zm0vctjr4M44HMpeg1P4bK6wItarumq0Ma82xorMKdFsWpphQBlRPzw/pxiVELX1A==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: @@ -12346,36 +13219,36 @@ packages: '@typescript-eslint/eslint-plugin': optional: true dependencies: - '@typescript-eslint/eslint-plugin': 5.62.0_l3h7p4bxv72z3fumgmc6kvfciu + '@typescript-eslint/eslint-plugin': 5.62.0(@typescript-eslint/parser@5.62.0)(eslint@8.44.0)(typescript@5.1.6) eslint: 8.44.0 eslint-rule-composer: 0.3.0 dev: true - /eslint-plugin-vue/9.15.1_eslint@8.44.0: + /eslint-plugin-vue@9.15.1(eslint@8.44.0): resolution: {integrity: sha512-CJE/oZOslvmAR9hf8SClTdQ9JLweghT6JCBQNrT2Iel1uVw0W0OLJxzvPd6CxmABKCvLrtyDnqGV37O7KQv6+A==} engines: {node: ^14.17.0 || >=16.0.0} peerDependencies: eslint: ^6.2.0 || ^7.0.0 || ^8.0.0 dependencies: - '@eslint-community/eslint-utils': 4.4.0_eslint@8.44.0 + '@eslint-community/eslint-utils': 4.4.0(eslint@8.44.0) eslint: 8.44.0 natural-compare: 1.4.0 nth-check: 2.1.1 postcss-selector-parser: 6.0.13 semver: 7.5.4 - vue-eslint-parser: 9.3.1_eslint@8.44.0 + vue-eslint-parser: 9.3.1(eslint@8.44.0) xml-name-validator: 4.0.0 transitivePeerDependencies: - supports-color dev: true - /eslint-plugin-yml/1.8.0_eslint@8.44.0: + /eslint-plugin-yml@1.8.0(eslint@8.44.0): resolution: {integrity: sha512-fgBiJvXD0P2IN7SARDJ2J7mx8t0bLdG6Zcig4ufOqW5hOvSiFxeUyc2g5I1uIm8AExbo26NNYCcTGZT0MXTsyg==} engines: {node: ^14.17.0 || >=16.0.0} peerDependencies: eslint: '>=6.0.0' dependencies: - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) eslint: 8.44.0 lodash: 4.17.21 natural-compare: 1.4.0 @@ -12384,12 +13257,12 @@ packages: - supports-color dev: true - /eslint-rule-composer/0.3.0: + /eslint-rule-composer@0.3.0: resolution: {integrity: sha512-bt+Sh8CtDmn2OajxvNO+BX7Wn4CIWMpTRm3MaiKPCQcnnlm0CS2mhui6QaoeQugs+3Kj2ESKEEGJUdVafwhiCg==} engines: {node: '>=4.0.0'} dev: true - /eslint-scope/4.0.3: + /eslint-scope@4.0.3: resolution: {integrity: sha512-p7VutNr1O/QrxysMo3E45FjYDTeXBy0iTltPFNSqKAIfjDSXC+4dj+qfyuD8bfAXrW/y6lW3O76VaYNPKfpKrg==} engines: {node: '>=4.0.0'} dependencies: @@ -12397,7 +13270,7 @@ packages: estraverse: 4.3.0 dev: true - /eslint-scope/5.1.1: + /eslint-scope@5.1.1: resolution: {integrity: sha512-2NxwbF/hZ0KpepYN0cNbo+FN6XoK7GaHlQhgx/hIZl6Va0bF45RQOOwhLIy8lQDbuCiadSLCBnH2CFYquit5bw==} engines: {node: '>=8.0.0'} dependencies: @@ -12405,7 +13278,7 @@ packages: estraverse: 4.3.0 dev: true - /eslint-scope/7.2.0: + /eslint-scope@7.2.0: resolution: {integrity: sha512-DYj5deGlHBfMt15J7rdtyKNq/Nqlv5KfU4iodrQ019XESsRnwXH9KAE0y3cwtUHDo2ob7CypAnCqefh6vioWRw==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dependencies: @@ -12413,7 +13286,7 @@ packages: estraverse: 5.3.0 dev: true - /eslint-utils/3.0.0_eslint@8.4.1: + /eslint-utils@3.0.0(eslint@8.4.1): resolution: {integrity: sha512-uuQC43IGctw68pJA1RgbQS8/NP7rch6Cwd4j3ZBtgo4/8Flj4eGE7ZYSZRN3iq5pVUv6GPdW5Z1RFleo84uLDA==} engines: {node: ^10.0.0 || ^12.0.0 || >= 14.0.0} peerDependencies: @@ -12423,17 +13296,17 @@ packages: eslint-visitor-keys: 2.1.0 dev: true - /eslint-visitor-keys/2.1.0: + /eslint-visitor-keys@2.1.0: resolution: {integrity: sha512-0rSmRBzXgDzIsD6mGdJgevzgezI534Cer5L/vyMX0kHzT/jiB43jRhd9YUlMGYLQy2zprNmoT8qasCGtY+QaKw==} engines: {node: '>=10'} dev: true - /eslint-visitor-keys/3.4.1: + /eslint-visitor-keys@3.4.1: resolution: {integrity: sha512-pZnmmLwYzf+kWaM/Qgrvpen51upAktaaiI01nsJD/Yr3lMOdNtq0cxkrrg16w64VtisN6okbs7Q8AfGqj4c9fA==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dev: true - /eslint/8.4.1: + /eslint@8.4.1: resolution: {integrity: sha512-TxU/p7LB1KxQ6+7aztTnO7K0i+h0tDi81YRY9VzB6Id71kNz+fFYnf5HD5UOQmxkzcoa0TlVZf9dpMtUv0GpWg==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} hasBin: true @@ -12443,12 +13316,12 @@ packages: ajv: 6.12.6 chalk: 4.1.2 cross-spawn: 7.0.3 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) doctrine: 3.0.0 enquirer: 2.3.6 escape-string-regexp: 4.0.0 eslint-scope: 7.2.0 - eslint-utils: 3.0.0_eslint@8.4.1 + eslint-utils: 3.0.0(eslint@8.4.1) eslint-visitor-keys: 3.4.1 espree: 9.2.0 esquery: 1.5.0 @@ -12480,12 +13353,12 @@ packages: - supports-color dev: true - /eslint/8.44.0: + /eslint@8.44.0: resolution: {integrity: sha512-0wpHoUbDUHgNCyvFB5aXLiQVfK9B0at6gUvzy83k4kAsQ/u769TQDX6iKC+aO4upIHO9WSaA3QoXYQDHbNwf1A==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} hasBin: true dependencies: - '@eslint-community/eslint-utils': 4.4.0_eslint@8.44.0 + '@eslint-community/eslint-utils': 4.4.0(eslint@8.44.0) '@eslint-community/regexpp': 4.5.1 '@eslint/eslintrc': 2.1.0 '@eslint/js': 8.44.0 @@ -12495,7 +13368,7 @@ packages: ajv: 6.12.6 chalk: 4.1.2 cross-spawn: 7.0.3 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) doctrine: 3.0.0 escape-string-regexp: 4.0.0 eslint-scope: 7.2.0 @@ -12528,73 +13401,73 @@ packages: - supports-color dev: true - /esm-env/1.0.0: + /esm-env@1.0.0: resolution: {integrity: sha512-Cf6VksWPsTuW01vU9Mk/3vRue91Zevka5SjyNf3nEpokFRuqt/KjUQoGAwq9qMmhpLTHmXzSIrFRw8zxWzmFBA==} dev: true - /esno/0.16.3: + /esno@0.16.3: resolution: {integrity: sha512-6slSBEV1lMKcX13DBifvnDFpNno5WXhw4j/ff7RI0y51BZiDqEe5dNhhjhIQ3iCOQuzsm2MbVzmwqbN78BBhPg==} hasBin: true dependencies: tsx: 3.12.7 dev: true - /espree/9.2.0: + /espree@9.2.0: resolution: {integrity: sha512-oP3utRkynpZWF/F2x/HZJ+AGtnIclaR7z1pYPxy7NYM2fSO6LgK/Rkny8anRSPK/VwEA1eqm2squui0T7ZMOBg==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dependencies: acorn: 8.10.0 - acorn-jsx: 5.3.2_acorn@8.10.0 + acorn-jsx: 5.3.2(acorn@8.10.0) eslint-visitor-keys: 3.4.1 dev: true - /espree/9.6.0: + /espree@9.6.0: resolution: {integrity: sha512-1FH/IiruXZ84tpUlm0aCUEwMl2Ho5ilqVh0VvQXw+byAz/4SAciyHLlfmL5WYqsvD38oymdUwBss0LtK8m4s/A==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dependencies: acorn: 8.10.0 - acorn-jsx: 5.3.2_acorn@8.10.0 + acorn-jsx: 5.3.2(acorn@8.10.0) eslint-visitor-keys: 3.4.1 dev: true - /esprima-extract-comments/1.1.0: + /esprima-extract-comments@1.1.0: resolution: {integrity: sha512-sBQUnvJwpeE9QnPrxh7dpI/dp67erYG4WXEAreAMoelPRpMR7NWb4YtwRPn9b+H1uLQKl/qS8WYmyaljTpjIsw==} engines: {node: '>=4'} dependencies: esprima: 4.0.1 dev: true - /esprima/4.0.1: + /esprima@4.0.1: resolution: {integrity: sha512-eGuFFw7Upda+g4p+QHvnW0RyTX/SVeJBDM/gCtMARO0cLuT2HcEKnTPvhjV6aGeqrCB/sbNop0Kszm0jsaWU4A==} engines: {node: '>=4'} hasBin: true dev: true - /esquery/1.5.0: + /esquery@1.5.0: resolution: {integrity: sha512-YQLXUplAwJgCydQ78IMJywZCceoqk1oH01OERdSAJc/7U2AylwjhSCLDEtqwg811idIS/9fIU5GjG73IgjKMVg==} engines: {node: '>=0.10'} dependencies: estraverse: 5.3.0 dev: true - /esrecurse/4.3.0: + /esrecurse@4.3.0: resolution: {integrity: sha512-KmfKL3b6G+RXvP8N1vr3Tq1kL/oCFgn2NYXEtqP8/L3pKapUA4G8cFVaoF3SU323CD4XypR/ffioHmkti6/Tag==} engines: {node: '>=4.0'} dependencies: estraverse: 5.3.0 dev: true - /estraverse/4.3.0: + /estraverse@4.3.0: resolution: {integrity: sha512-39nnKffWz8xN1BU/2c79n9nB9HDzo0niYUqx6xyqUnyoAnQyyWpOTdZEeiCch8BBu515t4wp9ZmgVfVhn9EBpw==} engines: {node: '>=4.0'} dev: true - /estraverse/5.3.0: + /estraverse@5.3.0: resolution: {integrity: sha512-MMdARuVEQziNTeJD8DgMqmhwR11BRQ/cBP+pLtYdSTnf3MIO8fFeiINEbX36ZdNlfU/7A9f3gUw49B3oQsvwBA==} engines: {node: '>=4.0'} dev: true - /estree-to-babel/3.2.1: + /estree-to-babel@3.2.1: resolution: {integrity: sha512-YNF+mZ/Wu2FU/gvmzuWtYc8rloubL7wfXCTgouFrnjGVXPA/EeYYA7pupXWrb3Iv1cTBeSSxxJIbK23l4MRNqg==} engines: {node: '>=8.3.0'} dependencies: @@ -12605,61 +13478,61 @@ packages: - supports-color dev: true - /estree-walker/1.0.1: + /estree-walker@1.0.1: resolution: {integrity: sha512-1fMXF3YP4pZZVozF8j/ZLfvnR8NSIljt56UhbZ5PeeDmmGHpgpdwQt7ITlGvYaQukCvuBRMLEiKiYC+oeIg4cg==} - /estree-walker/2.0.2: + /estree-walker@2.0.2: resolution: {integrity: sha512-Rfkk/Mp/DL7JVje3u18FxFujQlTNR2q6QfMSMB7AvCBx91NGj/ba3kCfza0f6dVDbw7YlRf/nDrn7pQrCCyQ/w==} - /estree-walker/3.0.3: + /estree-walker@3.0.3: resolution: {integrity: sha512-7RUKfXgSMMkzt6ZuXmqapOurLGPPfgj6l9uRZ7lRGolvk0y2yocc35LdcxKC5PQZdn2DMqioAQ2NoWcrTKmm6g==} dependencies: '@types/estree': 1.0.1 - /esutils/2.0.3: + /esutils@2.0.3: resolution: {integrity: sha512-kVscqXk4OCp68SZ0dkgEKVi6/8ij300KBWTJq32P/dYeWTSwK41WyTxalN1eRmA5Z9UU/LX9D7FWSmV9SAYx6g==} engines: {node: '>=0.10.0'} dev: true - /etag/1.8.1: + /etag@1.8.1: resolution: {integrity: sha512-aIL5Fx7mawVa300al2BnEE4iNvo1qETxLrPI/o05L7z6go7fCw1J6EQmbK4FmJ2AS7kgVF/KEZWufBfdClMcPg==} engines: {node: '>= 0.6'} dev: true - /event-target-polyfill/0.0.3: + /event-target-polyfill@0.0.3: resolution: {integrity: sha512-ZMc6UuvmbinrCk4RzGyVmRyIsAyxMRlp4CqSrcQRO8Dy0A9ldbiRy5kdtBj4OtP7EClGdqGfIqo9JmOClMsGLQ==} dev: true - /event-target-shim/5.0.1: + /event-target-shim@5.0.1: resolution: {integrity: sha512-i/2XbnSz/uxRCU6+NdVJgKWDTM427+MqYbkQzD321DuCQJUqOuJKIA0IM2+W2xtYHdKOmZ4dR6fExsd4SXL+WQ==} engines: {node: '>=6'} dev: true - /eventemitter2/6.4.7: + /eventemitter2@6.4.7: resolution: {integrity: sha512-tYUSVOGeQPKt/eC1ABfhHy5Xd96N3oIijJvN3O9+TsC28T5V9yX9oEfEK5faP0EFSNVOG97qtAS68GBrQB2hDg==} dev: true - /eventemitter3/4.0.7: + /eventemitter3@4.0.7: resolution: {integrity: sha512-8guHBZCwKnFhYdHr2ysuRWErTwhoN2X8XELRlrRwpmfeY2jjuUN4taQMsULKUVo1K4DvZl+0pgfyoysHxvmvEw==} dev: false - /events/3.3.0: + /events@3.3.0: resolution: {integrity: sha512-mQw+2fkQbALzQ7V0MY0IqdnXNOeTtP4r0lN9z7AAawCXgqea7bDii20AYrIBrFd/Hx0M2Ocz6S111CaFkUcb0Q==} engines: {node: '>=0.8.x'} dev: true - /evp_bytestokey/1.0.3: + /evp_bytestokey@1.0.3: resolution: {integrity: sha512-/f2Go4TognH/KvCISP7OUsHn85hT9nUkxxA9BEWxFn+Oj9o8ZNLm/40hdlgSLyuOimsrTKLUMEorQexp/aPQeA==} dependencies: md5.js: 1.3.5 safe-buffer: 5.2.1 dev: true - /exec-sh/0.3.6: + /exec-sh@0.3.6: resolution: {integrity: sha512-nQn+hI3yp+oD0huYhKwvYI32+JFeq+XkNcD1GAo3Y/MjxsfVGmrrzrnzjWiNY6f+pUCP440fThsFh5gZrRAU/w==} dev: true - /execa/1.0.0: + /execa@1.0.0: resolution: {integrity: sha512-adbxcyWV46qiHyvSp50TKt05tB4tK3HcmF7/nxfAdhnox83seTDbwnaqKO4sXRy7roHAIFqJP/Rw/AuEbX61LA==} engines: {node: '>=6'} dependencies: @@ -12672,7 +13545,7 @@ packages: strip-eof: 1.0.0 dev: true - /execa/4.1.0: + /execa@4.1.0: resolution: {integrity: sha512-j5W0//W7f8UxAn8hXVnwG8tLwdiUy4FJLcSupCg6maBYZDpyBvTApK7KyuI4bKj8KOh1r2YH+6ucuYtJv1bTZA==} engines: {node: '>=10'} dependencies: @@ -12687,7 +13560,7 @@ packages: strip-final-newline: 2.0.0 dev: true - /execa/5.1.1: + /execa@5.1.1: resolution: {integrity: sha512-8uSpZZocAZRBAPIEINJj3Lo9HyGitllczc27Eh5YYojjMFMn8yHMDMaUHE2Jqfq05D/wucwI4JGURyXt1vchyg==} engines: {node: '>=10'} dependencies: @@ -12702,7 +13575,7 @@ packages: strip-final-newline: 2.0.0 dev: true - /execa/6.1.0: + /execa@6.1.0: resolution: {integrity: sha512-QVWlX2e50heYJcCPG0iWtf8r0xjEYfz/OYLGDYH+IyjWezzPNxz63qNFOu0l4YftGWuizFVZHHs8PrLU5p2IDA==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dependencies: @@ -12717,7 +13590,7 @@ packages: strip-final-newline: 3.0.0 dev: true - /execa/7.1.1: + /execa@7.1.1: resolution: {integrity: sha512-wH0eMf/UXckdUYnO21+HDztteVv05rq2GXksxT4fCGeHkBhw1DROXh40wcjMcRqDOWE7iPJ4n3M7e2+YFP+76Q==} engines: {node: ^14.18.0 || ^16.14.0 || >=18.0.0} dependencies: @@ -12732,14 +13605,19 @@ packages: strip-final-newline: 3.0.0 dev: true - /executable/4.1.1: + /executable@4.1.1: resolution: {integrity: sha512-8iA79xD3uAch729dUG8xaaBBFGaEa0wdD2VkYLFHwlqosEj/jT66AzcreRDSgV7ehnNLBW2WR5jIXwGKjVdTLg==} engines: {node: '>=4'} dependencies: pify: 2.3.0 dev: true - /expand-brackets/2.1.4: + /exit@0.1.2: + resolution: {integrity: sha512-Zk/eNKV2zbjpKzrsQ+n1G6poVbErQxJ0LBOJXaKZ1EViLzH+hrLu9cdXI4zw9dBQJslwBEpbQ2P1oS7nDxs6jQ==} + engines: {node: '>= 0.8.0'} + dev: true + + /expand-brackets@2.1.4: resolution: {integrity: sha512-w/ozOKR9Obk3qoWeY/WDi6MFta9AoMR+zud60mdnbniMcBxRuFJyDt2LdX/14A1UABeqk+Uk+LDfUpvoGKppZA==} engines: {node: '>=0.10.0'} dependencies: @@ -12754,17 +13632,27 @@ packages: - supports-color dev: true - /expand-template/2.0.3: + /expand-template@2.0.3: resolution: {integrity: sha512-XYfuKMvj4O35f/pOXLObndIRvyQ+/+6AhODh+OKWj9S9498pHHn/IMszH+gt0fBCRWMNfk1ZSp5x3AifmnI2vg==} engines: {node: '>=6'} dev: true - /expect-type/0.16.0: + /expect-type@0.16.0: resolution: {integrity: sha512-wCpFeVBiAPGiYkQZzaqvGuuBnNCHbtnowMOBpBGY8a27XbG8VAit3lklWph1r8VmgsH61mOZqI3NuGm8bZnUlw==} engines: {node: '>=12.0.0'} dev: true - /expect/29.6.1: + /expect@27.5.1: + resolution: {integrity: sha512-E1q5hSUG2AmYQwQJ041nvgpkODHQvB+RKlB4IYdru6uJsyFTRyZAP463M+1lINorwbqAmUggi6+WwkD8lCS/Dw==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@jest/types': 27.5.1 + jest-get-type: 27.5.1 + jest-matcher-utils: 27.5.1 + jest-message-util: 27.5.1 + dev: true + + /expect@29.6.1: resolution: {integrity: sha512-XEdDLonERCU1n9uR56/Stx9OqojaLAQtZf9PrCHH9Hl8YXiEIka3H4NXJ3NOIBmQJTg7+j7buh34PMHfJujc8g==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: @@ -12776,7 +13664,7 @@ packages: jest-util: 29.6.1 dev: true - /express/4.18.2: + /express@4.18.2: resolution: {integrity: sha512-5/PsL6iGPdfQ/lKM1UuielYgv3BUoJfz1aUwU9vHZ+J7gyvwdQXFEBIEIaxeGf0GIcreATNyBExtalisDbuMqQ==} engines: {node: '>= 0.10.0'} dependencies: @@ -12815,14 +13703,14 @@ packages: - supports-color dev: true - /extend-shallow/2.0.1: + /extend-shallow@2.0.1: resolution: {integrity: sha512-zCnTtlxNoAiDc3gqY2aYAWFx7XWWiasuF2K8Me5WbN8otHKTUKBwjPtNpRs/rbUZm7KxWAaNj7P1a/p52GbVug==} engines: {node: '>=0.10.0'} dependencies: is-extendable: 0.1.1 dev: true - /extend-shallow/3.0.2: + /extend-shallow@3.0.2: resolution: {integrity: sha512-BwY5b5Ql4+qZoefgMj2NUmx+tehVTH/Kf4k1ZEtOHNFcm2wSxMRo992l6X3TIgni2eZVTZ85xMOjF31fwZAj6Q==} engines: {node: '>=0.10.0'} dependencies: @@ -12830,11 +13718,11 @@ packages: is-extendable: 1.0.1 dev: true - /extend/3.0.2: + /extend@3.0.2: resolution: {integrity: sha512-fjquC59cD7CyW6urNXK0FBufkZcoiGG80wTuPujX590cB5Ttln20E2UB4S/WARVqhXffZl2LNgS+gQdPIIim/g==} dev: true - /external-editor/3.1.0: + /external-editor@3.1.0: resolution: {integrity: sha512-hMQ4CX1p1izmuLYyZqLMO/qGNw10wSv9QDCPfzXfyFrOaCSSoRfqE1Kf1s5an66J5JZC62NewG+mK49jOCtQew==} engines: {node: '>=4'} dependencies: @@ -12843,7 +13731,7 @@ packages: tmp: 0.0.33 dev: true - /extglob/2.0.4: + /extglob@2.0.4: resolution: {integrity: sha512-Nmb6QXkELsuBr24CJSkilo6UHHgbekK5UiZgfE6UHD3Eb27YC6oD+bhcT+tJ6cl8dmsgdQxnWlcry8ksBIBLpw==} engines: {node: '>=0.10.0'} dependencies: @@ -12859,7 +13747,7 @@ packages: - supports-color dev: true - /extract-comments/1.1.0: + /extract-comments@1.1.0: resolution: {integrity: sha512-dzbZV2AdSSVW/4E7Ti5hZdHWbA+Z80RJsJhr5uiL10oyjl/gy7/o+HI1HwK4/WSZhlq4SNKU3oUzXlM13Qx02Q==} engines: {node: '>=6'} dependencies: @@ -12867,26 +13755,12 @@ packages: parse-code-context: 1.0.0 dev: true - /extract-zip/2.0.1: - resolution: {integrity: sha512-GDhU9ntwuKyGXdZBUgTIe+vXnWj0fppUEtMDL0+idd5Sta8TGpHssn/eusA9mrPr9qNDym6SxAYZjNvCn/9RBg==} - engines: {node: '>= 10.17.0'} - hasBin: true - dependencies: - debug: 4.3.4 - get-stream: 5.2.0 - yauzl: 2.10.0 - optionalDependencies: - '@types/yauzl': 2.10.0 - transitivePeerDependencies: - - supports-color - dev: true - - /extract-zip/2.0.1_supports-color@8.1.1: + /extract-zip@2.0.1(supports-color@8.1.1): resolution: {integrity: sha512-GDhU9ntwuKyGXdZBUgTIe+vXnWj0fppUEtMDL0+idd5Sta8TGpHssn/eusA9mrPr9qNDym6SxAYZjNvCn/9RBg==} engines: {node: '>= 10.17.0'} hasBin: true dependencies: - debug: 4.3.4_supports-color@8.1.1 + debug: 4.3.4(supports-color@8.1.1) get-stream: 5.2.0 yauzl: 2.10.0 optionalDependencies: @@ -12895,33 +13769,33 @@ packages: - supports-color dev: true - /extsprintf/1.3.0: + /extsprintf@1.3.0: resolution: {integrity: sha512-11Ndz7Nv+mvAC1j0ktTa7fAb0vLyGGX+rMHNBYQviQDGU0Hw7lhctJANqbPhu9nV9/izT/IntTgZ7Im/9LJs9g==} engines: {'0': node >=0.6.0} dev: true - /fast-decode-uri-component/1.0.1: + /fast-decode-uri-component@1.0.1: resolution: {integrity: sha512-WKgKWg5eUxvRZGwW8FvfbaH7AXSh2cL+3j5fMGzUMCxWBJ3dV3a7Wz8y2f/uQ0e3B6WmodD3oS54jTQ9HVTIIg==} dev: true - /fast-deep-equal/2.0.1: + /fast-deep-equal@2.0.1: resolution: {integrity: sha512-bCK/2Z4zLidyB4ReuIsvALH6w31YfAQDmXMqMx6FyfHqvBxtjC0eRumeSu4Bs3XtXwpyIywtSTrVT99BxY1f9w==} dev: true - /fast-deep-equal/3.1.3: + /fast-deep-equal@3.1.3: resolution: {integrity: sha512-f3qQ9oQy9j2AhBe/H9VC91wLmKBCCU/gDOnKNAYG5hswO7BLKj09Hc5HYNz9cGI++xlpDCIgDaitVs03ATR84Q==} dev: true - /fast-equals/5.0.1: + /fast-equals@5.0.1: resolution: {integrity: sha512-WF1Wi8PwwSY7/6Kx0vKXtw8RwuSGoM1bvDaJbu7MxDlR1vovZjIAKrnzyrThgAjm6JDTu0fVgWXDlMGspodfoQ==} engines: {node: '>=6.0.0'} dev: false - /fast-fifo/1.3.0: + /fast-fifo@1.3.0: resolution: {integrity: sha512-IgfweLvEpwyA4WgiQe9Nx6VV2QkML2NkvZnk1oKnIzXgXdWxuhF7zw4DvLTPZJn6PIUneiAXPF24QmoEqHTjyw==} dev: true - /fast-glob/2.2.7: + /fast-glob@2.2.7: resolution: {integrity: sha512-g1KuQwHOZAmOZMuBtHdxDtju+T2RT8jgCC9aANsbpdiDDTSnjgfuVsIBNKbUeJI3oKMRExcfNDtJl4OhbffMsw==} engines: {node: '>=4.0.0'} dependencies: @@ -12935,7 +13809,7 @@ packages: - supports-color dev: true - /fast-glob/3.3.0: + /fast-glob@3.3.0: resolution: {integrity: sha512-ChDuvbOypPuNjO8yIDf36x7BlZX1smcUMTTcyoIjycexOxd6DFsKsg21qVBzEmr3G7fUKIRy2/psii+CIUt7FA==} engines: {node: '>=8.6.0'} dependencies: @@ -12945,49 +13819,49 @@ packages: merge2: 1.4.1 micromatch: 4.0.5 - /fast-json-parse/1.0.3: + /fast-json-parse@1.0.3: resolution: {integrity: sha512-FRWsaZRWEJ1ESVNbDWmsAlqDk96gPQezzLghafp5J4GUKjbCz3OkAHuZs5TuPEtkbVQERysLp9xv6c24fBm8Aw==} dev: true - /fast-json-stable-stringify/2.1.0: + /fast-json-stable-stringify@2.1.0: resolution: {integrity: sha512-lhd/wF+Lk98HZoTCtlVraHtfh5XYijIjalXck7saUtuanSDyLMxnHhSXEDJqHxD7msR8D0uCmqlkwjCV8xvwHw==} dev: true - /fast-json-stringify/5.7.0: + /fast-json-stringify@5.7.0: resolution: {integrity: sha512-sBVPTgnAZseLu1Qgj6lUbQ0HfjFhZWXAmpZ5AaSGkyLh5gAXBga/uPJjQPHpDFjC9adWIpdOcCLSDTgrZ7snoQ==} dependencies: '@fastify/deepmerge': 1.3.0 ajv: 8.12.0 - ajv-formats: 2.1.1 + ajv-formats: 2.1.1(ajv@8.12.0) fast-deep-equal: 3.1.3 fast-uri: 2.2.0 rfdc: 1.3.0 dev: true - /fast-levenshtein/2.0.6: + /fast-levenshtein@2.0.6: resolution: {integrity: sha512-DCXu6Ifhqcks7TZKY3Hxp3y6qphY5SJZmrWMDrKcERSOXWQdMhU9Ig/PYrzyw/ul9jOIyh0N4M0tbC5hodg8dw==} dev: true - /fast-querystring/1.1.2: + /fast-querystring@1.1.2: resolution: {integrity: sha512-g6KuKWmFXc0fID8WWH0jit4g0AGBoJhCkJMb1RmbsSEUNvQ+ZC8D6CUZ+GtF8nMzSPXnhiePyyqqipzNNEnHjg==} dependencies: fast-decode-uri-component: 1.0.1 dev: true - /fast-redact/3.2.0: + /fast-redact@3.2.0: resolution: {integrity: sha512-zaTadChr+NekyzallAMXATXLOR8MNx3zqpZ0MUF2aGf4EathnG0f32VLODNlY8IuGY3HoRO2L6/6fSzNsLaHIw==} engines: {node: '>=6'} dev: true - /fast-safe-stringify/2.1.1: + /fast-safe-stringify@2.1.1: resolution: {integrity: sha512-W+KJc2dmILlPplD/H4K9l9LcAHAfPtP6BY84uVLXQ6Evcz9Lcg33Y2z1IVblT6xdY54PXYVHEv+0Wpq8Io6zkA==} dev: true - /fast-uri/2.2.0: + /fast-uri@2.2.0: resolution: {integrity: sha512-cIusKBIt/R/oI6z/1nyfe2FvGKVTohVRfvkOhvx0nCEW+xf5NoCXjAHcWp93uOUBchzYcsvPlrapAdX1uW+YGg==} dev: true - /fastify/4.5.3: + /fastify@4.5.3: resolution: {integrity: sha512-Q8Zvkmg7GnioMCDX1jT2Q7iRqjywlnDZ1735D2Ipf7ashCM/3/bqPKv2Jo1ZF2iDExct2eP1C/tdhcj0GG/OuQ==} dependencies: '@fastify/ajv-compiler': 3.5.0 @@ -13008,43 +13882,43 @@ packages: - supports-color dev: true - /fastq/1.15.0: + /fastq@1.15.0: resolution: {integrity: sha512-wBrocU2LCXXa+lWBt8RoIRD89Fi8OdABODa/kEnyeyjS5aZO5/GNvI5sEINADqP/h8M29UHTHUb53sUu5Ihqdw==} dependencies: reusify: 1.0.4 - /fb-watchman/2.0.2: + /fb-watchman@2.0.2: resolution: {integrity: sha512-p5161BqbuCaSnB8jIbzQHOlpgsPmK5rJVDfDKO91Axs5NC1uu3HRQm6wt9cd9/+GtQQIO53JdGXXoyDpTAsgYA==} dependencies: bser: 2.1.1 dev: true - /fd-slicer/1.1.0: + /fd-slicer@1.1.0: resolution: {integrity: sha512-cE1qsB/VwyQozZ+q1dGxR8LBYNZeofhEdUNGSMbQD3Gw2lAzX9Zb3uIU6Ebc/Fmyjo9AWWfnn0AUCHqtevs/8g==} dependencies: pend: 1.2.0 dev: true - /fetch-retry/5.0.6: + /fetch-retry@5.0.6: resolution: {integrity: sha512-3yurQZ2hD9VISAhJJP9bpYFNQrHHBXE2JxxjY5aLEcDi46RmAzJE2OC9FAde0yis5ElW0jTTzs0zfg/Cca4XqQ==} dev: true - /fflate/0.8.0: + /fflate@0.8.0: resolution: {integrity: sha512-FAdS4qMuFjsJj6XHbBaZeXOgaypXp8iw/Tpyuq/w3XA41jjLHT8NPA+n7czH/DDhdncq0nAyDZmPeWXh2qmdIg==} dev: false - /figgy-pudding/3.5.2: + /figgy-pudding@3.5.2: resolution: {integrity: sha512-0btnI/H8f2pavGMN8w40mlSKOfTK2SVJmBfBeVIj3kNw0swwgzyRq0d5TJVOwodFmtvpPeWPN/MCcfuWF0Ezbw==} dev: true - /figures/3.2.0: + /figures@3.2.0: resolution: {integrity: sha512-yaduQFRKLXYOGgEn6AZau90j3ggSOyiqXU0F9JZfeXYhNa+Jk4X+s45A2zg5jns87GAFa34BBm2kXw4XpNcbdg==} engines: {node: '>=8'} dependencies: escape-string-regexp: 1.0.5 dev: true - /figures/5.0.0: + /figures@5.0.0: resolution: {integrity: sha512-ej8ksPF4x6e5wvK9yevct0UCXh8TTFlWGVLlgjZuoBH1HwjIfKE/IdL5mq89sFA7zELi1VhKpmtDnrs7zWyeyg==} engines: {node: '>=14'} dependencies: @@ -13052,14 +13926,14 @@ packages: is-unicode-supported: 1.3.0 dev: true - /file-entry-cache/6.0.1: + /file-entry-cache@6.0.1: resolution: {integrity: sha512-7Gps/XWymbLk2QLYK4NzpMOrYjMhdIxXuIvy2QBsLE6ljuodKvdkWs/cpyJJ3CVIVpH0Oi1Hvg1ovbMzLdFBBg==} engines: {node: ^10.12.0 || >=12.0.0} dependencies: flat-cache: 3.0.4 dev: true - /file-loader/6.2.0_webpack@4.46.0: + /file-loader@6.2.0(webpack@4.46.0): resolution: {integrity: sha512-qo3glqyTa61Ytg4u73GultjHGjdRyig3tG6lPtyX/jOEJvHif9uB0/OCI2Kif6ctF3caQTW2G5gym21oAsI4pw==} engines: {node: '>= 10.13.0'} peerDependencies: @@ -13070,32 +13944,32 @@ packages: webpack: 4.46.0 dev: true - /file-system-cache/1.1.0: + /file-system-cache@1.1.0: resolution: {integrity: sha512-IzF5MBq+5CR0jXx5RxPe4BICl/oEhBSXKaL9fLhAXrIfIUS77Hr4vzrYyqYMHN6uTt+BOqi3fDCTjjEBCjERKw==} dependencies: fs-extra: 10.1.0 ramda: 0.28.0 dev: true - /file-system-cache/2.3.0: + /file-system-cache@2.3.0: resolution: {integrity: sha512-l4DMNdsIPsVnKrgEXbJwDJsA5mB8rGwHYERMgqQx/xAUtChPJMre1bXBzDEqqVbWv9AIbFezXMxeEkZDSrXUOQ==} dependencies: fs-extra: 11.1.1 ramda: 0.29.0 dev: true - /file-uri-to-path/1.0.0: + /file-uri-to-path@1.0.0: resolution: {integrity: sha512-0Zt+s3L7Vf1biwWZ29aARiVYLx7iMGnEUl9x33fbB/j3jR81u/O2LbqK+Bm1CDSNDKVtJ/YjwY7TUd5SkeLQLw==} dev: true optional: true - /filelist/1.0.4: + /filelist@1.0.4: resolution: {integrity: sha512-w1cEuf3S+DrLCQL7ET6kz+gmlJdbq9J7yXCSjK/OZCPA+qEN1WyF4ZAf0YYJa4/shHJra2t/d/r8SV4Ji+x+8Q==} dependencies: minimatch: 5.1.6 dev: true - /fill-range/4.0.0: + /fill-range@4.0.0: resolution: {integrity: sha512-VcpLTWqWDiTerugjj8e3+esbg+skS3M9e54UuR3iCeIDMXCLTsAH8hTSzDQU/X6/6t3eYkOKoZSef2PlU6U1XQ==} engines: {node: '>=0.10.0'} dependencies: @@ -13105,13 +13979,13 @@ packages: to-regex-range: 2.1.1 dev: true - /fill-range/7.0.1: + /fill-range@7.0.1: resolution: {integrity: sha512-qOo9F+dMUmC2Lcb4BbVvnKJxTPjCm+RRpe4gDuGrzkL7mEVl/djYSu2OdQ2Pa302N4oqkSg9ir6jaLWJ2USVpQ==} engines: {node: '>=8'} dependencies: to-regex-range: 5.0.1 - /finalhandler/1.2.0: + /finalhandler@1.2.0: resolution: {integrity: sha512-5uXcUVftlQMFnWC9qu/svkWv3GTd2PfUhK/3PLkYNAe7FbqJMt3515HaxE6eRL74GdsriiwujiawdaB1BpEISg==} engines: {node: '>= 0.8'} dependencies: @@ -13126,7 +14000,7 @@ packages: - supports-color dev: true - /find-cache-dir/2.1.0: + /find-cache-dir@2.1.0: resolution: {integrity: sha512-Tq6PixE0w/VMFfCgbONnkiQIVol/JJL7nRMi20fqzA4NRs9AfeqMGeRdPi3wIhYkxjeBaWh2rxwapn5Tu3IqOQ==} engines: {node: '>=6'} dependencies: @@ -13135,7 +14009,7 @@ packages: pkg-dir: 3.0.0 dev: true - /find-cache-dir/3.3.2: + /find-cache-dir@3.3.2: resolution: {integrity: sha512-wXZV5emFEjrridIgED11OoUKLxiYjAcqot/NJdAkOhlJ+vGzwhOAfcG5OX1jP+S0PcjEn8bdMJv+g2jwQ3Onig==} engines: {node: '>=8'} dependencies: @@ -13144,7 +14018,7 @@ packages: pkg-dir: 4.2.0 dev: true - /find-my-way/7.6.2: + /find-my-way@7.6.2: resolution: {integrity: sha512-0OjHn1b1nCX3eVbm9ByeEHiscPYiHLfhei1wOUU9qffQkk98wE0Lo8VrVYfSGMgnSnDh86DxedduAnBf4nwUEw==} engines: {node: '>=14'} dependencies: @@ -13153,11 +14027,11 @@ packages: safe-regex2: 2.0.0 dev: true - /find-root/1.1.0: + /find-root@1.1.0: resolution: {integrity: sha512-NKfW6bec6GfKc0SGx1e07QZY9PE99u0Bft/0rzSD5k3sO/vwkVUpDUKVm5Gpp5Ue3YfShPFTX2070tDs5kB9Ng==} dev: false - /find-up/1.1.2: + /find-up@1.1.2: resolution: {integrity: sha512-jvElSjyuo4EMQGoTwo1uJU5pQMwTW5lS1x05zzfJuTIyLR3zwO27LYrxNg+dlvKpGOuGy/MzBdXh80g0ve5+HA==} engines: {node: '>=0.10.0'} dependencies: @@ -13166,14 +14040,14 @@ packages: dev: true optional: true - /find-up/3.0.0: + /find-up@3.0.0: resolution: {integrity: sha512-1yD6RmLI1XBfxugvORwlck6f75tYL+iR0jqwsOrOxMZyGYqUuDhJ0l4AXdO1iX/FTs9cBAMEk1gWSEx1kSbylg==} engines: {node: '>=6'} dependencies: locate-path: 3.0.0 dev: true - /find-up/4.1.0: + /find-up@4.1.0: resolution: {integrity: sha512-PpOwAdQ/YlXQ2vj8a3h8IipDuYRi3wceVQQGYWxNINccq40Anw7BlsEXCMbt1Zt+OLA6Fq9suIpIWD0OsnISlw==} engines: {node: '>=8'} dependencies: @@ -13181,7 +14055,7 @@ packages: path-exists: 4.0.0 dev: true - /find-up/5.0.0: + /find-up@5.0.0: resolution: {integrity: sha512-78/PXT1wlLLDgTzDs7sjq9hzz0vXD+zn+7wypEe4fXQxCmdmqfGsEPQxmiCSQI3ajFV91bVSsvNtrJRiW6nGng==} engines: {node: '>=10'} dependencies: @@ -13189,7 +14063,7 @@ packages: path-exists: 4.0.0 dev: true - /find-up/6.3.0: + /find-up@6.3.0: resolution: {integrity: sha512-v2ZsoEuVHYy8ZIlYqwPe/39Cy+cFDzp4dXPaxNvkEuouymu+2Jbz0PxpKarJHYJTmv2HWT3O382qY8l4jMWthw==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dependencies: @@ -13197,7 +14071,7 @@ packages: path-exists: 5.0.0 dev: true - /flat-cache/3.0.4: + /flat-cache@3.0.4: resolution: {integrity: sha512-dm9s5Pw7Jc0GvMYbshN6zchCA9RgQlzzEZX3vylR9IqFfS8XciblUXOKfW6SiuJ0e13eDYZoZV5wdrev7P3Nwg==} engines: {node: ^10.12.0 || >=12.0.0} dependencies: @@ -13205,38 +14079,38 @@ packages: rimraf: 3.0.2 dev: true - /flat/5.0.2: + /flat@5.0.2: resolution: {integrity: sha512-b6suED+5/3rTpUBdG1gupIl8MPFCAMA0QXwmljLhvCUKcUvdE4gWky9zpuGCcXHOsz4J9wPGNWq6OKpmIzz3hQ==} hasBin: true dev: true - /flatted/3.2.7: + /flatted@3.2.7: resolution: {integrity: sha512-5nqDSxl8nn5BSNxyR3n4I6eDmbolI6WT+QqR547RwxQapgjQBmtktdP+HTBb/a/zLsbzERTONyUB5pefh5TtjQ==} - /floating-vue/2.0.0-y.0_vue@3.3.4: + /floating-vue@2.0.0-y.0(vue@3.3.4): resolution: {integrity: sha512-UpJquQIlP0Z5978RYwGN3qsE6jhxxCt7ltzE1mV2m9GwsZ6y7IaIOAszWqALC+OqWhdPad/0GYxoQYGLC0y+Ow==} peerDependencies: vue: ^3.2.0 dependencies: '@floating-ui/dom': 0.1.10 vue: 3.3.4 - vue-resize: 2.0.0-alpha.1_vue@3.3.4 + vue-resize: 2.0.0-alpha.1(vue@3.3.4) dev: true - /flush-write-stream/1.1.1: + /flush-write-stream@1.1.1: resolution: {integrity: sha512-3Z4XhFZ3992uIq0XOqb9AreonueSYphE6oYbpt5+3u06JWklbsPkNv3ZKkP9Bz/r+1MWCaMoSQ28P85+1Yc77w==} dependencies: inherits: 2.0.4 readable-stream: 2.3.8 dev: true - /focus-trap/7.5.2: + /focus-trap@7.5.2: resolution: {integrity: sha512-p6vGNNWLDGwJCiEjkSK6oERj/hEyI9ITsSwIUICBoKLlWiTWXJRfQibCwcoi50rTZdbi87qDtUlMCmQwsGSgPw==} dependencies: tabbable: 6.2.0 dev: true - /follow-redirects/1.15.2: + /follow-redirects@1.15.2: resolution: {integrity: sha512-VQLG33o04KaQ8uYi2tVNbdrWp1QWxNNea+nmIB4EVM28v0hmP17z7aG1+wAkNzVq4KeXTq3221ye5qTJP91JwA==} engines: {node: '>=4.0'} peerDependencies: @@ -13245,18 +14119,18 @@ packages: debug: optional: true - /for-each/0.3.3: + /for-each@0.3.3: resolution: {integrity: sha512-jqYfLp7mo9vIyQf8ykW2v7A+2N4QjeCeI5+Dz9XraiO1ign81wjiH7Fb9vSOWvQfNtmSa4H2RoQTrrXivdUZmw==} dependencies: is-callable: 1.2.7 dev: true - /for-in/1.0.2: + /for-in@1.0.2: resolution: {integrity: sha512-7EwmXrOjyL+ChxMhmG5lnW9MPt1aIeZEwKhQzoBUdTV0N3zuwWDZYVJatDvZ2OyzPUvdIAZDsCetk3coyMfcnQ==} engines: {node: '>=0.10.0'} dev: true - /foreground-child/2.0.0: + /foreground-child@2.0.0: resolution: {integrity: sha512-dCIq9FpEcyQyXKCkyzmlPTFNgrCzPudOe+mhvJU5zAtlBnGVy2yKxtfsxK2tQBThwq225jcvBjpw1Gr40uzZCA==} engines: {node: '>=8.0.0'} dependencies: @@ -13264,7 +14138,7 @@ packages: signal-exit: 3.0.7 dev: true - /foreground-child/3.1.1: + /foreground-child@3.1.1: resolution: {integrity: sha512-TMKDUnIte6bfb5nWv7V/caI169OHgvwjb7V4WkeUvbQQdjr5rWKqHFiKWb/fcOwB+CzBT+qbWjvj+DVwRskpIg==} engines: {node: '>=14'} dependencies: @@ -13272,11 +14146,11 @@ packages: signal-exit: 4.0.2 dev: true - /forever-agent/0.6.1: + /forever-agent@0.6.1: resolution: {integrity: sha512-j0KLYPhm6zeac4lz3oJ3o65qvgQCcPubiyotZrXqEaG4hNagNYO8qdlUrX5vwqv9ohqeT/Z3j6+yW067yWWdUw==} dev: true - /fork-ts-checker-webpack-plugin/4.1.6_evijigonbo4skk2vlqtwtdqibu: + /fork-ts-checker-webpack-plugin@4.1.6(eslint@8.4.1)(typescript@4.9.5)(webpack@4.46.0): resolution: {integrity: sha512-DUxuQaKoqfNne8iikd14SAkh5uw4+8vNifp6gmA73yYNS6ywLIWSLD/n/mBzHQRpW3J7rbATEakmiA8JvkTyZw==} engines: {node: '>=6.11.5', yarn: '>=1.0.0'} peerDependencies: @@ -13292,6 +14166,7 @@ packages: dependencies: '@babel/code-frame': 7.22.5 chalk: 2.4.2 + eslint: 8.4.1 micromatch: 3.1.10 minimatch: 3.1.2 semver: 5.7.2 @@ -13303,7 +14178,7 @@ packages: - supports-color dev: true - /fork-ts-checker-webpack-plugin/6.5.3_evijigonbo4skk2vlqtwtdqibu: + /fork-ts-checker-webpack-plugin@6.5.3(eslint@8.4.1)(typescript@4.9.5)(webpack@4.46.0): resolution: {integrity: sha512-SbH/l9ikmMWycd5puHJKTkZJKddF4iRLyW3DeZ08HTI7NGyLS38MXd/KGgeWumQO7YNQbW2u/NtPT2YowbPaGQ==} engines: {node: '>=10', yarn: '>=1.0.0'} peerDependencies: @@ -13323,6 +14198,7 @@ packages: chokidar: 3.5.3 cosmiconfig: 6.0.0 deepmerge: 4.3.1 + eslint: 8.4.1 fs-extra: 9.1.0 glob: 7.2.3 memfs: 3.5.3 @@ -13334,12 +14210,12 @@ packages: webpack: 4.46.0 dev: true - /form-data-encoder/2.1.4: + /form-data-encoder@2.1.4: resolution: {integrity: sha512-yDYSgNMraqvnxiEXO4hi88+YZxaHC6QKzb5N84iRCTDeRO7ZALpir/lVmf/uXUhnwUr2O4HU8s/n6x+yNjQkHw==} engines: {node: '>= 14.17'} dev: true - /form-data/2.3.3: + /form-data@2.3.3: resolution: {integrity: sha512-1lLKB2Mu3aGP1Q/2eCOx0fNbRMe7XdwktwOruhfqqd0rIJWwN4Dh+E3hrPSlDCXnSR7UtZ1N38rVXm+6+MEhJQ==} engines: {node: '>= 0.12'} dependencies: @@ -13348,7 +14224,7 @@ packages: mime-types: 2.1.35 dev: true - /form-data/3.0.1: + /form-data@3.0.1: resolution: {integrity: sha512-RHkBKtLWUVwd7SqRIvCZMEvAMoGUp0XU+seQiZejj0COz3RI3hWP4sCv3gZWWLjJTd7rGwcsF5eKZGii0r/hbg==} engines: {node: '>= 6'} dependencies: @@ -13357,7 +14233,7 @@ packages: mime-types: 2.1.35 dev: true - /form-data/4.0.0: + /form-data@4.0.0: resolution: {integrity: sha512-ETEklSGi5t0QMZuiXoA/Q6vcnxcLQP5vdugSpuAyi6SVGi2clPPp+xgEhuMaHC+zGgn31Kd235W35f7Hykkaww==} engines: {node: '>= 6'} dependencies: @@ -13366,7 +14242,7 @@ packages: mime-types: 2.1.35 dev: true - /formidable/2.1.2: + /formidable@2.1.2: resolution: {integrity: sha512-CM3GuJ57US06mlpQ47YcunuUZ9jpm8Vx+P2CGt2j7HpgkKZO/DJYQ0Bobim8G6PFQmK5lOqOOdUXboU+h73A4g==} dependencies: dezalgo: 1.0.4 @@ -13375,35 +14251,35 @@ packages: qs: 6.11.2 dev: true - /forwarded/0.2.0: + /forwarded@0.2.0: resolution: {integrity: sha512-buRG0fpBtRHSTCOASe6hD258tEubFoRLb4ZNA6NxMVHNw2gOcwHo9wyablzMzOA5z9xA9L1KNjk/Nt6MT9aYow==} engines: {node: '>= 0.6'} dev: true - /fragment-cache/0.2.1: + /fragment-cache@0.2.1: resolution: {integrity: sha512-GMBAbW9antB8iZRHLoGw0b3HANt57diZYFO/HL1JGIC1MjKrdmhxvrJbupnVvpys0zsz7yBApXdQyfepKly2kA==} engines: {node: '>=0.10.0'} dependencies: map-cache: 0.2.2 dev: true - /fresh/0.5.2: + /fresh@0.5.2: resolution: {integrity: sha512-zJ2mQYM18rEFOudeV4GShTGIQ7RbzA7ozbU9I/XBpm7kqgMywgmylMwXHxZJmkVoYkna9d2pVXVXPdYTP9ej8Q==} engines: {node: '>= 0.6'} dev: true - /from2/2.3.0: + /from2@2.3.0: resolution: {integrity: sha512-OMcX/4IC/uqEPVgGeyfN22LJk6AZrMkRZHxcHBMBvHScDGgwTm2GT2Wkgtocyd3JfZffjj2kYUDXXII0Fk9W0g==} dependencies: inherits: 2.0.4 readable-stream: 2.3.8 dev: true - /fs-constants/1.0.0: + /fs-constants@1.0.0: resolution: {integrity: sha512-y6OAwoSIf7FyjMIv94u+b5rdheZEjzR63GTyZJm5qh4Bi+2YgwLCcI/fPFZkL5PSixOt6ZNKm+w+Hfp/Bciwow==} dev: true - /fs-extra/10.1.0: + /fs-extra@10.1.0: resolution: {integrity: sha512-oRXApq54ETRj4eMiFzGnHWGy+zo5raudjuxN0b8H7s/RU2oW0Wvsx9O0ACRN/kRq9E8Vu/ReskGB5o3ji+FzHQ==} engines: {node: '>=12'} dependencies: @@ -13412,7 +14288,7 @@ packages: universalify: 2.0.0 dev: true - /fs-extra/11.1.1: + /fs-extra@11.1.1: resolution: {integrity: sha512-MGIE4HOvQCeUCzmlHs0vXpih4ysz4wg9qiSAu6cd42lVwPbTM1TjV7RusoyQqMmk/95gdQZX72u+YW+c3eEpFQ==} engines: {node: '>=14.14'} dependencies: @@ -13421,7 +14297,7 @@ packages: universalify: 2.0.0 dev: true - /fs-extra/9.1.0: + /fs-extra@9.1.0: resolution: {integrity: sha512-hcg3ZmepS30/7BSFqRvoo3DOMQu7IjqxO5nCDt+zM9XWjb33Wg7ziNT+Qvqbuc3+gWpzO02JubVyk2G4Zvo1OQ==} engines: {node: '>=10'} dependencies: @@ -13431,18 +14307,18 @@ packages: universalify: 2.0.0 dev: true - /fs-minipass/2.1.0: + /fs-minipass@2.1.0: resolution: {integrity: sha512-V/JgOLFCS+R6Vcq0slCuaeWEdNC3ouDlJMNIsacH2VtALiu9mV4LPrHc5cDl8k5aw6J8jwgWWpiTo5RYhmIzvg==} engines: {node: '>= 8'} dependencies: minipass: 3.3.6 dev: true - /fs-monkey/1.0.4: + /fs-monkey@1.0.4: resolution: {integrity: sha512-INM/fWAxMICjttnD0DX1rBvinKskj5G1w+oy/pnm9u/tSlnBrzFonJMcalKJ30P8RRsPzKcCG7Q8l0jx5Fh9YQ==} dev: true - /fs-write-stream-atomic/1.0.10: + /fs-write-stream-atomic@1.0.10: resolution: {integrity: sha512-gehEzmPn2nAwr39eay+x3X34Ra+M2QlVUTLhkXPjWdeO8RF9kszk116avgBJM3ZyNHgHXBNx+VmPaFC36k0PzA==} dependencies: graceful-fs: 4.2.11 @@ -13451,10 +14327,10 @@ packages: readable-stream: 2.3.8 dev: true - /fs.realpath/1.0.0: + /fs.realpath@1.0.0: resolution: {integrity: sha512-OO0pH2lK6a0hZnAdau5ItzHPI6pUlvI7jMVnxUQRtw4owF2wk8lOSabtGDCTP4Ggrg2MbGnWO9X8K1t4+fGMDw==} - /fsevents/1.2.13: + /fsevents@1.2.13: resolution: {integrity: sha512-oWb1Z6mkHIskLzEJ/XWX0srkpkTQ7vaopMQkyaEIoq0fmtFVxOthb8cCxeT+p3ynTdkk/RZwbgG4brR5BeWECw==} engines: {node: '>= 4.0'} os: [darwin] @@ -13466,17 +14342,17 @@ packages: dev: true optional: true - /fsevents/2.3.2: + /fsevents@2.3.2: resolution: {integrity: sha512-xiqMQR4xAeHTuB9uWm+fFRcIOgKBMiOBP+eXiyT7jsgVCq1bkVygt00oASowB7EdtpOHaaPgKt812P9ab+DDKA==} engines: {node: ^8.16.0 || ^10.6.0 || >=11.0.0} os: [darwin] requiresBuild: true optional: true - /function-bind/1.1.1: + /function-bind@1.1.1: resolution: {integrity: sha512-yIovAzMX49sF8Yl58fSCWJ5svSLuaibPxXQJFLmBObTuCr0Mf1KiPopGM9NiFjiYBCbfaa2Fh6breQ6ANVTI0A==} - /function.prototype.name/1.1.5: + /function.prototype.name@1.1.5: resolution: {integrity: sha512-uN7m/BzVKQnCUF/iW8jYea67v++2u7m5UgENbHRtdDVclOUP+FMPlCNdmk0h/ysGyo2tavMJEDqJAkJdRa1vMA==} engines: {node: '>= 0.4'} dependencies: @@ -13486,15 +14362,15 @@ packages: functions-have-names: 1.2.3 dev: true - /functional-red-black-tree/1.0.1: + /functional-red-black-tree@1.0.1: resolution: {integrity: sha512-dsKNQNdj6xA3T+QlADDA7mOSlX0qiMINjn0cgr+eGHGsbSHzTabcIogz2+p/iqP1Xs6EP/sS2SbqH+brGTbq0g==} dev: true - /functions-have-names/1.2.3: + /functions-have-names@1.2.3: resolution: {integrity: sha512-xckBUXyTIqT97tq2x2AMb+g163b5JFysYk0x4qxNFwbfQkmNZoiRHb6sPzI9/QV33WeuvVYBUIiD4NzNIyqaRQ==} dev: true - /gauge/3.0.2: + /gauge@3.0.2: resolution: {integrity: sha512-+5J6MS/5XksCuXq++uFRsnUd7Ovu1XenbeuIuNRJxYWjgQbPuFhT14lAvsWfqfAmnwluf1OwMjz39HjfLPci0Q==} engines: {node: '>=10'} dependencies: @@ -13509,20 +14385,20 @@ packages: wide-align: 1.1.5 dev: true - /gensync/1.0.0-beta.2: + /gensync@1.0.0-beta.2: resolution: {integrity: sha512-3hN7NaskYvMDLQY55gnW3NQ+mesEAepTqlg+VEbj7zzqEMBVNhzcGYYeqFo/TlYz6eQiFcp1HcsCZO+nGgS8zg==} engines: {node: '>=6.9.0'} - /get-caller-file/2.0.5: + /get-caller-file@2.0.5: resolution: {integrity: sha512-DyFP3BM/3YHTQOCUL/w0OZHR0lpKeGrxotcHWcqNEdnltqFwXVfhEBQ94eIo34AfQpo0rGki4cyIiftY06h2Fg==} engines: {node: 6.* || 8.* || >= 10.*} dev: true - /get-func-name/2.0.0: + /get-func-name@2.0.0: resolution: {integrity: sha512-Hm0ixYtaSZ/V7C8FJrtZIuBBI+iSgL+1Aq82zSu8VQNB4S3Gk8e7Qs3VwBDJAhmRZcFqkl3tQu36g/Foh5I5ig==} dev: false - /get-intrinsic/1.2.1: + /get-intrinsic@1.2.1: resolution: {integrity: sha512-2DcsyfABl+gVHEfCOaTrWgyt+tb6MSEGmKq+kI5HwLbIYgjgmMcV8KQ41uaKz1xxUcn9tJtgFbQUEVcEbd0FYw==} dependencies: function-bind: 1.1.1 @@ -13531,46 +14407,46 @@ packages: has-symbols: 1.0.3 dev: true - /get-own-enumerable-property-symbols/3.0.2: + /get-own-enumerable-property-symbols@3.0.2: resolution: {integrity: sha512-I0UBV/XOz1XkIJHEUDMZAbzCThU/H8DxmSfmdGcKPnVhu2VfFqr34jr9777IyaTYvxjedWhqVIilEDsCdP5G6g==} dev: true - /get-package-type/0.1.0: + /get-package-type@0.1.0: resolution: {integrity: sha512-pjzuKtY64GYfWizNAJ0fr9VqttZkNiK2iS430LtIHzjBEr6bX8Am2zm4sW4Ro5wjWW5cAlRL1qAMTcXbjNAO2Q==} engines: {node: '>=8.0.0'} dev: true - /get-stdin/4.0.1: + /get-stdin@4.0.1: resolution: {integrity: sha512-F5aQMywwJ2n85s4hJPTT9RPxGmubonuB10MNYo17/xph174n2MIR33HRguhzVag10O/npM7SPk73LMZNP+FaWw==} engines: {node: '>=0.10.0'} dev: true optional: true - /get-stdin/5.0.1: + /get-stdin@5.0.1: resolution: {integrity: sha512-jZV7n6jGE3Gt7fgSTJoz91Ak5MuTLwMwkoYdjxuJ/AmjIsE1UC03y/IWkZCQGEvVNS9qoRNwy5BCqxImv0FVeA==} engines: {node: '>=0.12.0'} dev: true - /get-stream/4.1.0: + /get-stream@4.1.0: resolution: {integrity: sha512-GMat4EJ5161kIy2HevLlr4luNjBgvmj413KaQA7jt4V8B4RDsfpHk7WQ9GVqfYyyx8OS/L66Kox+rJRNklLK7w==} engines: {node: '>=6'} dependencies: pump: 3.0.0 dev: true - /get-stream/5.2.0: + /get-stream@5.2.0: resolution: {integrity: sha512-nBF+F1rAZVCu/p7rjzgA+Yb4lfYXrpl7a6VmJrU8wF9I1CKvP/QwPNZHnOlwbTkY6dvtFIzFMSyQXbLoTQPRpA==} engines: {node: '>=8'} dependencies: pump: 3.0.0 dev: true - /get-stream/6.0.1: + /get-stream@6.0.1: resolution: {integrity: sha512-ts6Wi+2j3jQjqi70w5AlN8DFnkSwC+MqmxEzdEALB2qXZYV3X/b1CTfgPLGJNMeAWxdPfU8FO1ms3NUfaHCPYg==} engines: {node: '>=10'} dev: true - /get-symbol-description/1.0.0: + /get-symbol-description@1.0.0: resolution: {integrity: sha512-2EmdH1YvIQiZpltCNgkuiUnyukzxM/R6NDJX31Ke3BG1Nq5b0S2PhX59UKi9vZpPDQVdqn+1IcaAwnzTT5vCjw==} engines: {node: '>= 0.4'} dependencies: @@ -13578,30 +14454,30 @@ packages: get-intrinsic: 1.2.1 dev: true - /get-tsconfig/4.6.2: + /get-tsconfig@4.6.2: resolution: {integrity: sha512-E5XrT4CbbXcXWy+1jChlZmrmCwd5KGx502kDCXJJ7y898TtWW9FwoG5HfOLVRKmlmDGkWN2HM9Ho+/Y8F0sJDg==} dependencies: resolve-pkg-maps: 1.0.0 dev: true - /get-value/2.0.6: + /get-value@2.0.6: resolution: {integrity: sha512-Ln0UQDlxH1BapMu3GPtf7CuYNwRZf2gwCuPqbyG6pB8WfmFpzqcy4xtAaAMUhnNqjMKTiCPZG2oMT3YSx8U2NA==} engines: {node: '>=0.10.0'} dev: true - /getos/3.2.1: + /getos@3.2.1: resolution: {integrity: sha512-U56CfOK17OKgTVqozZjUKNdkfEv6jk5WISBJ8SHoagjE6L69zOwl3Z+O8myjY9MEW3i2HPWQBt/LTbCgcC973Q==} dependencies: async: 3.2.4 dev: true - /getpass/0.1.7: + /getpass@0.1.7: resolution: {integrity: sha512-0fzj9JxOLfJ+XGLhR8ze3unN0KZCgZwiSSDz168VERjK8Wl8kVSdcu2kspd4s4wtAa1y/qrVRiAA0WclVsu0ng==} dependencies: assert-plus: 1.0.0 dev: true - /giget/1.1.2: + /giget@1.1.2: resolution: {integrity: sha512-HsLoS07HiQ5oqvObOI+Qb2tyZH4Gj5nYGfF9qQcZNrPw+uEFhdXtgJr01aO2pWadGHucajYDLxxbtQkm97ON2A==} hasBin: true dependencies: @@ -13616,39 +14492,39 @@ packages: - supports-color dev: true - /github-from-package/0.0.0: + /github-from-package@0.0.0: resolution: {integrity: sha512-SyHy3T1v2NUXn29OsWdxmK6RwHD+vkj3v8en8AOBZ1wBQ/hCAQ5bAQTD02kW4W9tUp/3Qh6J8r9EvntiyCmOOw==} dev: true - /github-slugger/1.5.0: + /github-slugger@1.5.0: resolution: {integrity: sha512-wIh+gKBI9Nshz2o46B0B3f5k/W+WI9ZAv6y5Dn5WJ5SK1t0TnDimB4WE5rmTD05ZAIn8HALCZVmCsvj0w0v0lw==} dev: true - /givens/1.3.9: + /givens@1.3.9: resolution: {integrity: sha512-4hYlStsEIaYeYvZTZwgD5yOS2WVP0dcDsOBqeImdEM8eLuclvv0IEMlQQ1kuA5DN4he7wVH1jsYtNe9uininxg==} dev: true - /glob-parent/3.1.0: + /glob-parent@3.1.0: resolution: {integrity: sha512-E8Ak/2+dZY6fnzlR7+ueWvhsH1SjHr4jjss4YS/h4py44jY9MhK/VFdaZJAWDz6BbL21KeteKxFSFpq8OS5gVA==} dependencies: is-glob: 3.1.0 path-dirname: 1.0.2 dev: true - /glob-parent/5.1.2: + /glob-parent@5.1.2: resolution: {integrity: sha512-AOIgSQCepiJYwP3ARnGx+5VnTu2HBYdzbGP45eLw1vr3zB3vZLeyed1sC9hnbcOc9/SrMyM5RPQrkGz4aS9Zow==} engines: {node: '>= 6'} dependencies: is-glob: 4.0.3 - /glob-parent/6.0.2: + /glob-parent@6.0.2: resolution: {integrity: sha512-XxwI8EOhVQgWp6iDL+3b0r86f4d6AX6zSU55HfB4ydCEuXLXc5FcYeOu+nnGftS4TEju/11rt4KJPTMgbfmv4A==} engines: {node: '>=10.13.0'} dependencies: is-glob: 4.0.3 dev: true - /glob-promise/3.4.0_glob@7.2.3: + /glob-promise@3.4.0(glob@7.2.3): resolution: {integrity: sha512-q08RJ6O+eJn+dVanerAndJwIcumgbDdYiUT7zFQl3Wm1xD6fBKtah7H8ZJChj4wP+8C+QfeVy8xautR7rdmKEw==} engines: {node: '>=4'} peerDependencies: @@ -13658,7 +14534,7 @@ packages: glob: 7.2.3 dev: true - /glob-promise/4.2.2_glob@7.2.3: + /glob-promise@4.2.2(glob@7.2.3): resolution: {integrity: sha512-xcUzJ8NWN5bktoTIX7eOclO1Npxd/dyVqUJxlLIDasT4C7KZyqlPIwkdJ0Ypiy3p2ZKahTjK4M9uC3sNSfNMzw==} engines: {node: '>=12'} peerDependencies: @@ -13668,15 +14544,15 @@ packages: glob: 7.2.3 dev: true - /glob-to-regexp/0.3.0: + /glob-to-regexp@0.3.0: resolution: {integrity: sha512-Iozmtbqv0noj0uDDqoL0zNq0VBEfK2YFoMAZoxJe4cwphvLR+JskfF30QhXHOR4m3KrE6NLRYw+U9MRXvifyig==} dev: true - /glob-to-regexp/0.4.1: + /glob-to-regexp@0.4.1: resolution: {integrity: sha512-lkX1HJXwyMcprw/5YUZc2s7DrpAiHB21/V+E1rHUrVNokkvB6bqMzT0VfV6/86ZNabt1k14YOIaT7nDvOX3Iiw==} dev: true - /glob/10.3.3: + /glob@10.3.3: resolution: {integrity: sha512-92vPiMb/iqpmEgsOoIDvTjc50wf9CCCvMzsi6W0JLPeUKE8TWP1a73PgqSrqy7iAZxaSD1YdzU7QZR5LF51MJw==} engines: {node: '>=16 || 14 >=14.17'} hasBin: true @@ -13688,7 +14564,7 @@ packages: path-scurry: 1.10.1 dev: true - /glob/7.1.6: + /glob@7.1.6: resolution: {integrity: sha512-LwaxwyZ72Lk7vZINtNNrywX0ZuLyStrdDtabefZKAY5ZGJhVtgdznluResxNmPitE0SAO+O26sWTHeKSI2wMBA==} dependencies: fs.realpath: 1.0.0 @@ -13699,7 +14575,7 @@ packages: path-is-absolute: 1.0.1 dev: true - /glob/7.2.3: + /glob@7.2.3: resolution: {integrity: sha512-nFR0zLpU2YCaRxwoCJvL6UvCH2JFyFVIvwTLsIf21AuHlMskA1hhTdk+LlYJtOlYt9v6dvszD2BGRqBL+iQK9Q==} dependencies: fs.realpath: 1.0.0 @@ -13709,7 +14585,7 @@ packages: once: 1.4.0 path-is-absolute: 1.0.1 - /glob/8.1.0: + /glob@8.1.0: resolution: {integrity: sha512-r8hpEjiQEYlF2QU0df3dS+nxxSIreXQS1qRhMJM0Q5NDdR386C7jb7Hwwod8Fgiuex+k0GFjgft18yvxm5XoCQ==} engines: {node: '>=12'} dependencies: @@ -13720,39 +14596,39 @@ packages: once: 1.4.0 dev: true - /global-dirs/3.0.1: + /global-dirs@3.0.1: resolution: {integrity: sha512-NBcGGFbBA9s1VzD41QXDG+3++t9Mn5t1FpLdhESY6oKY4gYTFpX4wO3sqGUa0Srjtbfj3szX0RnemmrVRUdULA==} engines: {node: '>=10'} dependencies: ini: 2.0.0 dev: true - /global/4.4.0: + /global@4.4.0: resolution: {integrity: sha512-wv/LAoHdRE3BeTGz53FAamhGlPLhlssK45usmGFThIi4XqnBmjKQ16u+RNbP7WvigRZDxUsM0J3gcQ5yicaL0w==} dependencies: min-document: 2.19.0 process: 0.11.10 dev: true - /globals/11.12.0: + /globals@11.12.0: resolution: {integrity: sha512-WOBp/EEGUiIsJSp7wcv/y6MO+lV9UoncWqxuFfm8eBwzWNgyfBd6Gz+IeKQ9jCmyhoH99g15M3T+QaVHFjizVA==} engines: {node: '>=4'} - /globals/13.20.0: + /globals@13.20.0: resolution: {integrity: sha512-Qg5QtVkCy/kv3FUSlu4ukeZDVf9ee0iXLAUYX13gbR17bnejFTzr4iS9bY7kwCf1NztRNm1t91fjOiyx4CSwPQ==} engines: {node: '>=8'} dependencies: type-fest: 0.20.2 dev: true - /globalthis/1.0.3: + /globalthis@1.0.3: resolution: {integrity: sha512-sFdI5LyBiNTHjRd7cGPWapiHWMOXKyuBNX/cWJ3NfzrZQVa8GI/8cofCl74AOVqq9W5kNmguTIzJ/1s2gyI9wA==} engines: {node: '>= 0.4'} dependencies: define-properties: 1.2.0 dev: true - /globby/11.1.0: + /globby@11.1.0: resolution: {integrity: sha512-jhIXaOzy1sb8IyocaruWSn1TjmnBVs8Ayhcy83rmxNJ8q2uWKCAj3CnJY+KpGSXCueAPc0i05kVvVKtP1t9S3g==} engines: {node: '>=10'} dependencies: @@ -13764,7 +14640,7 @@ packages: slash: 3.0.0 dev: true - /globby/9.2.0: + /globby@9.2.0: resolution: {integrity: sha512-ollPHROa5mcxDEkwg6bPt3QbEf4pDQSNtd6JPL1YvOvAo/7/0VAm9TccUeoTmarjPw4pfUthSCqcyfNB1I3ZSg==} engines: {node: '>=6'} dependencies: @@ -13780,17 +14656,17 @@ packages: - supports-color dev: true - /glur/1.1.2: + /glur@1.1.2: resolution: {integrity: sha512-l+8esYHTKOx2G/Aao4lEQ0bnHWg4fWtJbVoZZT9Knxi01pB8C80BR85nONLFwkkQoFRCmXY+BUcGZN3yZ2QsRA==} dev: true - /gopd/1.0.1: + /gopd@1.0.1: resolution: {integrity: sha512-d65bNlIadxvpb/A2abVdlqKqV563juRnZ1Wtk6s1sIR8uNsXR70xqIzVqxVf1eTqDunwT2MkczEeaezCKTZhwA==} dependencies: get-intrinsic: 1.2.1 dev: true - /got/12.6.1: + /got@12.6.1: resolution: {integrity: sha512-mThBblvlAF1d4O5oqyvN+ZxLAYwIJK7bpMxgYqPD9okW0C3qm5FFn7k811QrcuEBwaogR3ngOFoCfs6mRv7teQ==} engines: {node: '>=14.16'} dependencies: @@ -13807,28 +14683,19 @@ packages: responselike: 3.0.0 dev: true - /graceful-fs/4.2.11: + /graceful-fs@4.2.11: resolution: {integrity: sha512-RbJ5/jmFcNNCcDV5o9eTnBLJ/HszWV0P73bc+Ff4nS/rJj+YaS6IGyiOL0VoBYX+l1Wrl3k63h/KrH+nhJ0XvQ==} dev: true - /grapheme-splitter/1.0.4: + /grapheme-splitter@1.0.4: resolution: {integrity: sha512-bzh50DW9kTPM00T8y4o8vQg89Di9oLJVLW/KaOGIXJWP/iqCN6WKYkbNOF04vFLJhwcpYUh9ydh/+5vpOqV4YQ==} dev: true - /graphemer/1.4.0: + /graphemer@1.4.0: resolution: {integrity: sha512-EtKwoO6kxCL9WO5xipiHTZlSzBm7WLT627TqC/uVRd0HKmq8NXyebnNYxDoBi7wt8eTWrUrKXCOVaFq9x1kgag==} dev: true - /graphql-tag/2.12.6: - resolution: {integrity: sha512-FdSNcu2QQcWnM2VNvSCCDCVS5PpPqpzgFT8+GXzqJuoDd0CBncxCY278u4mhRO7tMgo2JjgJA5aZ+nWSQ/Z+xg==} - engines: {node: '>=10'} - peerDependencies: - graphql: ^0.9.0 || ^0.10.0 || ^0.11.0 || ^0.12.0 || ^0.13.0 || ^14.0.0 || ^15.0.0 || ^16.0.0 - dependencies: - tslib: 2.6.0 - dev: false - - /graphql-tag/2.12.6_graphql@16.7.1: + /graphql-tag@2.12.6(graphql@16.7.1): resolution: {integrity: sha512-FdSNcu2QQcWnM2VNvSCCDCVS5PpPqpzgFT8+GXzqJuoDd0CBncxCY278u4mhRO7tMgo2JjgJA5aZ+nWSQ/Z+xg==} engines: {node: '>=10'} peerDependencies: @@ -13838,22 +14705,22 @@ packages: tslib: 2.6.0 dev: false - /graphql/16.7.1: + /graphql@16.7.1: resolution: {integrity: sha512-DRYR9tf+UGU0KOsMcKAlXeFfX89UiiIZ0dRU3mR0yJfu6OjZqUcp68NnFLnqQU5RexygFoDy1EW+ccOYcPfmHg==} engines: {node: ^12.22.0 || ^14.16.0 || ^16.0.0 || >=17.0.0} - /gzip-size/6.0.0: + /gzip-size@6.0.0: resolution: {integrity: sha512-ax7ZYomf6jqPTQ4+XCpUGyXKHk5WweS+e05MBO4/y3WJ5RkmPXNKvX+bx1behVILVwr6JSQvZAku021CHPXG3Q==} engines: {node: '>=10'} dependencies: duplexer: 0.1.2 dev: true - /handle-thing/2.0.1: + /handle-thing@2.0.1: resolution: {integrity: sha512-9Qn4yBxelxoh2Ow62nP+Ka/kMnOXRi8BXnRaUwezLNhqelnN49xKz4F/dPP8OYLxLxq6JDtZb2i9XznUQbNPTg==} dev: true - /handlebars/4.7.7: + /handlebars@4.7.7: resolution: {integrity: sha512-aAcXm5OAfE/8IXkcZvCepKU3VzW1/39Fb5ZuqMtgI/hT8X2YgoMvBY5dLhq/cpOvw7Lk1nK/UF71aLG/ZnVYRA==} engines: {node: '>=0.4.7'} hasBin: true @@ -13866,7 +14733,7 @@ packages: uglify-js: 3.17.4 dev: true - /happy-dom/10.1.1: + /happy-dom@10.1.1: resolution: {integrity: sha512-/9AMl/rwMCAz/lAs55W0B2p9I/RfnMWmR2iBI1/twz0+XZYrVgHyJzrBTpHDZlbf00NRk/pFoaktKPtdAP5Tlg==} dependencies: css.escape: 1.5.1 @@ -13877,7 +14744,7 @@ packages: whatwg-mimetype: 3.0.0 dev: true - /happy-dom/9.20.3: + /happy-dom@9.20.3: resolution: {integrity: sha512-eBsgauT435fXFvQDNcmm5QbGtYzxEzOaX35Ia+h6yP/wwa4xSWZh1CfP+mGby8Hk6Xu59mTkpyf72rUXHNxY7A==} dependencies: css.escape: 1.5.1 @@ -13888,60 +14755,60 @@ packages: whatwg-mimetype: 3.0.0 dev: true - /has-ansi/2.0.0: + /has-ansi@2.0.0: resolution: {integrity: sha512-C8vBJ8DwUCx19vhm7urhTuUsr4/IyP6l4VzNQDv+ryHQObW3TTTp9yB68WpYgRe2bbaGuZ/se74IqFeVnMnLZg==} engines: {node: '>=0.10.0'} dependencies: ansi-regex: 2.1.1 dev: true - /has-bigints/1.0.2: + /has-bigints@1.0.2: resolution: {integrity: sha512-tSvCKtBr9lkF0Ex0aQiP9N+OpV4zi2r/Nee5VkRDbaqv35RLYMzbwQfFSZZH0kR+Rd6302UJZ2p/bJCEoR3VoQ==} dev: true - /has-flag/3.0.0: + /has-flag@3.0.0: resolution: {integrity: sha512-sKJf1+ceQBr4SMkvQnBDNDtf4TXpVhVGateu0t918bl30FnbE2m4vNLX+VWe/dpjlb+HugGYzW7uQXH98HPEYw==} engines: {node: '>=4'} - /has-flag/4.0.0: + /has-flag@4.0.0: resolution: {integrity: sha512-EykJT/Q1KjTWctppgIAgfSO0tKVuZUjhgMr17kqTumMl6Afv3EISleU7qZUzoXDFTAHTDC4NOoG/ZxU3EvlMPQ==} engines: {node: '>=8'} - /has-glob/1.0.0: + /has-glob@1.0.0: resolution: {integrity: sha512-D+8A457fBShSEI3tFCj65PAbT++5sKiFtdCdOam0gnfBgw9D277OERk+HM9qYJXmdVLZ/znez10SqHN0BBQ50g==} engines: {node: '>=0.10.0'} dependencies: is-glob: 3.1.0 dev: true - /has-property-descriptors/1.0.0: + /has-property-descriptors@1.0.0: resolution: {integrity: sha512-62DVLZGoiEBDHQyqG4w9xCuZ7eJEwNmJRWw2VY84Oedb7WFcA27fiEVe8oUQx9hAUJ4ekurquucTGwsyO1XGdQ==} dependencies: get-intrinsic: 1.2.1 dev: true - /has-proto/1.0.1: + /has-proto@1.0.1: resolution: {integrity: sha512-7qE+iP+O+bgF9clE5+UoBFzE65mlBiVj3tKCrlNQ0Ogwm0BjpT/gK4SlLYDMybDh5I3TCTKnPPa0oMG7JDYrhg==} engines: {node: '>= 0.4'} dev: true - /has-symbols/1.0.3: + /has-symbols@1.0.3: resolution: {integrity: sha512-l3LCuF6MgDNwTDKkdYGEihYjt5pRPbEg46rtlmnSPlUbgmB8LOIrKJbYYFBSbnPaJexMKtiPO8hmeRjRz2Td+A==} engines: {node: '>= 0.4'} dev: true - /has-tostringtag/1.0.0: + /has-tostringtag@1.0.0: resolution: {integrity: sha512-kFjcSNhnlGV1kyoGk7OXKSawH5JOb/LzUc5w9B02hOTO0dfFRjbHQKvg1d6cf3HbeUmtU9VbbV3qzZ2Teh97WQ==} engines: {node: '>= 0.4'} dependencies: has-symbols: 1.0.3 dev: true - /has-unicode/2.0.1: + /has-unicode@2.0.1: resolution: {integrity: sha512-8Rf9Y83NBReMnx0gFzA8JImQACstCYWUplepDa9xprwwtmgEZUF0h/i5xSA625zB/I37EtrswSST6OXxwaaIJQ==} dev: true - /has-value/0.3.1: + /has-value@0.3.1: resolution: {integrity: sha512-gpG936j8/MzaeID5Yif+577c17TxaDmhuyVgSwtnL/q8UUTySg8Mecb+8Cf1otgLoD7DDH75axp86ER7LFsf3Q==} engines: {node: '>=0.10.0'} dependencies: @@ -13950,7 +14817,7 @@ packages: isobject: 2.1.0 dev: true - /has-value/1.0.0: + /has-value@1.0.0: resolution: {integrity: sha512-IBXk4GTsLYdQ7Rvt+GRBrFSVEkmuOUy4re0Xjd9kJSUQpnTrWR4/y9RpfexN9vkAPMFuQoeWKwqzPozRTlasGw==} engines: {node: '>=0.10.0'} dependencies: @@ -13959,12 +14826,12 @@ packages: isobject: 3.0.1 dev: true - /has-values/0.1.4: + /has-values@0.1.4: resolution: {integrity: sha512-J8S0cEdWuQbqD9//tlZxiMuMNmxB8PlEwvYwuxsTmR1G5RXUePEX/SJn7aD0GMLieuZYSwNH0cQuJGwnYunXRQ==} engines: {node: '>=0.10.0'} dev: true - /has-values/1.0.0: + /has-values@1.0.0: resolution: {integrity: sha512-ODYZC64uqzmtfGMEAX/FvZiRyWLpAC3vYnNunURUnkGVTS+mI0smVsWaPydRBsE3g+ok7h960jChO8mFcWlHaQ==} engines: {node: '>=0.10.0'} dependencies: @@ -13972,13 +14839,13 @@ packages: kind-of: 4.0.0 dev: true - /has/1.0.3: + /has@1.0.3: resolution: {integrity: sha512-f2dvO0VU6Oej7RkWJGrehjbzMAjFp5/VKPp5tTpWIV4JHHZK1/BxbFRtf/siA2SWTe09caDmVtYYzWEIbBS4zw==} engines: {node: '>= 0.4.0'} dependencies: function-bind: 1.1.1 - /hash-base/3.1.0: + /hash-base@3.1.0: resolution: {integrity: sha512-1nmYp/rhMDiE7AYkDw+lLwlAzz0AntGIe51F3RfFfEqyQ3feY2eI/NcwC6umIQVOASPMsWJLJScWKSSvzL9IVA==} engines: {node: '>=4'} dependencies: @@ -13987,14 +14854,14 @@ packages: safe-buffer: 5.2.1 dev: true - /hash.js/1.1.7: + /hash.js@1.1.7: resolution: {integrity: sha512-taOaskGt4z4SOANNseOviYDvjEJinIkRgmp7LbKP2YTTmVxWBl87s/uzK9r+44BclBSp2X7K1hqeNfz9JbBeXA==} dependencies: inherits: 2.0.4 minimalistic-assert: 1.0.1 dev: true - /hast-to-hyperscript/9.0.1: + /hast-to-hyperscript@9.0.1: resolution: {integrity: sha512-zQgLKqF+O2F72S1aa4y2ivxzSlko3MAvxkwG8ehGmNiqd98BIN3JM1rAJPmplEyLmGLO2QZYJtIneOSZ2YbJuA==} dependencies: '@types/unist': 2.0.7 @@ -14006,7 +14873,7 @@ packages: web-namespaces: 1.1.4 dev: true - /hast-util-from-parse5/6.0.1: + /hast-util-from-parse5@6.0.1: resolution: {integrity: sha512-jeJUWiN5pSxW12Rh01smtVkZgZr33wBokLzKLwinYOUfSzm1Nl/c3GUGebDyOKjdsRgMvoVbV0VpAcpjF4NrJA==} dependencies: '@types/parse5': 5.0.3 @@ -14017,11 +14884,11 @@ packages: web-namespaces: 1.1.4 dev: true - /hast-util-parse-selector/2.2.5: + /hast-util-parse-selector@2.2.5: resolution: {integrity: sha512-7j6mrk/qqkSehsM92wQjdIgWM2/BW61u/53G6xmC8i1OmEdKLHbk419QKQUjz6LglWsfqoiHmyMRkP1BGjecNQ==} dev: true - /hast-util-raw/6.0.1: + /hast-util-raw@6.0.1: resolution: {integrity: sha512-ZMuiYA+UF7BXBtsTBNcLBF5HzXzkyE6MLzJnL605LKE8GJylNjGc4jjxazAHUtcwT5/CEt6afRKViYB4X66dig==} dependencies: '@types/hast': 2.3.5 @@ -14036,7 +14903,7 @@ packages: zwitch: 1.0.5 dev: true - /hast-util-to-parse5/6.0.0: + /hast-util-to-parse5@6.0.0: resolution: {integrity: sha512-Lu5m6Lgm/fWuz8eWnrKezHtVY83JeRGaNQ2kn9aJgqaxvVkFCZQBEhgodZUDUvoodgyROHDb3r5IxAEdl6suJQ==} dependencies: hast-to-hyperscript: 9.0.1 @@ -14046,7 +14913,7 @@ packages: zwitch: 1.0.5 dev: true - /hastscript/6.0.0: + /hastscript@6.0.0: resolution: {integrity: sha512-nDM6bvd7lIqDUiYEiu5Sl/+6ReP0BMk/2f4U/Rooccxkj0P5nm+acM5PrGJ/t5I8qPGiqZSE6hVAwZEdZIvP4w==} dependencies: '@types/hast': 2.3.5 @@ -14056,26 +14923,26 @@ packages: space-separated-tokens: 1.1.5 dev: true - /he/1.2.0: + /he@1.2.0: resolution: {integrity: sha512-F/1DnUGPopORZi0ni+CvrCgHQ5FyEAHRLSApuYWMmrbSwoN2Mn/7k+Gl38gJnR7yyDZk6WLXwiGod1JOWNDKGw==} hasBin: true dev: true - /headers-polyfill/3.1.2: + /headers-polyfill@3.1.2: resolution: {integrity: sha512-tWCK4biJ6hcLqTviLXVR9DTRfYGQMXEIUj3gwJ2rZ5wO/at3XtkI4g8mCvFdUF9l1KMBNCfmNAdnahm1cgavQA==} dev: true - /hexoid/1.0.0: + /hexoid@1.0.0: resolution: {integrity: sha512-QFLV0taWQOZtvIRIAdBChesmogZrtuXvVWsFHZTk2SU+anspqZ2vMnoLg7IE1+Uk16N19APic1BuF8bC8c2m5g==} engines: {node: '>=8'} dev: true - /history/5.3.0: + /history@5.3.0: resolution: {integrity: sha512-ZqaKwjjrAYUYfLG+htGaIIZ4nioX2L70ZUMIFysS3xvBsSG4x/n1V6TXV3N8ZYNuFGlDirFg32T7B6WOUPDYcQ==} dependencies: '@babel/runtime': 7.22.6 - /hmac-drbg/1.0.1: + /hmac-drbg@1.0.1: resolution: {integrity: sha512-Tti3gMqLdZfhOQY1Mzf/AanLiqh1WTiJgEj26ZuYQ9fbkLomzGchCws4FyrSd4VkpBfiNhaE1On+lOz894jvXg==} dependencies: hash.js: 1.1.7 @@ -14083,24 +14950,24 @@ packages: minimalistic-crypto-utils: 1.0.1 dev: true - /hoist-non-react-statics/3.3.2: + /hoist-non-react-statics@3.3.2: resolution: {integrity: sha512-/gGivxi8JPKWNm/W0jSmzcMPpfpPLc3dY/6GxhX2hQ9iGj3aDfklV4ET7NjKpSinLpJ5vafa9iiGIEZg10SfBw==} dependencies: react-is: 16.13.1 dev: false - /hosted-git-info/2.8.9: + /hosted-git-info@2.8.9: resolution: {integrity: sha512-mxIDAb9Lsm6DoOJ7xH+5+X4y1LU/4Hi50L9C5sIswK3JzULS4bwk1FvjdBgvYR4bzT4tuUQiC15FE2f5HbLvYw==} dev: true - /hosted-git-info/4.1.0: + /hosted-git-info@4.1.0: resolution: {integrity: sha512-kyCuEOWjJqZuDbRHzL8V93NzQhwIB71oFWSyzVo+KPZI+pnQPPxucdkrOZvkLRnrf5URsQM+IJ09Dw29cRALIA==} engines: {node: '>=10'} dependencies: lru-cache: 6.0.0 dev: true - /hpack.js/2.1.6: + /hpack.js@2.1.6: resolution: {integrity: sha512-zJxVehUdMGIKsRaNt7apO2Gqp0BdqW5yaiGHXXmbpvxgBYVZnAql+BJb4RO5ad2MgpbZKn5G6nMnegrH1FcNYQ==} dependencies: inherits: 2.0.4 @@ -14109,32 +14976,39 @@ packages: wbuf: 1.7.3 dev: true - /html-element-map/1.3.1: + /html-element-map@1.3.1: resolution: {integrity: sha512-6XMlxrAFX4UEEGxctfFnmrFaaZFNf9i5fNuV5wZ3WWQ4FVaNP1aX1LkX9j2mfEx1NpjeE/rL3nmgEn23GdFmrg==} dependencies: array.prototype.filter: 1.0.2 call-bind: 1.0.2 dev: true - /html-encoding-sniffer/3.0.0: + /html-encoding-sniffer@2.0.1: + resolution: {integrity: sha512-D5JbOMBIR/TVZkubHT+OyT2705QvogUW4IBn6nHd756OwieSF9aDYFj4dv6HHEVGYbHaLETa3WggZYWWMyy3ZQ==} + engines: {node: '>=10'} + dependencies: + whatwg-encoding: 1.0.5 + dev: true + + /html-encoding-sniffer@3.0.0: resolution: {integrity: sha512-oWv4T4yJ52iKrufjnyZPkrN0CH3QnrUqdB6In1g5Fe1mia8GmF36gnfNySxoZtxD5+NmYw1EElVXiBk93UeskA==} engines: {node: '>=12'} dependencies: whatwg-encoding: 2.0.0 dev: true - /html-entities/2.3.3: + /html-entities@2.3.3: resolution: {integrity: sha512-DV5Ln36z34NNTDgnz0EWGBLZENelNAtkiFA4kyNOG2tDI6Mz1uSWiq1wAKdyjnJwyDiDO7Fa2SO1CTxPXL8VxA==} dev: true - /html-entities/2.4.0: + /html-entities@2.4.0: resolution: {integrity: sha512-igBTJcNNNhvZFRtm8uA6xMY6xYleeDwn3PeBCkDz7tHttv4F2hsDI2aPgNERWzvRcNYHNT3ymRaQzllmXj4YsQ==} dev: true - /html-escaper/2.0.2: + /html-escaper@2.0.2: resolution: {integrity: sha512-H2iMtd0I4Mt5eYiapRdIDjp+XzelXQ0tFE4JS7YFwFevXXMmOp9myNrUvCg0D6ws8iqkRPBfKHgbwig1SmlLfg==} - /html-minifier-terser/5.1.1: + /html-minifier-terser@5.1.1: resolution: {integrity: sha512-ZPr5MNObqnV/T9akshPKbVgyOqLmy+Bxo7juKCfTfnjNniTAMdy4hz21YQqoofMBJD2kdREaqPPdThoR78Tgxg==} engines: {node: '>=6'} hasBin: true @@ -14148,16 +15022,16 @@ packages: terser: 4.8.1 dev: true - /html-tags/3.3.1: + /html-tags@3.3.1: resolution: {integrity: sha512-ztqyC3kLto0e9WbNp0aeP+M3kTt+nbaIveGmUxAtZa+8iFgKLUOD4YKM5j+f3QD89bra7UeumolZHKuOXnTmeQ==} engines: {node: '>=8'} dev: true - /html-void-elements/1.0.5: + /html-void-elements@1.0.5: resolution: {integrity: sha512-uE/TxKuyNIcx44cIWnjr/rfIATDH7ZaOMmstu0CwhFG1Dunhlp4OC6/NMbhiwoq5BpW0ubi303qnEk/PZj614w==} dev: true - /html-webpack-plugin/4.5.2_webpack@4.46.0: + /html-webpack-plugin@4.5.2(webpack@4.46.0): resolution: {integrity: sha512-q5oYdzjKUIPQVjOosjgvCHQOv9Ett9CYYHlgvJeXG0qQvdSojnBq4vAdQBwn1+yGveAwHCoe/rMR86ozX3+c2A==} engines: {node: '>=6.9'} peerDependencies: @@ -14175,7 +15049,7 @@ packages: webpack: 4.46.0 dev: true - /htmlparser2-svelte/4.1.0: + /htmlparser2-svelte@4.1.0: resolution: {integrity: sha512-+4f4RBFz7Rj2Hp0ZbFbXC+Kzbd6S9PgjiuFtdT76VMNgKogrEZy0pG2UrPycPbrZzVEIM5lAT3lAdkSTCHLPjg==} dependencies: domelementtype: 2.3.0 @@ -14184,7 +15058,7 @@ packages: entities: 2.2.0 dev: true - /htmlparser2/6.1.0: + /htmlparser2@6.1.0: resolution: {integrity: sha512-gyyPk6rgonLFEDGoeRgQNaEUvdJ4ktTmmUh/h2t7s+M8oPpIPxgNACWa+6ESR57kXstwqPiCut0V8NRpcwgU7A==} dependencies: domelementtype: 2.3.0 @@ -14193,7 +15067,7 @@ packages: entities: 2.2.0 dev: true - /htmlparser2/8.0.2: + /htmlparser2@8.0.2: resolution: {integrity: sha512-GYdjWKDkbRLkZ5geuHs5NY1puJ+PXwP7+fHPRz06Eirsb9ugf6d8kkXav6ADhcODhFFPMIXyxkxSuMf3D6NCFA==} dependencies: domelementtype: 2.3.0 @@ -14202,15 +15076,15 @@ packages: entities: 4.5.0 dev: true - /http-cache-semantics/4.1.1: + /http-cache-semantics@4.1.1: resolution: {integrity: sha512-er295DKPVsV82j5kw1Gjt+ADA/XYHsajl82cGNQG2eyoPkvgUhX+nDIyelzhIWbbsXP39EHcI6l5tYs2FYqYXQ==} dev: true - /http-deceiver/1.2.7: + /http-deceiver@1.2.7: resolution: {integrity: sha512-LmpOGxTfbpgtGVxJrj5k7asXHCgNZp5nLfp+hWc8QQRqtb7fUy6kRY3BO1h9ddF6yIPYUARgxGOwB42DnxIaNw==} dev: true - /http-errors/2.0.0: + /http-errors@2.0.0: resolution: {integrity: sha512-FtwrG/euBzaEjYeRqOgly7G0qviiXoJWnvEH2Z1plBdXgbyjv34pHTSb9zoeHMyDy33+DWy5Wt9Wo+TURtOYSQ==} engines: {node: '>= 0.8'} dependencies: @@ -14221,18 +15095,29 @@ packages: toidentifier: 1.0.1 dev: true - /http-proxy-agent/5.0.0: + /http-proxy-agent@4.0.1: + resolution: {integrity: sha512-k0zdNgqWTGA6aeIRVpvfVob4fL52dTfaehylg0Y4UvSySvOq/Y+BOyPrgpUrA7HylqvU8vIZGsRuXmspskV0Tg==} + engines: {node: '>= 6'} + dependencies: + '@tootallnate/once': 1.1.2 + agent-base: 6.0.2 + debug: 4.3.4(supports-color@8.1.1) + transitivePeerDependencies: + - supports-color + dev: true + + /http-proxy-agent@5.0.0: resolution: {integrity: sha512-n2hY8YdoRE1i7r6M0w9DIw5GgZN0G25P8zLCRQ8rjXtTU3vsNFBI/vWK/UIeE6g5MUUz6avwAPXmL6Fy9D/90w==} engines: {node: '>= 6'} dependencies: '@tootallnate/once': 2.0.0 agent-base: 6.0.2 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) transitivePeerDependencies: - supports-color dev: true - /http-signature/1.3.6: + /http-signature@1.3.6: resolution: {integrity: sha512-3adrsD6zqo4GsTqtO7FyrejHNv+NgiIfAfv68+jVlFmSr9OGy7zrxONceFRLKvnnZA5jbxQBX1u9PpB6Wi32Gw==} engines: {node: '>=0.10'} dependencies: @@ -14241,7 +15126,7 @@ packages: sshpk: 1.17.0 dev: true - /http2-wrapper/2.2.0: + /http2-wrapper@2.2.0: resolution: {integrity: sha512-kZB0wxMo0sh1PehyjJUWRFEd99KC5TLjZ2cULC4f9iqJBAmKQQXEICjxl5iPJRwP40dpeHFqqhm7tYCvODpqpQ==} engines: {node: '>=10.19.0'} dependencies: @@ -14249,11 +15134,11 @@ packages: resolve-alpn: 1.2.1 dev: true - /https-browserify/1.0.0: + /https-browserify@1.0.0: resolution: {integrity: sha512-J+FkSdyD+0mA0N+81tMotaRMfSL9SGi+xpD3T6YApKsc3bGSXJlfXri3VyFOeYkfLRQisDk1W+jIFFKBeUBbBg==} dev: true - /https-localhost/4.7.1: + /https-localhost@4.7.1: resolution: {integrity: sha512-rl+NFV0l67/0W7fZwk4LB5gS6HdhtSFLpCpf1N+KD5WQAXtPXX1QE8H0cP8VNJii18rtpTkE9eAHdUfJ0goAnQ==} hasBin: true dependencies: @@ -14267,70 +15152,70 @@ packages: - supports-color dev: true - /https-proxy-agent/5.0.1: + /https-proxy-agent@5.0.1: resolution: {integrity: sha512-dFcAjpTQFgoLMzC2VwU+C/CbS7uRL0lWmxDITmqm7C+7F0Odmj6s9l6alZc6AELXhrnggM2CeWSXHGOdX2YtwA==} engines: {node: '>= 6'} dependencies: agent-base: 6.0.2 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) transitivePeerDependencies: - supports-color dev: true - /human-signals/1.1.1: + /human-signals@1.1.1: resolution: {integrity: sha512-SEQu7vl8KjNL2eoGBLF3+wAjpsNfA9XMlXAYj/3EdaNfAlxKthD1xjEQfGOUhllCGGJVNY34bRr6lPINhNjyZw==} engines: {node: '>=8.12.0'} dev: true - /human-signals/2.1.0: + /human-signals@2.1.0: resolution: {integrity: sha512-B4FFZ6q/T2jhhksgkbEW3HBvWIfDW85snkQgawt07S7J5QXTk6BkNV+0yAeZrM5QpMAdYlocGoljn0sJ/WQkFw==} engines: {node: '>=10.17.0'} dev: true - /human-signals/3.0.1: + /human-signals@3.0.1: resolution: {integrity: sha512-rQLskxnM/5OCldHo+wNXbpVgDn5A17CUoKX+7Sokwaknlq7CdSnphy0W39GU8dw59XiCXmFXDg4fRuckQRKewQ==} engines: {node: '>=12.20.0'} dev: true - /human-signals/4.3.1: + /human-signals@4.3.1: resolution: {integrity: sha512-nZXjEF2nbo7lIw3mgYjItAfgQXog3OjJogSbKa2CQIIvSGWcKgeJnQlNXip6NglNzYH45nSRiEVimMvYL8DDqQ==} engines: {node: '>=14.18.0'} dev: true - /ico-endec/0.1.6: + /ico-endec@0.1.6: resolution: {integrity: sha512-ZdLU38ZoED3g1j3iEyzcQj+wAkY2xfWNkymszfJPoxucIUhK7NayQ+/C4Kv0nDFMIsbtbEHldv3V8PU494/ueQ==} dev: true - /iconv-lite/0.4.24: + /iconv-lite@0.4.24: resolution: {integrity: sha512-v3MXnZAcvnywkTUEZomIActle7RXXeedOR31wwl7VlyoXO4Qi9arvSenNQWne1TcRwhCL1HwLI21bEqdpj8/rA==} engines: {node: '>=0.10.0'} dependencies: safer-buffer: 2.1.2 dev: true - /iconv-lite/0.6.3: + /iconv-lite@0.6.3: resolution: {integrity: sha512-4fCk79wshMdzMp2rH06qWrJE4iolqLhCUH+OiuIgU++RB0+94NlDL81atO7GX55uUKueo0txHNtvEyI6D7WdMw==} engines: {node: '>=0.10.0'} dependencies: safer-buffer: 2.1.2 dev: true - /icss-utils/4.1.1: + /icss-utils@4.1.1: resolution: {integrity: sha512-4aFq7wvWyMHKgxsH8QQtGpvbASCf+eM3wPRLI6R+MgAnTCZ6STYsRvttLvRWK0Nfif5piF394St3HeJDaljGPA==} engines: {node: '>= 6'} dependencies: postcss: 7.0.39 dev: true - /idb/7.1.1: + /idb@7.1.1: resolution: {integrity: sha512-gchesWBzyvGHRO9W8tzUWFDycow5gwjvFKfyV9FF32Y7F50yZMp7mP+T2mJIWFx49zicqyC4uefHM17o6xKIVQ==} dev: true - /ieee754/1.2.1: + /ieee754@1.2.1: resolution: {integrity: sha512-dcyqhDvX1C46lXZcVqCpK+FtMRQVdIMN6/Df5js2zouUsqG7I6sFxitIC+7KYK29KdXOLHdu9zL4sFnoVQnqaA==} dev: true - /if-node-version/1.1.1: + /if-node-version@1.1.1: resolution: {integrity: sha512-qMcJD7ftbSWlf+6w8nzZAWKOELmG3xH5Gu5XYW2+f9uaYj1t9JX5KNWxnvNMGhu8f+uIUgnqFHLlwyKTHaLWWA==} engines: {node: '>=0.10.0'} hasBin: true @@ -14339,37 +15224,46 @@ packages: semver: 5.7.2 dev: true - /iferr/0.1.5: + /iferr@0.1.5: resolution: {integrity: sha512-DUNFN5j7Tln0D+TxzloUjKB+CtVu6myn0JEFak6dG18mNt9YkQ6lzGCdafwofISZ1lLF3xRHJ98VKy9ynkcFaA==} dev: true - /ignore/4.0.6: + /ignore@4.0.6: resolution: {integrity: sha512-cyFDKrqc/YdcWFniJhzI42+AzS+gNwmUzOSFcRCQYwySuBBBy/KjuxWLZ/FHEH6Moq1NizMOBWyTcv8O4OZIMg==} engines: {node: '>= 4'} dev: true - /ignore/5.2.4: + /ignore@5.2.4: resolution: {integrity: sha512-MAb38BcSbH0eHNBxn7ql2NH/kX33OkB3lZ1BNdh7ENeRChHTYsTvWrMubiIAMNS2llXEEgZ1MUOBtXChP3kaFQ==} engines: {node: '>= 4'} dev: true - /import-fresh/3.3.0: + /import-fresh@3.3.0: resolution: {integrity: sha512-veYYhQa+D1QBKznvhUHxb8faxlrwUnxseDAbAp457E0wLNio2bOSKnjYDhMj+YiAq61xrMGhQk9iXVk5FzgQMw==} engines: {node: '>=6'} dependencies: parent-module: 1.0.1 resolve-from: 4.0.0 - /import-meta-resolve/3.0.0: + /import-local@3.1.0: + resolution: {integrity: sha512-ASB07uLtnDs1o6EHjKpX34BKYDSqnFerfTOJL2HvMqF70LnxpjkzDB8J44oT9pu4AMPkQwf8jl6szgvNd2tRIg==} + engines: {node: '>=8'} + hasBin: true + dependencies: + pkg-dir: 4.2.0 + resolve-cwd: 3.0.0 + dev: true + + /import-meta-resolve@3.0.0: resolution: {integrity: sha512-4IwhLhNNA8yy445rPjD/lWh++7hMDOml2eHtd58eG7h+qK3EryMuuRbsHGPikCoAgIkkDnckKfWSk2iDla/ejg==} dev: true - /imurmurhash/0.1.4: + /imurmurhash@0.1.4: resolution: {integrity: sha512-JmXMZ6wuvDmLiHEml9ykzqO6lwFbof0GG4IkcGaENdCRDDmMVnny7s5HsIgHCbaq0w2MyPhDqkhTUgS2LU2PHA==} engines: {node: '>=0.8.19'} dev: true - /indent-string/2.1.0: + /indent-string@2.1.0: resolution: {integrity: sha512-aqwDFWSgSgfRaEwao5lg5KEcVd/2a+D1rvoG7NdilmYz0NwRk6StWpWdz/Hpk34MKPpx7s8XxUqimfcQK6gGlg==} engines: {node: '>=0.10.0'} dependencies: @@ -14377,46 +15271,46 @@ packages: dev: true optional: true - /indent-string/4.0.0: + /indent-string@4.0.0: resolution: {integrity: sha512-EdDDZu4A2OyIK7Lr/2zG+w5jmbuk1DVBnEwREQvBzspBJkCEbRa8GxU1lghYcaGJCnRWibjDXlq779X1/y5xwg==} engines: {node: '>=8'} dev: true - /infer-owner/1.0.4: + /infer-owner@1.0.4: resolution: {integrity: sha512-IClj+Xz94+d7irH5qRyfJonOdfTzuDaifE6ZPWfx0N0+/ATZCbuTPq2prFl526urkQd90WyUKIh1DfBQ2hMz9A==} dev: true - /inflight/1.0.6: + /inflight@1.0.6: resolution: {integrity: sha512-k92I/b08q4wvFscXCLvqfsHCrjrF7yiXsQuIVvVE7N82W3+aqpzuUdBbfhWcy/FZR3/4IgflMgKLOsvPDrGCJA==} dependencies: once: 1.4.0 wrappy: 1.0.2 - /inherits/2.0.1: + /inherits@2.0.1: resolution: {integrity: sha512-8nWq2nLTAwd02jTqJExUYFSD/fKq6VH9Y/oG2accc/kdI0V98Bag8d5a4gi3XHz73rDWa2PvTtvcWYquKqSENA==} dev: true - /inherits/2.0.3: + /inherits@2.0.3: resolution: {integrity: sha512-x00IRNXNy63jwGkJmzPigoySHbaqpNuzKbBOmzK+g2OdZpQ9w+sxCN+VSB3ja7IAge2OP2qpfxTjeNcyjmW1uw==} dev: true - /inherits/2.0.4: + /inherits@2.0.4: resolution: {integrity: sha512-k/vGaX4/Yla3WzyMCvTQOXYeIHvqOKtnqBduzTHpzpQZzAskKMhZ2K+EnBiSM9zGSoIFeMpXKxa4dYeZIQqewQ==} - /ini/1.3.8: + /ini@1.3.8: resolution: {integrity: sha512-JV/yugV2uzW5iMRSiZAyDtQd+nxtUnjeLt0acNdw98kKLrvuRVyB80tsREOE7yvGVgalhZ6RNXCmEHkUKBKxew==} dev: true - /ini/2.0.0: + /ini@2.0.0: resolution: {integrity: sha512-7PnF4oN3CvZF23ADhA5wRaYEQpJ8qygSkbtTXWBeXWXmEVRXK+1ITciHWwHhsjv1TmW0MgacIv6hEi5pX5NQdA==} engines: {node: '>=10'} dev: true - /inline-style-parser/0.1.1: + /inline-style-parser@0.1.1: resolution: {integrity: sha512-7NXolsK4CAS5+xvdj5OMMbI962hU/wvwoxk+LWR9Ek9bVtyuuYScDN6eS0rUm6TxApFpw7CX1o4uJzcd4AyD3Q==} dev: true - /inquirer/8.2.5: + /inquirer@8.2.5: resolution: {integrity: sha512-QAgPDQMEgrDssk1XiwwHoOGYF9BAbUcc1+j+FhEvaOt8/cKRqyLn0U5qA6F74fGhTMGxf92pOvPBeh29jQJDTQ==} engines: {node: '>=12.0.0'} dependencies: @@ -14437,7 +15331,7 @@ packages: wrap-ansi: 7.0.0 dev: true - /inquirer/9.2.7: + /inquirer@9.2.7: resolution: {integrity: sha512-Bf52lnfvNxGPJPltiNO2tLBp3zC339KNlGMqOkW+dsvNikBhcVDK5kqU2lVX2FTPzuXUFX5WJDlsw//w3ZwoTw==} engines: {node: '>=14.18.0'} dependencies: @@ -14458,7 +15352,7 @@ packages: wrap-ansi: 6.2.0 dev: true - /internal-slot/1.0.5: + /internal-slot@1.0.5: resolution: {integrity: sha512-Y+R5hJrzs52QCG2laLn4udYVnxsfny9CpOhNhUvk/SSSVyF6T27FzRbF0sroPidSu3X8oEAkOn2K804mjpt6UQ==} engines: {node: '>= 0.4'} dependencies: @@ -14467,56 +15361,56 @@ packages: side-channel: 1.0.4 dev: true - /internmap/2.0.3: + /internmap@2.0.3: resolution: {integrity: sha512-5Hh7Y1wQbvY5ooGgPbDaL5iYLAPzMTUrjMulskHLH6wnv/A+1q5rgEaiuqEjB+oxGXIVZs1FF+R/KPN3ZSQYYg==} engines: {node: '>=12'} dev: false - /interpret/2.2.0: + /interpret@2.2.0: resolution: {integrity: sha512-Ju0Bz/cEia55xDwUWEa8+olFpCiQoypjnQySseKtmjNrnps3P+xfpUmGr90T7yjlVJmOtybRvPXhKMbHr+fWnw==} engines: {node: '>= 0.10'} dev: true - /ip/2.0.0: + /ip@2.0.0: resolution: {integrity: sha512-WKa+XuLG1A1R0UWhl2+1XQSi+fZWMsYKffMZTTYsiZaUD8k2yDAj5atimTUD2TZkyCkNEeYE5NhFZmupOGtjYQ==} dev: true - /ipaddr.js/1.9.1: + /ipaddr.js@1.9.1: resolution: {integrity: sha512-0KI/607xoxSToH7GjN1FfSbLoU0+btTicjsQSWQlh/hZykN8KpmMf7uYwPW3R+akZ6R/w18ZlXSHBYXiYUPO3g==} engines: {node: '>= 0.10'} dev: true - /is-absolute-url/3.0.3: + /is-absolute-url@3.0.3: resolution: {integrity: sha512-opmNIX7uFnS96NtPmhWQgQx6/NYFgsUXYMllcfzwWKUMwfo8kku1TvE6hkNcH+Q1ts5cMVrsY7j0bxXQDciu9Q==} engines: {node: '>=8'} dev: true - /is-accessor-descriptor/0.1.6: + /is-accessor-descriptor@0.1.6: resolution: {integrity: sha512-e1BM1qnDbMRG3ll2U9dSK0UMHuWOs3pY3AtcFsmvwPtKL3MML/Q86i+GilLfvqEs4GW+ExB91tQ3Ig9noDIZ+A==} engines: {node: '>=0.10.0'} dependencies: kind-of: 3.2.2 dev: true - /is-accessor-descriptor/1.0.0: + /is-accessor-descriptor@1.0.0: resolution: {integrity: sha512-m5hnHTkcVsPfqx3AKlyttIPb7J+XykHvJP2B9bZDjlhLIoEq4XoK64Vg7boZlVWYK6LUY94dYPEE7Lh0ZkZKcQ==} engines: {node: '>=0.10.0'} dependencies: kind-of: 6.0.3 dev: true - /is-alphabetical/1.0.4: + /is-alphabetical@1.0.4: resolution: {integrity: sha512-DwzsA04LQ10FHTZuL0/grVDk4rFoVH1pjAToYwBrHSxcrBIGQuXrQMtD5U1b0U2XVgKZCTLLP8u2Qxqhy3l2Vg==} dev: true - /is-alphanumerical/1.0.4: + /is-alphanumerical@1.0.4: resolution: {integrity: sha512-UzoZUr+XfVz3t3v4KyGEniVL9BDRoQtY7tOyrRybkVNjDFWyo1yhXNGrrBTQxp3ib9BLAWs7k2YKBQsFRkZG9A==} dependencies: is-alphabetical: 1.0.4 is-decimal: 1.0.4 dev: true - /is-arguments/1.1.1: + /is-arguments@1.1.1: resolution: {integrity: sha512-8Q7EARjzEnKpt/PCD7e1cgUS0a6X8u5tdSiMqXhojOdoV9TsMsiO+9VLC5vAmO8N7/GmXn7yjR8qnA6bVAEzfA==} engines: {node: '>= 0.4'} dependencies: @@ -14524,7 +15418,7 @@ packages: has-tostringtag: 1.0.0 dev: true - /is-array-buffer/3.0.2: + /is-array-buffer@3.0.2: resolution: {integrity: sha512-y+FyyR/w8vfIRq4eQcM1EYgSTnmHXPqaF+IgzgraytCFq5Xh8lllDVmAZolPJiZttZLeFSINPYMaEJ7/vWUa1w==} dependencies: call-bind: 1.0.2 @@ -14532,20 +15426,20 @@ packages: is-typed-array: 1.1.10 dev: true - /is-arrayish/0.2.1: + /is-arrayish@0.2.1: resolution: {integrity: sha512-zz06S8t0ozoDXMG+ube26zeCTNXcKIPJZJi8hBrF4idCLms4CG9QtK7qBl1boi5ODzFpjswb5JPmHCbMpjaYzg==} - /is-arrayish/0.3.2: + /is-arrayish@0.3.2: resolution: {integrity: sha512-eVRqCvVlZbuw3GrM63ovNSNAeA1K16kaR/LRY/92w0zxQ5/1YzwblUX652i4Xs9RwAGjW9d9y6X88t8OaAJfWQ==} dev: true - /is-bigint/1.0.4: + /is-bigint@1.0.4: resolution: {integrity: sha512-zB9CruMamjym81i2JZ3UMn54PKGsQzsJeo6xvN3HJJ4CAsQNB6iRutp2To77OfCNuoxspsIhzaPoO1zyCEhFOg==} dependencies: has-bigints: 1.0.2 dev: true - /is-binary-path/1.0.1: + /is-binary-path@1.0.1: resolution: {integrity: sha512-9fRVlXc0uCxEDj1nQzaWONSpbTfx0FmJfzHF7pwlI8DkWGoHBBea4Pg5Ky0ojwwxQmnSifgbKkI06Qv0Ljgj+Q==} engines: {node: '>=0.10.0'} dependencies: @@ -14553,14 +15447,14 @@ packages: dev: true optional: true - /is-binary-path/2.1.0: + /is-binary-path@2.1.0: resolution: {integrity: sha512-ZMERYes6pDydyuGidse7OsHxtbI7WVeUEozgR/g7rd0xUimYNlvZRE/K2MgZTjWy725IfelLeVcEM97mmtRGXw==} engines: {node: '>=8'} dependencies: binary-extensions: 2.2.0 dev: true - /is-boolean-object/1.1.2: + /is-boolean-object@1.1.2: resolution: {integrity: sha512-gDYaKHJmnj4aWxyj6YHyXVpdQawtVLHU5cb+eztPGczf6cjuTdwve5ZIEfgXqH4e57An1D1AKf8CZ3kYrQRqYA==} engines: {node: '>= 0.4'} dependencies: @@ -14568,72 +15462,72 @@ packages: has-tostringtag: 1.0.0 dev: true - /is-buffer/1.1.6: + /is-buffer@1.1.6: resolution: {integrity: sha512-NcdALwpXkTm5Zvvbk7owOUSvVvBKDgKP5/ewfXEznmQFfs4ZRmanOeKBTjRVjka3QFoN6XJ+9F3USqfHqTaU5w==} dev: true - /is-buffer/2.0.5: + /is-buffer@2.0.5: resolution: {integrity: sha512-i2R6zNFDwgEHJyQUtJEk0XFi1i0dPFn/oqjK3/vPCcDeJvW5NQ83V8QbicfF1SupOaB0h8ntgBC2YiE7dfyctQ==} engines: {node: '>=4'} dev: true - /is-builtin-module/3.2.1: + /is-builtin-module@3.2.1: resolution: {integrity: sha512-BSLE3HnV2syZ0FK0iMA/yUGplUeMmNz4AW5fnTunbCIqZi4vG3WjJT9FHMy5D69xmAYBHXQhJdALdpwVxV501A==} engines: {node: '>=6'} dependencies: builtin-modules: 3.3.0 dev: true - /is-callable/1.2.7: + /is-callable@1.2.7: resolution: {integrity: sha512-1BC0BVFhS/p0qtw6enp8e+8OD0UrK0oFLztSjNzhcKA3WDuJxxAPXzPuPtKkjEY9UUoEWlX/8fgKeu2S8i9JTA==} engines: {node: '>= 0.4'} dev: true - /is-ci/2.0.0: + /is-ci@2.0.0: resolution: {integrity: sha512-YfJT7rkpQB0updsdHLGWrvhBJfcfzNNawYDNIyQXJz0IViGf75O8EBPKSdvw2rF+LGCsX4FZ8tcr3b19LcZq4w==} hasBin: true dependencies: ci-info: 2.0.0 dev: true - /is-ci/3.0.1: + /is-ci@3.0.1: resolution: {integrity: sha512-ZYvCgrefwqoQ6yTyYUbQu64HsITZ3NfKX1lzaEYdkTDcfKzzCI/wthRRYKkdjHKFVgNiXKAKm65Zo1pk2as/QQ==} hasBin: true dependencies: ci-info: 3.8.0 dev: true - /is-core-module/2.12.1: + /is-core-module@2.12.1: resolution: {integrity: sha512-Q4ZuBAe2FUsKtyQJoQHlvP8OvBERxO3jEmy1I7hcRXcJBGGHFh/aJBswbXuS9sgrDH2QUO8ilkwNPHvHMd8clg==} dependencies: has: 1.0.3 - /is-data-descriptor/0.1.4: + /is-data-descriptor@0.1.4: resolution: {integrity: sha512-+w9D5ulSoBNlmw9OHn3U2v51SyoCd0he+bB3xMl62oijhrspxowjU+AIcDY0N3iEJbUEkB15IlMASQsxYigvXg==} engines: {node: '>=0.10.0'} dependencies: kind-of: 3.2.2 dev: true - /is-data-descriptor/1.0.0: + /is-data-descriptor@1.0.0: resolution: {integrity: sha512-jbRXy1FmtAoCjQkVmIVYwuuqDFUbaOeDjmed1tOGPrsMhtJA4rD9tkgA0F1qJ3gRFRXcHYVkdeaP50Q5rE/jLQ==} engines: {node: '>=0.10.0'} dependencies: kind-of: 6.0.3 dev: true - /is-date-object/1.0.5: + /is-date-object@1.0.5: resolution: {integrity: sha512-9YQaSxsAiSwcvS33MBk3wTCVnWK+HhF8VZR2jRxehM16QcVOdHqPn4VPHmRK4lSr38n9JriurInLcP90xsYNfQ==} engines: {node: '>= 0.4'} dependencies: has-tostringtag: 1.0.0 dev: true - /is-decimal/1.0.4: + /is-decimal@1.0.4: resolution: {integrity: sha512-RGdriMmQQvZ2aqaQq3awNA6dCGtKpiDFcOzrTWrDAT2MiWrKQVPmxLGHl7Y2nNu6led0kEyoX0enY0qXYsv9zw==} dev: true - /is-descriptor/0.1.6: + /is-descriptor@0.1.6: resolution: {integrity: sha512-avDYr0SB3DwO9zsMov0gKCESFYqCnE4hq/4z3TdUlukEy5t9C0YRq7HLrsN52NAcqXKaepeCD0n+B0arnVG3Hg==} engines: {node: '>=0.10.0'} dependencies: @@ -14642,7 +15536,7 @@ packages: kind-of: 5.1.0 dev: true - /is-descriptor/1.0.2: + /is-descriptor@1.0.2: resolution: {integrity: sha512-2eis5WqQGV7peooDyLmNEPUrps9+SXX5c9pL3xEB+4e9HnGuDa7mB7kHxHw4CbqS9k1T2hOH3miL8n8WtiYVtg==} engines: {node: '>=0.10.0'} dependencies: @@ -14651,80 +15545,85 @@ packages: kind-of: 6.0.3 dev: true - /is-docker/2.2.1: + /is-docker@2.2.1: resolution: {integrity: sha512-F+i2BKsFrH66iaUFc0woD8sLy8getkwTwtOBjvs56Cx4CgJDeKQeqfz8wAYiSb8JOprWhHH5p77PbmYCvvUuXQ==} engines: {node: '>=8'} hasBin: true dev: true - /is-dom/1.1.0: + /is-dom@1.1.0: resolution: {integrity: sha512-u82f6mvhYxRPKpw8V1N0W8ce1xXwOrQtgGcxl6UCL5zBmZu3is/18K0rR7uFCnMDuAsS/3W54mGL4vsaFUQlEQ==} dependencies: is-object: 1.0.2 is-window: 1.0.2 dev: true - /is-extendable/0.1.1: + /is-extendable@0.1.1: resolution: {integrity: sha512-5BMULNob1vgFX6EjQw5izWDxrecWK9AM72rugNr0TFldMOi0fj6Jk+zeKIt0xGj4cEfQIJth4w3OKWOJ4f+AFw==} engines: {node: '>=0.10.0'} dev: true - /is-extendable/1.0.1: + /is-extendable@1.0.1: resolution: {integrity: sha512-arnXMxT1hhoKo9k1LZdmlNyJdDDfy2v0fXjFlmok4+i8ul/6WlbVge9bhM74OpNPQPMGUToDtz+KXa1PneJxOA==} engines: {node: '>=0.10.0'} dependencies: is-plain-object: 2.0.4 dev: true - /is-extglob/2.1.1: + /is-extglob@2.1.1: resolution: {integrity: sha512-SbKbANkN603Vi4jEZv49LeVJMn4yGwsbzZworEoyEiutsN3nJYdbO36zfhGJ6QEDpOZIFkDtnq5JRxmvl3jsoQ==} engines: {node: '>=0.10.0'} - /is-finite/1.1.0: + /is-finite@1.1.0: resolution: {integrity: sha512-cdyMtqX/BOqqNBBiKlIVkytNHm49MtMlYyn1zxzvJKWmFMlGzm+ry5BBfYyeY9YmNKbRSo/o7OX9w9ale0wg3w==} engines: {node: '>=0.10.0'} dev: true optional: true - /is-fullwidth-code-point/3.0.0: + /is-fullwidth-code-point@3.0.0: resolution: {integrity: sha512-zymm5+u+sCsSWyD9qNaejV3DFvhCKclKdizYaJUuHA83RLjb7nSuGnddCHGv0hk+KY7BMAlsWeK4Ueg6EV6XQg==} engines: {node: '>=8'} dev: true - /is-fullwidth-code-point/4.0.0: + /is-fullwidth-code-point@4.0.0: resolution: {integrity: sha512-O4L094N2/dZ7xqVdrXhh9r1KODPJpFms8B5sGdJLPy664AgvXsreZUyCQQNItZRDlYug4xStLjNp/sz3HvBowQ==} engines: {node: '>=12'} dev: true - /is-function/1.0.2: + /is-function@1.0.2: resolution: {integrity: sha512-lw7DUp0aWXYg+CBCN+JKkcE0Q2RayZnSvnZBlwgxHBQhqt5pZNVy4Ri7H9GmmXkdu7LUthszM+Tor1u/2iBcpQ==} dev: true - /is-generator-function/1.0.10: + /is-generator-fn@2.1.0: + resolution: {integrity: sha512-cTIB4yPYL/Grw0EaSzASzg6bBy9gqCofvWN8okThAYIxKJZC+udlRAmGbM0XLeniEJSs8uEgHPGuHSe1XsOLSQ==} + engines: {node: '>=6'} + dev: true + + /is-generator-function@1.0.10: resolution: {integrity: sha512-jsEjy9l3yiXEQ+PsXdmBwEPcOxaXWLspKdplFUVI9vq1iZgIekeC0L167qeu86czQaxed3q/Uzuw0swL0irL8A==} engines: {node: '>= 0.4'} dependencies: has-tostringtag: 1.0.0 dev: true - /is-glob/3.1.0: + /is-glob@3.1.0: resolution: {integrity: sha512-UFpDDrPgM6qpnFNI+rh/p3bUaq9hKLZN8bMUWzxmcnZVS3omf4IPK+BrewlnWjO1WmUsMYuSjKh4UJuV4+Lqmw==} engines: {node: '>=0.10.0'} dependencies: is-extglob: 2.1.1 dev: true - /is-glob/4.0.3: + /is-glob@4.0.3: resolution: {integrity: sha512-xelSayHH36ZgE7ZWhli7pW34hNbNl8Ojv5KVmkJD4hBdD3th8Tfk9vYasLM+mXWOZhFkgZfxhLSnrwRr4elSSg==} engines: {node: '>=0.10.0'} dependencies: is-extglob: 2.1.1 - /is-hexadecimal/1.0.4: + /is-hexadecimal@1.0.4: resolution: {integrity: sha512-gyPJuv83bHMpocVYoqof5VDiZveEoGoFL8m3BXNb2VW8Xs+rz9kqO8LOQ5DH6EsuvilT1ApazU0pyl+ytbPtlw==} dev: true - /is-installed-globally/0.4.0: + /is-installed-globally@0.4.0: resolution: {integrity: sha512-iwGqO3J21aaSkC7jWnHP/difazwS7SFeIqxv6wEtLU8Y5KlzFTjyqcSIT0d8s4+dDhKytsk9PJZ2BkS5eZwQRQ==} engines: {node: '>=10'} dependencies: @@ -14732,99 +15631,99 @@ packages: is-path-inside: 3.0.3 dev: true - /is-interactive/1.0.0: + /is-interactive@1.0.0: resolution: {integrity: sha512-2HvIEKRoqS62guEC+qBjpvRubdX910WCMuJTZ+I9yvqKU2/12eSL549HMwtabb4oupdj2sMP50k+XJfB/8JE6w==} engines: {node: '>=8'} dev: true - /is-map/2.0.2: + /is-map@2.0.2: resolution: {integrity: sha512-cOZFQQozTha1f4MxLFzlgKYPTyj26picdZTx82hbc/Xf4K/tZOOXSCkMvU4pKioRXGDLJRn0GM7Upe7kR721yg==} dev: true - /is-module/1.0.0: + /is-module@1.0.0: resolution: {integrity: sha512-51ypPSPCoTEIN9dy5Oy+h4pShgJmPCygKfyRCISBI+JoWT/2oJvK8QPxmwv7b/p239jXrm9M1mlQbyKJ5A152g==} dev: true - /is-negative-zero/2.0.2: + /is-negative-zero@2.0.2: resolution: {integrity: sha512-dqJvarLawXsFbNDeJW7zAz8ItJ9cd28YufuuFzh0G8pNHjJMnY08Dv7sYX2uF5UpQOwieAeOExEYAWWfu7ZZUA==} engines: {node: '>= 0.4'} dev: true - /is-node-process/1.2.0: + /is-node-process@1.2.0: resolution: {integrity: sha512-Vg4o6/fqPxIjtxgUH5QLJhwZ7gW5diGCVlXpuUfELC62CuxM1iHcRe51f2W1FDy04Ai4KJkagKjx3XaqyfRKXw==} dev: true - /is-number-object/1.0.7: + /is-number-object@1.0.7: resolution: {integrity: sha512-k1U0IRzLMo7ZlYIfzRu23Oh6MiIFasgpb9X76eqfFZAqwH44UI4KTBvBYIZ1dSL9ZzChTB9ShHfLkR4pdW5krQ==} engines: {node: '>= 0.4'} dependencies: has-tostringtag: 1.0.0 dev: true - /is-number/3.0.0: + /is-number@3.0.0: resolution: {integrity: sha512-4cboCqIpliH+mAvFNegjZQ4kgKc3ZUhQVr3HvWbSh5q3WH2v82ct+T2Y1hdU5Gdtorx/cLifQjqCbL7bpznLTg==} engines: {node: '>=0.10.0'} dependencies: kind-of: 3.2.2 dev: true - /is-number/7.0.0: + /is-number@7.0.0: resolution: {integrity: sha512-41Cifkg6e8TylSpdtTpeLVMqvSBEVzTttHvERD741+pnZ8ANv0004MRL43QKPDlK9cGvNp6NZWZUBlbGXYxxng==} engines: {node: '>=0.12.0'} - /is-obj/1.0.1: + /is-obj@1.0.1: resolution: {integrity: sha512-l4RyHgRqGN4Y3+9JHVrNqO+tN0rV5My76uW5/nuO4K1b6vw5G8d/cmFjP9tRfEsdhZNt0IFdZuK/c2Vr4Nb+Qg==} engines: {node: '>=0.10.0'} dev: true - /is-object/1.0.2: + /is-object@1.0.2: resolution: {integrity: sha512-2rRIahhZr2UWb45fIOuvZGpFtz0TyOZLf32KxBbSoUCeZR495zCKlWUKKUByk3geS2eAs7ZAABt0Y/Rx0GiQGA==} dev: true - /is-path-inside/3.0.3: + /is-path-inside@3.0.3: resolution: {integrity: sha512-Fd4gABb+ycGAmKou8eMftCupSir5lRxqf4aD/vd0cD2qc4HL07OjCeuHMr8Ro4CoMaeCKDB0/ECBOVWjTwUvPQ==} engines: {node: '>=8'} dev: true - /is-plain-obj/2.1.0: + /is-plain-obj@2.1.0: resolution: {integrity: sha512-YWnfyRwxL/+SsrWYfOpUtz5b3YD+nyfkHvjbcanzk8zgyO4ASD67uVMRt8k5bM4lLMDnXfriRhOpemw+NfT1eA==} engines: {node: '>=8'} dev: true - /is-plain-obj/4.1.0: + /is-plain-obj@4.1.0: resolution: {integrity: sha512-+Pgi+vMuUNkJyExiMBt5IlFoMyKnr5zhJ4Uspz58WOhBF5QoIZkFyNHIbBAtHwzVAgk5RtndVNsDRN61/mmDqg==} engines: {node: '>=12'} dev: true - /is-plain-object/2.0.4: + /is-plain-object@2.0.4: resolution: {integrity: sha512-h5PpgXkWitc38BBMYawTYMWJHFZJVnBquFE57xFpjB8pJFiF6gZ+bU+WyI/yqXiFR5mdLsgYNaPe8uao6Uv9Og==} engines: {node: '>=0.10.0'} dependencies: isobject: 3.0.1 dev: true - /is-plain-object/5.0.0: + /is-plain-object@5.0.0: resolution: {integrity: sha512-VRSzKkbMm5jMDoKLbltAkFQ5Qr7VDiTFGXxYFXXowVj387GeGNOCsOH6Msy00SGZ3Fp84b1Naa1psqgcCIEP5Q==} engines: {node: '>=0.10.0'} dev: true - /is-potential-custom-element-name/1.0.1: + /is-potential-custom-element-name@1.0.1: resolution: {integrity: sha512-bCYeRA2rVibKZd+s2625gGnGF/t7DSqDs4dP7CrLA1m7jKWz6pps0LpYLJN8Q64HtmPKJ1hrN3nzPNKFEKOUiQ==} dev: true - /is-reference/1.2.1: + /is-reference@1.2.1: resolution: {integrity: sha512-U82MsXXiFIrjCK4otLT+o2NA2Cd2g5MLoOVXUZjIOhLurrRxpEXzI8O0KZHr3IjLvlAH1kTPYSuqer5T9ZVBKQ==} dependencies: '@types/estree': 1.0.1 dev: true - /is-reference/3.0.1: + /is-reference@3.0.1: resolution: {integrity: sha512-baJJdQLiYaJdvFbJqXrcGv3WU3QCzBlUcI5QhbesIm6/xPsvmO+2CDoi/GMOFBQEQm+PXkwOPrp9KK5ozZsp2w==} dependencies: '@types/estree': 1.0.1 dev: true - /is-regex/1.1.4: + /is-regex@1.1.4: resolution: {integrity: sha512-kvRdxDsxZjhzUX07ZnLydzS1TU/TJlTUHHY4YLL87e37oUA49DfkLqgy+VjFocowy29cKvcSiu+kIv728jTTVg==} engines: {node: '>= 0.4'} dependencies: @@ -14832,55 +15731,55 @@ packages: has-tostringtag: 1.0.0 dev: true - /is-regexp/1.0.0: + /is-regexp@1.0.0: resolution: {integrity: sha512-7zjFAPO4/gwyQAAgRRmqeEeyIICSdmCqa3tsVHMdBzaXXRiqopZL4Cyghg/XulGWrtABTpbnYYzzIRffLkP4oA==} engines: {node: '>=0.10.0'} dev: true - /is-set/2.0.2: + /is-set@2.0.2: resolution: {integrity: sha512-+2cnTEZeY5z/iXGbLhPrOAaK/Mau5k5eXq9j14CpRTftq0pAJu2MwVRSZhyZWBzx3o6X795Lz6Bpb6R0GKf37g==} dev: true - /is-shared-array-buffer/1.0.2: + /is-shared-array-buffer@1.0.2: resolution: {integrity: sha512-sqN2UDu1/0y6uvXyStCOzyhAjCSlHceFoMKJW8W9EU9cvic/QdsZ0kEU93HEy3IUEFZIiH/3w+AH/UQbPHNdhA==} dependencies: call-bind: 1.0.2 dev: true - /is-stream/1.1.0: + /is-stream@1.1.0: resolution: {integrity: sha512-uQPm8kcs47jx38atAcWTVxyltQYoPT68y9aWYdV6yWXSyW8mzSat0TL6CiWdZeCdF3KrAvpVtnHbTv4RN+rqdQ==} engines: {node: '>=0.10.0'} dev: true - /is-stream/2.0.1: + /is-stream@2.0.1: resolution: {integrity: sha512-hFoiJiTl63nn+kstHGBtewWSKnQLpyb155KHheA1l39uvtO9nWIop1p3udqPcUd/xbF1VLMO4n7OI6p7RbngDg==} engines: {node: '>=8'} dev: true - /is-stream/3.0.0: + /is-stream@3.0.0: resolution: {integrity: sha512-LnQR4bZ9IADDRSkvpqMGvt/tEJWclzklNgSw48V5EAaAeDd6qGvN8ei6k5p0tvxSR171VmGyHuTiAOfxAbr8kA==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dev: true - /is-string/1.0.7: + /is-string@1.0.7: resolution: {integrity: sha512-tE2UXzivje6ofPW7l23cjDOMa09gb7xlAqG6jG5ej6uPV32TlWP3NKPigtaGeHNu9fohccRYvIiZMfOOnOYUtg==} engines: {node: '>= 0.4'} dependencies: has-tostringtag: 1.0.0 dev: true - /is-subset/0.1.1: + /is-subset@0.1.1: resolution: {integrity: sha512-6Ybun0IkarhmEqxXCNw/C0bna6Zb/TkfUX9UbwJtK6ObwAVCxmAP308WWTHviM/zAqXk05cdhYsUsZeGQh99iw==} dev: true - /is-symbol/1.0.4: + /is-symbol@1.0.4: resolution: {integrity: sha512-C/CPBqKWnvdcxqIARxyOh4v1UUEOCHpgDa0WYgpKDFMszcrPcffg5uhwSgPCLD2WWxmq6isisz87tzT01tuGhg==} engines: {node: '>= 0.4'} dependencies: has-symbols: 1.0.3 dev: true - /is-typed-array/1.1.10: + /is-typed-array@1.1.10: resolution: {integrity: sha512-PJqgEHiWZvMpaFZ3uTc8kHPM4+4ADTlDniuQL7cU/UDA0Ql7F70yGfHph3cLNe+c9toaigv+DFzTJKhc2CtO6A==} engines: {node: '>= 0.4'} dependencies: @@ -14891,111 +15790,111 @@ packages: has-tostringtag: 1.0.0 dev: true - /is-typedarray/1.0.0: + /is-typedarray@1.0.0: resolution: {integrity: sha512-cyA56iCMHAh5CdzjJIa4aohJyeO1YbwLi3Jc35MmRU6poroFjIGZzUzupGiRPOjgHg9TLu43xbpwXk523fMxKA==} dev: true - /is-unicode-supported/0.1.0: + /is-unicode-supported@0.1.0: resolution: {integrity: sha512-knxG2q4UC3u8stRGyAVJCOdxFmv5DZiRcdlIaAQXAbSfJya+OhopNotLQrstBhququ4ZpuKbDc/8S6mgXgPFPw==} engines: {node: '>=10'} dev: true - /is-unicode-supported/1.3.0: + /is-unicode-supported@1.3.0: resolution: {integrity: sha512-43r2mRvz+8JRIKnWJ+3j8JtjRKZ6GmjzfaE/qiBJnikNnYv/6bagRJ1kUhNk8R5EX/GkobD+r+sfxCPJsiKBLQ==} engines: {node: '>=12'} dev: true - /is-utf8/0.2.1: + /is-utf8@0.2.1: resolution: {integrity: sha512-rMYPYvCzsXywIsldgLaSoPlw5PfoB/ssr7hY4pLfcodrA5M/eArza1a9VmTiNIBNMjOGr1Ow9mTyU2o69U6U9Q==} dev: true optional: true - /is-weakmap/2.0.1: + /is-weakmap@2.0.1: resolution: {integrity: sha512-NSBR4kH5oVj1Uwvv970ruUkCV7O1mzgVFO4/rev2cLRda9Tm9HrL70ZPut4rOHgY0FNrUu9BCbXA2sdQ+x0chA==} dev: true - /is-weakref/1.0.2: + /is-weakref@1.0.2: resolution: {integrity: sha512-qctsuLZmIQ0+vSSMfoVvyFe2+GSEvnmZ2ezTup1SBse9+twCCeial6EEi3Nc2KFcf6+qz2FBPnjXsk8xhKSaPQ==} dependencies: call-bind: 1.0.2 dev: true - /is-weakset/2.0.2: + /is-weakset@2.0.2: resolution: {integrity: sha512-t2yVvttHkQktwnNNmBQ98AhENLdPUTDTE21uPqAQ0ARwQfGeQKRVS0NNurH7bTf7RrvcVn1OOge45CnBeHCSmg==} dependencies: call-bind: 1.0.2 get-intrinsic: 1.2.1 dev: true - /is-what/4.1.15: + /is-what@4.1.15: resolution: {integrity: sha512-uKua1wfy3Yt+YqsD6mTUEa2zSi3G1oPlqTflgaPJ7z63vUGN5pxFpnQfeSLMFnJDEsdvOtkp1rUWkYjB4YfhgA==} engines: {node: '>=12.13'} dev: true - /is-whitespace-character/1.0.4: + /is-whitespace-character@1.0.4: resolution: {integrity: sha512-SDweEzfIZM0SJV0EUga669UTKlmL0Pq8Lno0QDQsPnvECB3IM2aP0gdx5TrU0A01MAPfViaZiI2V1QMZLaKK5w==} dev: true - /is-whitespace/0.3.0: + /is-whitespace@0.3.0: resolution: {integrity: sha512-RydPhl4S6JwAyj0JJjshWJEFG6hNye3pZFBRZaTUfZFwGHxzppNaNOVgQuS/E/SlhrApuMXrpnK1EEIXfdo3Dg==} engines: {node: '>=0.10.0'} dev: true - /is-window/1.0.2: + /is-window@1.0.2: resolution: {integrity: sha512-uj00kdXyZb9t9RcAUAwMZAnkBUwdYGhYlt7djMXhfyhUCzwNba50tIiBKR7q0l7tdoBtFVw/3JmLY6fI3rmZmg==} dev: true - /is-windows/1.0.2: + /is-windows@1.0.2: resolution: {integrity: sha512-eXK1UInq2bPmjyX6e3VHIzMLobc4J94i4AWn+Hpq3OU5KkrRC96OAcR3PRJ/pGu6m8TRnBHP9dkXQVsT/COVIA==} engines: {node: '>=0.10.0'} dev: true - /is-word-character/1.0.4: + /is-word-character@1.0.4: resolution: {integrity: sha512-5SMO8RVennx3nZrqtKwCGyyetPE9VDba5ugvKLaD4KopPG5kR4mQ7tNt/r7feL5yt5h3lpuBbIUmCOG2eSzXHA==} dev: true - /is-wsl/1.1.0: + /is-wsl@1.1.0: resolution: {integrity: sha512-gfygJYZ2gLTDlmbWMI0CE2MwnFzSN/2SZfkMlItC4K/JBlsWVDB0bO6XhqcY13YXE7iMcAJnzTCJjPiTeJJ0Mw==} engines: {node: '>=4'} dev: true - /is-wsl/2.2.0: + /is-wsl@2.2.0: resolution: {integrity: sha512-fKzAra0rGJUUBwGBgNkHZuToZcn+TtXHpeCgmkMJMMYx1sQDYaCSyjJBSCa2nH1DGm7s3n1oBnohoVTBaN7Lww==} engines: {node: '>=8'} dependencies: is-docker: 2.2.1 dev: true - /isarray/1.0.0: + /isarray@1.0.0: resolution: {integrity: sha512-VLghIWNM6ELQzo7zwmcg0NmTVyWKYjvIeM83yjp0wRDTmUnrM678fQbcKBo6n2CJEF0szoG//ytg+TKla89ALQ==} dev: true - /isarray/2.0.5: + /isarray@2.0.5: resolution: {integrity: sha512-xHjhDr3cNBK0BzdUJSPXZntQUx/mwMS5Rw4A7lPJ90XGAO6ISP/ePDNuo0vhqOZU+UD5JoodwCAAoZQd3FeAKw==} dev: true - /isexe/2.0.0: + /isexe@2.0.0: resolution: {integrity: sha512-RHxMLp9lnKHGHRng9QFhRCMbYAcVpn69smSGcq3f36xjgVVWThj4qqLbTLlq7Ssj8B+fIQ1EuCEGI2lKsyQeIw==} dev: true - /isobject/2.1.0: + /isobject@2.1.0: resolution: {integrity: sha512-+OUdGJlgjOBZDfxnDjYYG6zp487z0JGNQq3cYQYg5f5hKR+syHMsaztzGeml/4kGG55CSpKSpWTY+jYGgsHLgA==} engines: {node: '>=0.10.0'} dependencies: isarray: 1.0.0 dev: true - /isobject/3.0.1: + /isobject@3.0.1: resolution: {integrity: sha512-WhB9zCku7EGTj/HQQRz5aUQEUeoQZH2bWcltRErOpymJ4boYE6wL9Tbr23krRPSZ+C5zqNSrSw+Cc7sZZ4b7vg==} engines: {node: '>=0.10.0'} dev: true - /isobject/4.0.0: + /isobject@4.0.0: resolution: {integrity: sha512-S/2fF5wH8SJA/kmwr6HYhK/RI/OkhD84k8ntalo0iJjZikgq1XFvR5M8NPT1x5F7fBwCG3qHfnzeP/Vh/ZxCUA==} engines: {node: '>=0.10.0'} dev: true - /isomorphic-unfetch/3.1.0: + /isomorphic-unfetch@3.1.0: resolution: {integrity: sha512-geDJjpoZ8N0kWexiwkX8F9NkTsXhetLPVbZFQ+JTW239QNOwvB0gniuR1Wc6f0AMTn7/mFGyXvHTifrCp/GH8Q==} dependencies: node-fetch: 2.6.12 @@ -15004,15 +15903,15 @@ packages: - encoding dev: true - /isstream/0.1.2: + /isstream@0.1.2: resolution: {integrity: sha512-Yljz7ffyPbrLpLngrMtZ7NduUgVvi6wG9RJ9IUcyCd59YQ911PBJphODUcbOVbqYfxe1wuYf/LJ8PauMRwsM/g==} dev: true - /istanbul-lib-coverage/3.2.0: + /istanbul-lib-coverage@3.2.0: resolution: {integrity: sha512-eOeJ5BHCmHYvQK7xt9GkdHuzuCGS1Y6g9Gvnx3Ym33fz/HpLRYxiS0wHNr+m/MBC8B647Xt608vCDEvhl9c6Mw==} engines: {node: '>=8'} - /istanbul-lib-instrument/5.2.1: + /istanbul-lib-instrument@5.2.1: resolution: {integrity: sha512-pzqtp31nLv/XFOzXGuvhCb8qhjmTVo5vjVk19XE4CRlSWz0KoeJ3bw9XsA7nOp9YBf4qHjwBxkDzKcME/J29Yg==} engines: {node: '>=8'} dependencies: @@ -15025,7 +15924,7 @@ packages: - supports-color dev: true - /istanbul-lib-report/3.0.0: + /istanbul-lib-report@3.0.0: resolution: {integrity: sha512-wcdi+uAKzfiGT2abPpKZ0hSU1rGQjUQnLvtY5MpQ7QCTahD3VODhcu4wcfY1YtkGaDD5yuydOLINXsfbus9ROw==} engines: {node: '>=8'} dependencies: @@ -15033,36 +15932,35 @@ packages: make-dir: 4.0.0 supports-color: 7.2.0 - /istanbul-lib-source-maps/4.0.1: + /istanbul-lib-source-maps@4.0.1: resolution: {integrity: sha512-n3s8EwkdFIJCG3BPKBYvskgXGoy88ARzvegkitk60NxRdwltLOTaH7CUiMRXvwYorl0Q712iEjcWB+fK/MrWVw==} engines: {node: '>=10'} dependencies: - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) istanbul-lib-coverage: 3.2.0 source-map: 0.6.1 transitivePeerDependencies: - supports-color - dev: false - /istanbul-reports/3.1.5: + /istanbul-reports@3.1.5: resolution: {integrity: sha512-nUsEMa9pBt/NOHqbcbeJEgqIlY/K7rVWUX6Lql2orY5e9roQOthbR3vtY4zzf2orPELg80fnxxk9zUyPlgwD1w==} engines: {node: '>=8'} dependencies: html-escaper: 2.0.2 istanbul-lib-report: 3.0.1 - /iterate-iterator/1.0.2: + /iterate-iterator@1.0.2: resolution: {integrity: sha512-t91HubM4ZDQ70M9wqp+pcNpu8OyJ9UAtXntT/Bcsvp5tZMnz9vRa+IunKXeI8AnfZMTv0jNuVEmGeLSMjVvfPw==} dev: true - /iterate-value/1.0.2: + /iterate-value@1.0.2: resolution: {integrity: sha512-A6fMAio4D2ot2r/TYzr4yUWrmwNdsN5xL7+HUiyACE4DXm+q8HtPcnFTp+NnW3k4N05tZ7FVYFFb2CR13NxyHQ==} dependencies: es-get-iterator: 1.1.3 iterate-iterator: 1.0.2 dev: true - /jackspeak/2.2.1: + /jackspeak@2.2.1: resolution: {integrity: sha512-MXbxovZ/Pm42f6cDIDkl3xpwv1AGwObKwfmjs2nQePiy85tP3fatofl3FC1aBsOtP/6fq5SbtgHwWcMsLP+bDw==} engines: {node: '>=14'} dependencies: @@ -15071,7 +15969,7 @@ packages: '@pkgjs/parseargs': 0.11.0 dev: true - /jake/10.8.7: + /jake@10.8.7: resolution: {integrity: sha512-ZDi3aP+fG/LchyBzUM804VjddnwfSfsdeYkwt8NcbKRvo4rFkjhs456iLFn3k2ZUWvNe4i48WACDbza8fhq2+w==} engines: {node: '>=10'} hasBin: true @@ -15082,7 +15980,124 @@ packages: minimatch: 3.1.2 dev: true - /jest-diff/29.6.1: + /jest-changed-files@27.5.1: + resolution: {integrity: sha512-buBLMiByfWGCoMsLLzGUUSpAmIAGnbR2KJoMN10ziLhOLvP4e0SlypHnAel8iqQXTrcbmfEY9sSqae5sgUsTvw==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@jest/types': 27.5.1 + execa: 5.1.1 + throat: 6.0.2 + dev: true + + /jest-circus@27.5.1: + resolution: {integrity: sha512-D95R7x5UtlMA5iBYsOHFFbMD/GVA4R/Kdq15f7xYWUfWHBto9NYRsOvnSauTgdF+ogCpJ4tyKOXhUifxS65gdw==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@jest/environment': 27.5.1 + '@jest/test-result': 27.5.1 + '@jest/types': 27.5.1 + '@types/node': 20.4.1 + chalk: 4.1.2 + co: 4.6.0 + dedent: 0.7.0 + expect: 27.5.1 + is-generator-fn: 2.1.0 + jest-each: 27.5.1 + jest-matcher-utils: 27.5.1 + jest-message-util: 27.5.1 + jest-runtime: 27.5.1 + jest-snapshot: 27.5.1 + jest-util: 27.5.1 + pretty-format: 27.5.1 + slash: 3.0.0 + stack-utils: 2.0.6 + throat: 6.0.2 + transitivePeerDependencies: + - supports-color + dev: true + + /jest-cli@27.5.1(ts-node@10.9.1): + resolution: {integrity: sha512-Hc6HOOwYq4/74/c62dEE3r5elx8wjYqxY0r0G/nFrLDPMFRu6RA/u8qINOIkvhxG7mMQ5EJsOGfRpI8L6eFUVw==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + hasBin: true + peerDependencies: + node-notifier: ^8.0.1 || ^9.0.0 || ^10.0.0 + peerDependenciesMeta: + node-notifier: + optional: true + dependencies: + '@jest/core': 27.5.1(ts-node@10.9.1) + '@jest/test-result': 27.5.1 + '@jest/types': 27.5.1 + chalk: 4.1.2 + exit: 0.1.2 + graceful-fs: 4.2.11 + import-local: 3.1.0 + jest-config: 27.5.1(ts-node@10.9.1) + jest-util: 27.5.1 + jest-validate: 27.5.1 + prompts: 2.4.2 + yargs: 16.2.0 + transitivePeerDependencies: + - bufferutil + - canvas + - supports-color + - ts-node + - utf-8-validate + dev: true + + /jest-config@27.5.1(ts-node@10.9.1): + resolution: {integrity: sha512-5sAsjm6tGdsVbW9ahcChPAFCk4IlkQUknH5AvKjuLTSlcO/wCZKyFdn7Rg0EkC+OGgWODEy2hDpWB1PgzH0JNA==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + peerDependencies: + ts-node: '>=9.0.0' + peerDependenciesMeta: + ts-node: + optional: true + dependencies: + '@babel/core': 7.22.8 + '@jest/test-sequencer': 27.5.1 + '@jest/types': 27.5.1 + babel-jest: 27.5.1(@babel/core@7.22.8) + chalk: 4.1.2 + ci-info: 3.8.0 + deepmerge: 4.3.1 + glob: 7.2.3 + graceful-fs: 4.2.11 + jest-circus: 27.5.1 + jest-environment-jsdom: 27.5.1 + jest-environment-node: 27.5.1 + jest-get-type: 27.5.1 + jest-jasmine2: 27.5.1 + jest-regex-util: 27.5.1 + jest-resolve: 27.5.1 + jest-runner: 27.5.1 + jest-util: 27.5.1 + jest-validate: 27.5.1 + micromatch: 4.0.5 + parse-json: 5.2.0 + pretty-format: 27.5.1 + slash: 3.0.0 + strip-json-comments: 3.1.1 + ts-node: 10.9.1(@types/node@18.16.19)(typescript@5.1.6) + transitivePeerDependencies: + - bufferutil + - canvas + - supports-color + - utf-8-validate + dev: true + + /jest-diff@27.5.1: + resolution: {integrity: sha512-m0NvkX55LDt9T4mctTEgnZk3fmEg3NRYutvMPWM/0iPnkFj2wIeF45O1718cMSOFO1vINkqmxqD8vE37uTEbqw==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + chalk: 4.1.2 + diff-sequences: 27.5.1 + jest-get-type: 27.5.1 + pretty-format: 27.5.1 + dev: true + + /jest-diff@29.6.1: resolution: {integrity: sha512-FsNCvinvl8oVxpNLttNQX7FAq7vR+gMDGj90tiP7siWw1UdakWUGqrylpsYrpvj908IYckm5Y0Q7azNAozU1Kg==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: @@ -15092,12 +16107,65 @@ packages: pretty-format: 29.6.1 dev: true - /jest-get-type/29.4.3: + /jest-docblock@27.5.1: + resolution: {integrity: sha512-rl7hlABeTsRYxKiUfpHrQrG4e2obOiTQWfMEH3PxPjOtdsfLQO4ReWSZaQ7DETm4xu07rl4q/h4zcKXyU0/OzQ==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + detect-newline: 3.1.0 + dev: true + + /jest-each@27.5.1: + resolution: {integrity: sha512-1Ff6p+FbhT/bXQnEouYy00bkNSY7OUpfIcmdl8vZ31A1UUaurOLPA8a8BbJOF2RDUElwJhmeaV7LnagI+5UwNQ==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@jest/types': 27.5.1 + chalk: 4.1.2 + jest-get-type: 27.5.1 + jest-util: 27.5.1 + pretty-format: 27.5.1 + dev: true + + /jest-environment-jsdom@27.5.1: + resolution: {integrity: sha512-TFBvkTC1Hnnnrka/fUb56atfDtJ9VMZ94JkjTbggl1PEpwrYtUBKMezB3inLmWqQsXYLcMwNoDQwoBTAvFfsfw==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@jest/environment': 27.5.1 + '@jest/fake-timers': 27.5.1 + '@jest/types': 27.5.1 + '@types/node': 20.4.1 + jest-mock: 27.5.1 + jest-util: 27.5.1 + jsdom: 16.7.0 + transitivePeerDependencies: + - bufferutil + - canvas + - supports-color + - utf-8-validate + dev: true + + /jest-environment-node@27.5.1: + resolution: {integrity: sha512-Jt4ZUnxdOsTGwSRAfKEnE6BcwsSPNOijjwifq5sDFSA2kesnXTvNqKHYgM0hDq3549Uf/KzdXNYn4wMZJPlFLw==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@jest/environment': 27.5.1 + '@jest/fake-timers': 27.5.1 + '@jest/types': 27.5.1 + '@types/node': 20.4.1 + jest-mock: 27.5.1 + jest-util: 27.5.1 + dev: true + + /jest-get-type@27.5.1: + resolution: {integrity: sha512-2KY95ksYSaK7DMBWQn6dQz3kqAf3BB64y2udeG+hv4KfSOb9qwcYQstTJc1KCbsix+wLZWZYN8t7nwX3GOBLRw==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dev: true + + /jest-get-type@29.4.3: resolution: {integrity: sha512-J5Xez4nRRMjk8emnTpWrlkyb9pfRQQanDrvWHhsR1+VUfbwxi30eVcZFlcdGInRibU4G5LwHXpI7IRHU0CY+gg==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dev: true - /jest-haste-map/26.6.2: + /jest-haste-map@26.6.2: resolution: {integrity: sha512-easWIJXIw71B2RdR8kgqpjQrbMRWQBgiBwXYEhtGUTaX+doCjBheluShdDMeR8IMfJiTqH4+zfhtg29apJf/8w==} engines: {node: '>= 10.14.2'} dependencies: @@ -15120,7 +16188,27 @@ packages: - supports-color dev: true - /jest-image-snapshot/4.5.1: + /jest-haste-map@27.5.1: + resolution: {integrity: sha512-7GgkZ4Fw4NFbMSDSpZwXeBiIbx+t/46nJ2QitkOjvwPYyZmqttu2TDSimMHP1EkPOi4xUZAN1doE5Vd25H4Jng==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@jest/types': 27.5.1 + '@types/graceful-fs': 4.1.6 + '@types/node': 20.4.1 + anymatch: 3.1.3 + fb-watchman: 2.0.2 + graceful-fs: 4.2.11 + jest-regex-util: 27.5.1 + jest-serializer: 27.5.1 + jest-util: 27.5.1 + jest-worker: 27.5.1 + micromatch: 4.0.5 + walker: 1.0.8 + optionalDependencies: + fsevents: 2.3.2 + dev: true + + /jest-image-snapshot@4.5.1(jest@27.5.1): resolution: {integrity: sha512-0YkgupgkkCx0wIZkxvqs/oNiUT0X0d2WTpUhaAp+Dy6CpqBUZMRTIZo4KR1f+dqmx6WXrLCvecjnHLIsLkI+gQ==} engines: {node: '>= 10.14.2'} peerDependencies: @@ -15129,6 +16217,7 @@ packages: chalk: 1.1.3 get-stdin: 5.0.1 glur: 1.1.2 + jest: 27.5.1(ts-node@10.9.1) lodash: 4.17.21 mkdirp: 0.5.6 pixelmatch: 5.3.0 @@ -15137,7 +16226,50 @@ packages: ssim.js: 3.5.0 dev: true - /jest-matcher-utils/29.6.1: + /jest-jasmine2@27.5.1: + resolution: {integrity: sha512-jtq7VVyG8SqAorDpApwiJJImd0V2wv1xzdheGHRGyuT7gZm6gG47QEskOlzsN1PG/6WNaCo5pmwMHDf3AkG2pQ==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@jest/environment': 27.5.1 + '@jest/source-map': 27.5.1 + '@jest/test-result': 27.5.1 + '@jest/types': 27.5.1 + '@types/node': 20.4.1 + chalk: 4.1.2 + co: 4.6.0 + expect: 27.5.1 + is-generator-fn: 2.1.0 + jest-each: 27.5.1 + jest-matcher-utils: 27.5.1 + jest-message-util: 27.5.1 + jest-runtime: 27.5.1 + jest-snapshot: 27.5.1 + jest-util: 27.5.1 + pretty-format: 27.5.1 + throat: 6.0.2 + transitivePeerDependencies: + - supports-color + dev: true + + /jest-leak-detector@27.5.1: + resolution: {integrity: sha512-POXfWAMvfU6WMUXftV4HolnJfnPOGEu10fscNCA76KBpRRhcMN2c8d3iT2pxQS3HLbA+5X4sOUPzYO2NUyIlHQ==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + jest-get-type: 27.5.1 + pretty-format: 27.5.1 + dev: true + + /jest-matcher-utils@27.5.1: + resolution: {integrity: sha512-z2uTx/T6LBaCoNWNFWwChLBKYxTMcGBRjAt+2SbP929/Fflb9aa5LGma654Rz8z9HLxsrUaYzxE9T/EFIL/PAw==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + chalk: 4.1.2 + jest-diff: 27.5.1 + jest-get-type: 27.5.1 + pretty-format: 27.5.1 + dev: true + + /jest-matcher-utils@29.6.1: resolution: {integrity: sha512-SLaztw9d2mfQQKHmJXKM0HCbl2PPVld/t9Xa6P9sgiExijviSp7TnZZpw2Fpt+OI3nwUO/slJbOfzfUMKKC5QA==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: @@ -15147,7 +16279,22 @@ packages: pretty-format: 29.6.1 dev: true - /jest-message-util/29.6.1: + /jest-message-util@27.5.1: + resolution: {integrity: sha512-rMyFe1+jnyAAf+NHwTclDz0eAaLkVDdKVHHBFWsBWHnnh5YeJMNWWsv7AbFYXfK3oTqvL7VTWkhNLu1jX24D+g==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@babel/code-frame': 7.22.5 + '@jest/types': 27.5.1 + '@types/stack-utils': 2.0.1 + chalk: 4.1.2 + graceful-fs: 4.2.11 + micromatch: 4.0.5 + pretty-format: 27.5.1 + slash: 3.0.0 + stack-utils: 2.0.6 + dev: true + + /jest-message-util@29.6.1: resolution: {integrity: sha512-KoAW2zAmNSd3Gk88uJ56qXUWbFk787QKmjjJVOjtGFmmGSZgDBrlIL4AfQw1xyMYPNVD7dNInfIbur9B2rd/wQ==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: @@ -15162,12 +16309,126 @@ packages: stack-utils: 2.0.6 dev: true - /jest-regex-util/26.0.0: + /jest-mock@27.5.1: + resolution: {integrity: sha512-K4jKbY1d4ENhbrG2zuPWaQBvDly+iZ2yAW+T1fATN78hc0sInwn7wZB8XtlNnvHug5RMwV897Xm4LqmPM4e2Og==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@jest/types': 27.5.1 + '@types/node': 20.4.1 + dev: true + + /jest-pnp-resolver@1.2.3(jest-resolve@27.5.1): + resolution: {integrity: sha512-+3NpwQEnRoIBtx4fyhblQDPgJI0H1IEIkX7ShLUjPGA7TtUTvI1oiKi3SR4oBR0hQhQR80l4WAe5RrXBwWMA8w==} + engines: {node: '>=6'} + peerDependencies: + jest-resolve: '*' + peerDependenciesMeta: + jest-resolve: + optional: true + dependencies: + jest-resolve: 27.5.1 + dev: true + + /jest-regex-util@26.0.0: resolution: {integrity: sha512-Gv3ZIs/nA48/Zvjrl34bf+oD76JHiGDUxNOVgUjh3j890sblXryjY4rss71fPtD/njchl6PSE2hIhvyWa1eT0A==} engines: {node: '>= 10.14.2'} dev: true - /jest-serializer/26.6.2: + /jest-regex-util@27.5.1: + resolution: {integrity: sha512-4bfKq2zie+x16okqDXjXn9ql2B0dScQu+vcwe4TvFVhkVyuWLqpZrZtXxLLWoXYgn0E87I6r6GRYHF7wFZBUvg==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dev: true + + /jest-resolve-dependencies@27.5.1: + resolution: {integrity: sha512-QQOOdY4PE39iawDn5rzbIePNigfe5B9Z91GDD1ae/xNDlu9kaat8QQ5EKnNmVWPV54hUdxCVwwj6YMgR2O7IOg==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@jest/types': 27.5.1 + jest-regex-util: 27.5.1 + jest-snapshot: 27.5.1 + transitivePeerDependencies: + - supports-color + dev: true + + /jest-resolve@27.5.1: + resolution: {integrity: sha512-FFDy8/9E6CV83IMbDpcjOhumAQPDyETnU2KZ1O98DwTnz8AOBsW/Xv3GySr1mOZdItLR+zDZ7I/UdTFbgSOVCw==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@jest/types': 27.5.1 + chalk: 4.1.2 + graceful-fs: 4.2.11 + jest-haste-map: 27.5.1 + jest-pnp-resolver: 1.2.3(jest-resolve@27.5.1) + jest-util: 27.5.1 + jest-validate: 27.5.1 + resolve: 1.22.2 + resolve.exports: 1.1.1 + slash: 3.0.0 + dev: true + + /jest-runner@27.5.1: + resolution: {integrity: sha512-g4NPsM4mFCOwFKXO4p/H/kWGdJp9V8kURY2lX8Me2drgXqG7rrZAx5kv+5H7wtt/cdFIjhqYx1HrlqWHaOvDaQ==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@jest/console': 27.5.1 + '@jest/environment': 27.5.1 + '@jest/test-result': 27.5.1 + '@jest/transform': 27.5.1 + '@jest/types': 27.5.1 + '@types/node': 20.4.1 + chalk: 4.1.2 + emittery: 0.8.1 + graceful-fs: 4.2.11 + jest-docblock: 27.5.1 + jest-environment-jsdom: 27.5.1 + jest-environment-node: 27.5.1 + jest-haste-map: 27.5.1 + jest-leak-detector: 27.5.1 + jest-message-util: 27.5.1 + jest-resolve: 27.5.1 + jest-runtime: 27.5.1 + jest-util: 27.5.1 + jest-worker: 27.5.1 + source-map-support: 0.5.21 + throat: 6.0.2 + transitivePeerDependencies: + - bufferutil + - canvas + - supports-color + - utf-8-validate + dev: true + + /jest-runtime@27.5.1: + resolution: {integrity: sha512-o7gxw3Gf+H2IGt8fv0RiyE1+r83FJBRruoA+FXrlHw6xEyBsU8ugA6IPfTdVyA0w8HClpbK+DGJxH59UrNMx8A==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@jest/environment': 27.5.1 + '@jest/fake-timers': 27.5.1 + '@jest/globals': 27.5.1 + '@jest/source-map': 27.5.1 + '@jest/test-result': 27.5.1 + '@jest/transform': 27.5.1 + '@jest/types': 27.5.1 + chalk: 4.1.2 + cjs-module-lexer: 1.2.3 + collect-v8-coverage: 1.0.2 + execa: 5.1.1 + glob: 7.2.3 + graceful-fs: 4.2.11 + jest-haste-map: 27.5.1 + jest-message-util: 27.5.1 + jest-mock: 27.5.1 + jest-regex-util: 27.5.1 + jest-resolve: 27.5.1 + jest-snapshot: 27.5.1 + jest-util: 27.5.1 + slash: 3.0.0 + strip-bom: 4.0.0 + transitivePeerDependencies: + - supports-color + dev: true + + /jest-serializer@26.6.2: resolution: {integrity: sha512-S5wqyz0DXnNJPd/xfIzZ5Xnp1HrJWBczg8mMfMpN78OJ5eDxXyf+Ygld9wX1DnUWbIbhM1YDY95NjR4CBXkb2g==} engines: {node: '>= 10.14.2'} dependencies: @@ -15175,7 +16436,45 @@ packages: graceful-fs: 4.2.11 dev: true - /jest-util/26.6.2: + /jest-serializer@27.5.1: + resolution: {integrity: sha512-jZCyo6iIxO1aqUxpuBlwTDMkzOAJS4a3eYz3YzgxxVQFwLeSA7Jfq5cbqCY+JLvTDrWirgusI/0KwxKMgrdf7w==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@types/node': 20.4.1 + graceful-fs: 4.2.11 + dev: true + + /jest-snapshot@27.5.1: + resolution: {integrity: sha512-yYykXI5a0I31xX67mgeLw1DZ0bJB+gpq5IpSuCAoyDi0+BhgU/RIrL+RTzDmkNTchvDFWKP8lp+w/42Z3us5sA==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@babel/core': 7.22.8 + '@babel/generator': 7.22.7 + '@babel/plugin-syntax-typescript': 7.22.5(@babel/core@7.22.8) + '@babel/traverse': 7.22.8 + '@babel/types': 7.22.5 + '@jest/transform': 27.5.1 + '@jest/types': 27.5.1 + '@types/babel__traverse': 7.20.1 + '@types/prettier': 2.7.3 + babel-preset-current-node-syntax: 1.0.1(@babel/core@7.22.8) + chalk: 4.1.2 + expect: 27.5.1 + graceful-fs: 4.2.11 + jest-diff: 27.5.1 + jest-get-type: 27.5.1 + jest-haste-map: 27.5.1 + jest-matcher-utils: 27.5.1 + jest-message-util: 27.5.1 + jest-util: 27.5.1 + natural-compare: 1.4.0 + pretty-format: 27.5.1 + semver: 7.5.4 + transitivePeerDependencies: + - supports-color + dev: true + + /jest-util@26.6.2: resolution: {integrity: sha512-MDW0fKfsn0OI7MS7Euz6h8HNDXVQ0gaM9uW6RjfDmd1DAFcaxX9OqIakHIqhbnmF08Cf2DLDG+ulq8YQQ0Lp0Q==} engines: {node: '>= 10.14.2'} dependencies: @@ -15187,19 +16486,56 @@ packages: micromatch: 4.0.5 dev: true - /jest-util/29.6.1: - resolution: {integrity: sha512-NRFCcjc+/uO3ijUVyNOQJluf8PtGCe/W6cix36+M3cTFgiYqFOOW5MgN4JOOcvbUhcKTYVd1CvHz/LWi8d16Mg==} - engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} + /jest-util@27.5.1: + resolution: {integrity: sha512-Kv2o/8jNvX1MQ0KGtw480E/w4fBCDOnH6+6DmeKi6LZUIlKA5kwY0YNdlzaWTiVgxqAqik11QyxDOKk543aKXw==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@jest/types': 27.5.1 + '@types/node': 20.4.1 + chalk: 4.1.2 + ci-info: 3.8.0 + graceful-fs: 4.2.11 + picomatch: 2.3.1 + dev: true + + /jest-util@29.6.1: + resolution: {integrity: sha512-NRFCcjc+/uO3ijUVyNOQJluf8PtGCe/W6cix36+M3cTFgiYqFOOW5MgN4JOOcvbUhcKTYVd1CvHz/LWi8d16Mg==} + engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} + dependencies: + '@jest/types': 29.6.1 + '@types/node': 20.4.1 + chalk: 4.1.2 + ci-info: 3.8.0 + graceful-fs: 4.2.11 + picomatch: 2.3.1 + dev: true + + /jest-validate@27.5.1: + resolution: {integrity: sha512-thkNli0LYTmOI1tDB3FI1S1RTp/Bqyd9pTarJwL87OIBFuqEb5Apv5EaApEudYg4g86e3CT6kM0RowkhtEnCBQ==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + dependencies: + '@jest/types': 27.5.1 + camelcase: 6.3.0 + chalk: 4.1.2 + jest-get-type: 27.5.1 + leven: 3.1.0 + pretty-format: 27.5.1 + dev: true + + /jest-watcher@27.5.1: + resolution: {integrity: sha512-z676SuD6Z8o8qbmEGhoEUFOM1+jfEiL3DXHK/xgEiG2EyNYfFG60jluWcupY6dATjfEsKQuibReS1djInQnoVw==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: - '@jest/types': 29.6.1 + '@jest/test-result': 27.5.1 + '@jest/types': 27.5.1 '@types/node': 20.4.1 + ansi-escapes: 4.3.2 chalk: 4.1.2 - ci-info: 3.8.0 - graceful-fs: 4.2.11 - picomatch: 2.3.1 + jest-util: 27.5.1 + string-length: 4.0.2 dev: true - /jest-worker/26.6.2: + /jest-worker@26.6.2: resolution: {integrity: sha512-KWYVV1c4i+jbMpaBC+U++4Va0cp8OisU185o73T1vo99hqi7w8tSJfUXYswwqqrjzwxa6KpRK54WhPvwf5w6PQ==} engines: {node: '>= 10.13.0'} dependencies: @@ -15208,25 +16544,46 @@ packages: supports-color: 7.2.0 dev: true - /jest-worker/27.5.1: + /jest-worker@27.5.1: resolution: {integrity: sha512-7vuh85V5cdDofPyxn58nrPjBktZo0u9x1g8WtjQol+jZDaE+fhN+cIvTj11GndBnMnyfrUOG1sZQxCdjKh+DKg==} engines: {node: '>= 10.13.0'} dependencies: - '@types/node': 16.18.38 + '@types/node': 20.4.1 merge-stream: 2.0.0 supports-color: 8.1.1 dev: true - /jiti/1.19.1: + /jest@27.5.1(ts-node@10.9.1): + resolution: {integrity: sha512-Yn0mADZB89zTtjkPJEXwrac3LHudkQMR+Paqa8uxJHCBr9agxztUifWCyiYrjhMPBoUVBjyny0I7XH6ozDr7QQ==} + engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} + hasBin: true + peerDependencies: + node-notifier: ^8.0.1 || ^9.0.0 || ^10.0.0 + peerDependenciesMeta: + node-notifier: + optional: true + dependencies: + '@jest/core': 27.5.1(ts-node@10.9.1) + import-local: 3.1.0 + jest-cli: 27.5.1(ts-node@10.9.1) + transitivePeerDependencies: + - bufferutil + - canvas + - supports-color + - ts-node + - utf-8-validate + dev: true + + /jiti@1.19.1: resolution: {integrity: sha512-oVhqoRDaBXf7sjkll95LHVS6Myyyb1zaunVwk4Z0+WPSW4gjS0pl01zYKHScTuyEhQsFxV5L4DR5r+YqSyqyyg==} hasBin: true - /joycon/3.1.1: + /joycon@3.1.1: resolution: {integrity: sha512-34wB/Y7MW7bzjKRjUKTa46I2Z7eV62Rkhva+KkopW7Qvv/OSWBqvkSY7vusOPrNuZcUG3tApvdVgNB8POj3SPw==} engines: {node: '>=10'} dev: true - /js-beautify/1.14.6: + /js-beautify@1.14.6: resolution: {integrity: sha512-GfofQY5zDp+cuHc+gsEXKPpNw2KbPddreEo35O6jT6i0RVK6LhsoYBhq5TvK4/n74wnA0QbK8gGd+jUZwTMKJw==} engines: {node: '>=10'} hasBin: true @@ -15237,7 +16594,7 @@ packages: nopt: 6.0.0 dev: true - /js-beautify/1.14.8: + /js-beautify@1.14.8: resolution: {integrity: sha512-4S7HFeI9YfRvRgKnEweohs0tgJj28InHVIj4Nl8Htf96Y6pHg3+tJrmo4ucAM9f7l4SHbFI3IvFAZ2a1eQPbyg==} engines: {node: '>=12'} hasBin: true @@ -15248,24 +16605,24 @@ packages: nopt: 6.0.0 dev: true - /js-levenshtein/1.1.6: + /js-levenshtein@1.1.6: resolution: {integrity: sha512-X2BB11YZtrRqY4EnQcLX5Rh373zbK4alC1FW7D7MBhL2gtcC17cTnr6DmfHZeS0s2rTHjUTMMHfG7gO8SSdw+g==} engines: {node: '>=0.10.0'} dev: true - /js-sha3/0.8.0: + /js-sha3@0.8.0: resolution: {integrity: sha512-gF1cRrHhIzNfToc802P800N8PpXS+evLLXfsVpowqmAFR9uwbi89WvXg2QspOmXL8QL86J4T1EpFu+yUkwJY3Q==} dev: false - /js-string-escape/1.0.1: + /js-string-escape@1.0.1: resolution: {integrity: sha512-Smw4xcfIQ5LVjAOuJCvN/zIodzA/BBSsluuoSykP+lUvScIi4U6RJLfwHet5cxFnCswUjISV8oAXaqaJDY3chg==} engines: {node: '>= 0.8'} dev: true - /js-tokens/4.0.0: + /js-tokens@4.0.0: resolution: {integrity: sha512-RdJUflcE3cUzKiMqQgsCu06FPu9UdIJO0beYbPhHN4k6apgJtifcoCtT9bcxOpYBtpD2kCM6Sbzg4CausW/PKQ==} - /js-yaml/3.14.1: + /js-yaml@3.14.1: resolution: {integrity: sha512-okMH7OXXJ7YrN9Ok3/SXrnu4iX9yOk+25nqX4imS2npuvTYDmo/QEZoqwZkYaIDk3jVvBOTOIEgEhaLOynBS9g==} hasBin: true dependencies: @@ -15273,18 +16630,60 @@ packages: esprima: 4.0.1 dev: true - /js-yaml/4.1.0: + /js-yaml@4.1.0: resolution: {integrity: sha512-wpxZs9NoxZaJESJGIZTyDEaYpl0FKSA+FB9aJiyemKhMwkxQg63h4T1KJgUGHpTqPDNRcmmYLugrRjJlBtWvRA==} hasBin: true dependencies: argparse: 2.0.1 dev: true - /jsbn/0.1.1: + /jsbn@0.1.1: resolution: {integrity: sha512-UVU9dibq2JcFWxQPA6KCqj5O42VOmAY3zQUfEKxU0KpTGXwNoCjkX1e13eHNvw/xPynt6pU0rZ1htjWTNTSXsg==} dev: true - /jsdom/20.0.3: + /jsdom@16.7.0: + resolution: {integrity: sha512-u9Smc2G1USStM+s/x1ru5Sxrl6mPYCbByG1U/hUmqaVsm4tbNyS7CicOSRyuGQYZhTu0h84qkZZQ/I+dzizSVw==} + engines: {node: '>=10'} + peerDependencies: + canvas: ^2.5.0 + peerDependenciesMeta: + canvas: + optional: true + dependencies: + abab: 2.0.6 + acorn: 8.10.0 + acorn-globals: 6.0.0 + cssom: 0.4.4 + cssstyle: 2.3.0 + data-urls: 2.0.0 + decimal.js: 10.4.3 + domexception: 2.0.1 + escodegen: 2.1.0 + form-data: 3.0.1 + html-encoding-sniffer: 2.0.1 + http-proxy-agent: 4.0.1 + https-proxy-agent: 5.0.1 + is-potential-custom-element-name: 1.0.1 + nwsapi: 2.2.7 + parse5: 6.0.1 + saxes: 5.0.1 + symbol-tree: 3.2.4 + tough-cookie: 4.1.3 + w3c-hr-time: 1.0.2 + w3c-xmlserializer: 2.0.0 + webidl-conversions: 6.1.0 + whatwg-encoding: 1.0.5 + whatwg-mimetype: 2.3.0 + whatwg-url: 8.7.0 + ws: 7.5.9 + xml-name-validator: 3.0.0 + transitivePeerDependencies: + - bufferutil + - supports-color + - utf-8-validate + dev: true + + /jsdom@20.0.3: resolution: {integrity: sha512-SYhBvTh89tTfCD/CRdSOm13mOBa42iTaTyfyEWBdKcGdPxPtLFBXuHR8XHb33YNYaP+lLbmSvBTsnoesCNJEsQ==} engines: {node: '>=14'} peerDependencies: @@ -15325,7 +16724,7 @@ packages: - utf-8-validate dev: true - /jsdom/21.1.2: + /jsdom@21.1.2: resolution: {integrity: sha512-sCpFmK2jv+1sjff4u7fzft+pUh2KSUbUrEHYHyfSIbGTIcmnjyp83qg6qLwdJ/I3LpTXx33ACxeRL7Lsyc6lGQ==} engines: {node: '>=14'} peerDependencies: @@ -15366,7 +16765,7 @@ packages: - utf-8-validate dev: true - /jsdom/22.1.0: + /jsdom@22.1.0: resolution: {integrity: sha512-/9AVW7xNbsBv6GfWho4TTNjEo9fe6Zhf9O7s0Fhhr3u+awPwAJMKwAMXnkk5vBxflqLW9hTHX/0cs+P3gW+cQw==} engines: {node: '>=16'} peerDependencies: @@ -15404,66 +16803,66 @@ packages: - utf-8-validate dev: true - /jsesc/0.5.0: + /jsesc@0.5.0: resolution: {integrity: sha512-uZz5UnB7u4T9LvwmFqXii7pZSouaRPorGs5who1Ip7VO0wxanFvBL7GkM6dTHlgX+jhBApRetaWpnDabOeTcnA==} hasBin: true dev: true - /jsesc/2.5.2: + /jsesc@2.5.2: resolution: {integrity: sha512-OYu7XEzjkCQ3C5Ps3QIZsQfNpqoJyZZA99wd9aWd05NCtC5pWOkShK2mkL6HXQR6/Cy2lbNdPlZBpuQHXE63gA==} engines: {node: '>=4'} hasBin: true - /jsesc/3.0.2: + /jsesc@3.0.2: resolution: {integrity: sha512-xKqzzWXDttJuOcawBt4KnKHHIf5oQ/Cxax+0PWFG+DFDgHNAdi+TXECADI+RYiFUMmx8792xsMbbgXj4CwnP4g==} engines: {node: '>=6'} hasBin: true dev: true - /json-buffer/3.0.1: + /json-buffer@3.0.1: resolution: {integrity: sha512-4bV5BfR2mqfQTJm+V5tPPdf+ZpuhiIvTuAB5g8kcrXOZpTT/QwwVRWBywX1ozr6lEuPdbHxwaJlm9G6mI2sfSQ==} dev: true - /json-parse-better-errors/1.0.2: + /json-parse-better-errors@1.0.2: resolution: {integrity: sha512-mrqyZKfX5EhL7hvqcV6WG1yYjnjeuYDzDhhcAAUrq8Po85NBQBJP+ZDUT75qZQ98IkUoBqdkExkukOU7Ts2wrw==} dev: true - /json-parse-even-better-errors/2.3.1: + /json-parse-even-better-errors@2.3.1: resolution: {integrity: sha512-xyFwyhro/JEof6Ghe2iz2NcXoj2sloNsWr/XsERDK/oiPCfaNhl5ONfp+jQdAZRQQ0IJWNzH9zIZF7li91kh2w==} - /json-schema-traverse/0.4.1: + /json-schema-traverse@0.4.1: resolution: {integrity: sha512-xbbCH5dCYU5T8LcEhhuh7HJ88HXuW3qsI3Y0zOZFKfZEHcpWiHU/Jxzk629Brsab/mMiHQti9wMP+845RPe3Vg==} dev: true - /json-schema-traverse/1.0.0: + /json-schema-traverse@1.0.0: resolution: {integrity: sha512-NM8/P9n3XjXhIZn1lLhkFaACTOURQXjWhV4BA/RnOv8xvgqtqpAX9IO4mRQxSx1Rlo4tqzeqb0sOlruaOy3dug==} dev: true - /json-schema/0.4.0: + /json-schema@0.4.0: resolution: {integrity: sha512-es94M3nTIfsEPisRafak+HDLfHXnKBhV3vU5eqPcS3flIWqcxJWgXHXiey3YrpaNsanY5ei1VoYEbOzijuq9BA==} dev: true - /json-stable-stringify-without-jsonify/1.0.1: + /json-stable-stringify-without-jsonify@1.0.1: resolution: {integrity: sha512-Bdboy+l7tA3OGW6FjyFHWkP5LuByj1Tk33Ljyq0axyzdk9//JSi2u3fP1QSmd1KNwq6VOKYGlAu87CisVir6Pw==} dev: true - /json-stringify-safe/5.0.1: + /json-stringify-safe@5.0.1: resolution: {integrity: sha512-ZClg6AaYvamvYEE82d3Iyd3vSSIjQ+odgjaTzRuO3s7toCdFKczob2i0zCh7JE8kWn17yvAWhUVxvqGwUalsRA==} dev: true - /json5/1.0.2: + /json5@1.0.2: resolution: {integrity: sha512-g1MWMLBiz8FKi1e4w0UyVL3w+iJceWAFBAaBnnGKOpNa5f8TLktkbre1+s6oICydWAm+HRUGTmI+//xv2hvXYA==} hasBin: true dependencies: minimist: 1.2.8 dev: true - /json5/2.2.3: + /json5@2.2.3: resolution: {integrity: sha512-XmOWe7eyHYH14cLdVPoyg+GOH3rYX++KpzrylJwSW98t3Nk+U8XOl8FWKOgwtzdb8lXGf6zYwDUzeHMWfxasyg==} engines: {node: '>=6'} hasBin: true - /jsonc-eslint-parser/2.3.0: + /jsonc-eslint-parser@2.3.0: resolution: {integrity: sha512-9xZPKVYp9DxnM3sd1yAsh/d59iIaswDkai8oTxbursfKYbg/ibjX0IzFt35+VZ8iEW453TVTXztnRvYUQlAfUQ==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dependencies: @@ -15473,10 +16872,10 @@ packages: semver: 7.5.4 dev: true - /jsonc-parser/3.2.0: + /jsonc-parser@3.2.0: resolution: {integrity: sha512-gfFQZrcTc8CnKXp6Y4/CBT3fTc0OVuDofpre4aEeEpSBPV5X5v4+Vmx+8snU7RLPrNHPKSgLxGo9YuQzz20o+w==} - /jsonfile/6.1.0: + /jsonfile@6.1.0: resolution: {integrity: sha512-5dgndWOriYSm5cnYaJNhalLNDKOqFwyDB/rr1E9ZsGciGvKPs8R2xYGCacuf3z6K1YKDz182fd+fY3cn3pMqXQ==} dependencies: universalify: 2.0.0 @@ -15484,12 +16883,12 @@ packages: graceful-fs: 4.2.11 dev: true - /jsonpointer/5.0.1: + /jsonpointer@5.0.1: resolution: {integrity: sha512-p/nXbhSEcu3pZRdkW1OfJhpsVtW1gd4Wa1fnQc9YLiTfAjn0312eMKimbdIQzuZl9aa9xUGaRlP9T/CJE/ditQ==} engines: {node: '>=0.10.0'} dev: true - /jsprim/2.0.2: + /jsprim@2.0.2: resolution: {integrity: sha512-gqXddjPqQ6G40VdnI6T6yObEC+pDNvyP95wdQhkWkg7crHH3km5qP1FsOXEkzEQwnz6gz5qGTn1c2Y52wP3OyQ==} engines: {'0': node >=0.6.0} dependencies: @@ -15499,71 +16898,71 @@ packages: verror: 1.10.0 dev: true - /junk/3.1.0: + /junk@3.1.0: resolution: {integrity: sha512-pBxcB3LFc8QVgdggvZWyeys+hnrNWg4OcZIU/1X59k5jQdLBlCsYGRQaz234SqoRLTCgMH00fY0xRJH+F9METQ==} engines: {node: '>=8'} dev: true - /keyv/4.5.2: + /keyv@4.5.2: resolution: {integrity: sha512-5MHbFaKn8cNSmVW7BYnijeAVlE4cYA/SVkifVgrh7yotnfhKmjuXpDKjrABLnT0SfHWV21P8ow07OGfRrNDg8g==} dependencies: json-buffer: 3.0.1 dev: true - /kind-of/3.2.2: + /kind-of@3.2.2: resolution: {integrity: sha512-NOW9QQXMoZGg/oqnVNoNTTIFEIid1627WCffUBJEdMxYApq7mNE7CpzucIPc+ZQg25Phej7IJSmX3hO+oblOtQ==} engines: {node: '>=0.10.0'} dependencies: is-buffer: 1.1.6 dev: true - /kind-of/4.0.0: + /kind-of@4.0.0: resolution: {integrity: sha512-24XsCxmEbRwEDbz/qz3stgin8TTzZ1ESR56OMCN0ujYg+vRutNSiOj9bHH9u85DKgXguraugV5sFuvbD4FW/hw==} engines: {node: '>=0.10.0'} dependencies: is-buffer: 1.1.6 dev: true - /kind-of/5.1.0: + /kind-of@5.1.0: resolution: {integrity: sha512-NGEErnH6F2vUuXDh+OlbcKW7/wOcfdRHaZ7VWtqCztfHri/++YKmP51OdWeGPuqCOba6kk2OTe5d02VmTB80Pw==} engines: {node: '>=0.10.0'} dev: true - /kind-of/6.0.3: + /kind-of@6.0.3: resolution: {integrity: sha512-dcS1ul+9tmeD95T+x28/ehLgd9mENa3LsvDTtzm3vyBEO7RPptvAD+t44WVXaUjTBRcrpFeFlC8WCruUR456hw==} engines: {node: '>=0.10.0'} dev: true - /kleur/3.0.3: + /kleur@3.0.3: resolution: {integrity: sha512-eTIzlVOSUR+JxdDFepEYcBMtZ9Qqdef+rnzWdRZuMbOywu5tO2w2N7rqjoANZ5k9vywhL6Br1VRjUIgTQx4E8w==} engines: {node: '>=6'} dev: true - /kleur/4.1.5: + /kleur@4.1.5: resolution: {integrity: sha512-o+NO+8WrRiQEE4/7nwRJhN1HWpVmJm511pBHUxPLtp0BUISzlBplORYSmTclCnJvQq2tKu/sgl3xVpkc7ZWuQQ==} engines: {node: '>=6'} dev: true - /klona/2.0.6: + /klona@2.0.6: resolution: {integrity: sha512-dhG34DXATL5hSxJbIexCft8FChFXtmskoZYnoPWjXQuebWYCNkVeV3KkGegCK9CP1oswI/vQibS2GY7Em/sJJA==} engines: {node: '>= 8'} dev: true - /kolorist/1.8.0: + /kolorist@1.8.0: resolution: {integrity: sha512-Y+60/zizpJ3HRH8DCss+q95yr6145JXZo46OTpFvDZWLfRCE4qChOyk1b26nMaNpfHHgxagk9dXT5OP0Tfe+dQ==} dev: true - /ky/0.33.3: + /ky@0.33.3: resolution: {integrity: sha512-CasD9OCEQSFIam2U8efFK81Yeg8vNMTBUqtMOHlrcWQHqUX3HeCl9Dr31u4toV7emlH8Mymk5+9p0lL6mKb/Xw==} engines: {node: '>=14.16'} dev: true - /lazy-ass/1.6.0: + /lazy-ass@1.6.0: resolution: {integrity: sha512-cc8oEVoctTvsFZ/Oje/kGnHbpWHYBe8IAJe4C0QNc3t8uM/0Y8+erSz/7Y1ALuXTEZTMvxXwO6YbX1ey3ujiZw==} engines: {node: '> 0.8'} dev: true - /lazy-universal-dotenv/3.0.1: + /lazy-universal-dotenv@3.0.1: resolution: {integrity: sha512-prXSYk799h3GY3iOWnC6ZigYzMPjxN2svgjJ9shk7oMadSNX3wXy0B6F32PMJv7qtMnrIbUxoEHzbutvxR2LBQ==} engines: {node: '>=6.0.0', npm: '>=6.0.0', yarn: '>=1.0.0'} dependencies: @@ -15574,19 +16973,19 @@ packages: dotenv-expand: 5.1.0 dev: true - /lazystream/1.0.1: + /lazystream@1.0.1: resolution: {integrity: sha512-b94GiNHQNy6JNTrt5w6zNyffMrNkXZb3KTkCZJb2V1xaEGCk093vkZ2jk3tpaeP33/OiXC+WvK9AxUebnf5nbw==} engines: {node: '>= 0.6.3'} dependencies: readable-stream: 2.3.8 dev: true - /leven/3.1.0: + /leven@3.1.0: resolution: {integrity: sha512-qsda+H8jTaUaN/x5vzW2rzc+8Rw4TAQ/4KjB46IwK5VH+IlVeeeje/EoZRpiXvIqjFgK84QffqPztGI3VBLG1A==} engines: {node: '>=6'} dev: true - /levn/0.4.1: + /levn@0.4.1: resolution: {integrity: sha512-+bT2uH4E5LGE7h/n3evcS/sQlJXCpIp6ym8OWJ5eV6+67Dsql/LaaT7qJBAt2rzfoa/5QBGBhxDix1dMt2kQKQ==} engines: {node: '>= 0.8.0'} dependencies: @@ -15594,7 +16993,7 @@ packages: type-check: 0.4.0 dev: true - /light-my-request/5.10.0: + /light-my-request@5.10.0: resolution: {integrity: sha512-ZU2D9GmAcOUculTTdH9/zryej6n8TzT+fNGdNtm6SDp5MMMpHrJJkvAdE3c6d8d2chE9i+a//dS9CWZtisknqA==} dependencies: cookie: 0.5.0 @@ -15602,7 +17001,7 @@ packages: set-cookie-parser: 2.6.0 dev: true - /lighthouse-logger/1.4.2: + /lighthouse-logger@1.4.2: resolution: {integrity: sha512-gPWxznF6TKmUHrOQjlVo2UbaL2EJ71mb2CCeRs/2qBpi4L/g4LUVc9+3lKQ6DTUZwJswfM7ainGrLO1+fOqa2g==} dependencies: debug: 2.6.9 @@ -15611,15 +17010,15 @@ packages: - supports-color dev: true - /lilconfig/2.1.0: + /lilconfig@2.1.0: resolution: {integrity: sha512-utWOt/GHzuUxnLKxB6dk81RoOeoNeHgbrXiuGk4yyF5qlRz+iIVWu56E2fqGHFrXz0QNUhLB/8nKqvRH66JKGQ==} engines: {node: '>=10'} dev: true - /lines-and-columns/1.2.4: + /lines-and-columns@1.2.4: resolution: {integrity: sha512-7ylylesZQ/PV29jhEDl3Ufjo6ZX7gCqJr5F7PKrqc93v7fzSymt1BpwEU8nAUXs8qzzvqhbjhK5QZg6Mt/HkBg==} - /lint-staged/13.2.3: + /lint-staged@13.2.3: resolution: {integrity: sha512-zVVEXLuQIhr1Y7R7YAWx4TZLdvuzk7DnmrsTNL0fax6Z3jrpFcas+vKbzxhhvp6TA55m1SQuWkpzI1qbfDZbAg==} engines: {node: ^14.13.1 || >=16.0.0} hasBin: true @@ -15627,7 +17026,7 @@ packages: chalk: 5.2.0 cli-truncate: 3.1.0 commander: 10.0.1 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) execa: 7.1.1 lilconfig: 2.1.0 listr2: 5.0.8 @@ -15642,7 +17041,7 @@ packages: - supports-color dev: true - /listr2/3.14.0_enquirer@2.3.6: + /listr2@3.14.0(enquirer@2.3.6): resolution: {integrity: sha512-TyWI8G99GX9GjE54cJ+RrNMcIFBfwMPxc3XTFiAYGN4s10hWROGtOg7+O6u6LE3mNkyld7RSLE6nrKBvTfcs3g==} engines: {node: '>=10.0.0'} peerDependencies: @@ -15662,7 +17061,7 @@ packages: wrap-ansi: 7.0.0 dev: true - /listr2/5.0.8: + /listr2@5.0.8: resolution: {integrity: sha512-mC73LitKHj9w6v30nLNGPetZIlfpUniNSsxxrbaPcWOjDb92SHPzJPi/t+v1YC/lxKz/AJ9egOjww0qUuFxBpA==} engines: {node: ^14.13.1 || >=16.0.0} peerDependencies: @@ -15681,7 +17080,7 @@ packages: wrap-ansi: 7.0.0 dev: true - /lit-element/3.3.2: + /lit-element@3.3.2: resolution: {integrity: sha512-xXAeVWKGr4/njq0rGC9dethMnYCq5hpKYrgQZYTzawt9YQhMiXfD+T1RgrdY3NamOxwq2aXlb0vOI6e29CKgVQ==} dependencies: '@lit-labs/ssr-dom-shim': 1.1.1 @@ -15689,13 +17088,13 @@ packages: lit-html: 2.7.5 dev: false - /lit-html/2.7.5: + /lit-html@2.7.5: resolution: {integrity: sha512-YqUzpisJodwKIlbMFCtyrp58oLloKGnnPLMJ1t23cbfIJjg/H9pvLWK4XS69YeubK5HUs1UE4ys9w5dP1zg6IA==} dependencies: '@types/trusted-types': 2.0.3 dev: false - /lit/2.7.6: + /lit@2.7.6: resolution: {integrity: sha512-1amFHA7t4VaaDe+vdQejSVBklwtH9svGoG6/dZi9JhxtJBBlqY5D1RV7iLUYY0trCqQc4NfhYYZilZiVHt7Hxg==} dependencies: '@lit/reactive-element': 1.6.2 @@ -15703,7 +17102,7 @@ packages: lit-html: 2.7.5 dev: false - /load-json-file/1.1.0: + /load-json-file@1.1.0: resolution: {integrity: sha512-cy7ZdNRXdablkXYNI049pthVeXFurRyb9+hA/dZzerZ0pGTx42z+y+ssxBaVV2l70t1muq5IdKhn4UtcoGUY9A==} engines: {node: '>=0.10.0'} dependencies: @@ -15715,7 +17114,7 @@ packages: dev: true optional: true - /load-json-file/4.0.0: + /load-json-file@4.0.0: resolution: {integrity: sha512-Kx8hMakjX03tiGTLAIdJ+lL0htKnXjEZN6hk/tozf/WOuYGdZBJrZ+rCJRbVCugsjB3jMLn9746NsQIf5VjBMw==} engines: {node: '>=4'} dependencies: @@ -15725,22 +17124,22 @@ packages: strip-bom: 3.0.0 dev: true - /load-tsconfig/0.2.5: + /load-tsconfig@0.2.5: resolution: {integrity: sha512-IXO6OCs9yg8tMKzfPZ1YmheJbZCiEsnBdcB03l0OcfK9prKnJb96siuHCr5Fl37/yo9DnKU+TLpxzTUspw9shg==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dev: true - /loader-runner/2.4.0: + /loader-runner@2.4.0: resolution: {integrity: sha512-Jsmr89RcXGIwivFY21FcRrisYZfvLMTWx5kOLc+JTxtpBOG6xML0vzbc6SEQG2FO9/4Fc3wW4LVcB5DmGflaRw==} engines: {node: '>=4.3.0 <5.0.0 || >=5.10'} dev: true - /loader-runner/4.3.0: + /loader-runner@4.3.0: resolution: {integrity: sha512-3R/1M+yS3j5ou80Me59j7F9IMs4PXs3VqRrm0TU3AbKPxlmpoY1TNscJV/oGJXo8qCatFGTfDbY6W6ipGOYXfg==} engines: {node: '>=6.11.5'} dev: true - /loader-utils/1.4.2: + /loader-utils@1.4.2: resolution: {integrity: sha512-I5d00Pd/jwMD2QCduo657+YM/6L3KZu++pmX9VFncxaxvHcru9jx1lBaFft+r4Mt2jK0Yhp41XlRAihzPxHNCg==} engines: {node: '>=4.0.0'} dependencies: @@ -15749,7 +17148,7 @@ packages: json5: 1.0.2 dev: true - /loader-utils/2.0.4: + /loader-utils@2.0.4: resolution: {integrity: sha512-xXqpXoINfFhgua9xiqD8fPFHgkoq1mmmpE92WlDbm9rNRd/EbRb+Gqf908T2DMfuHjjJlksiK2RbHVOdD/MqSw==} engines: {node: '>=8.9.0'} dependencies: @@ -15758,15 +17157,15 @@ packages: json5: 2.2.3 dev: true - /local-pkg/0.4.3: + /local-pkg@0.4.3: resolution: {integrity: sha512-SFppqq5p42fe2qcZQqqEOiVRXl+WCP1MdT6k7BDEW1j++sp5fIY+/fdRQitvKgB5BrBcmrs5m/L0v2FrU5MY1g==} engines: {node: '>=14'} - /locate-character/3.0.0: + /locate-character@3.0.0: resolution: {integrity: sha512-SW13ws7BjaeJ6p7Q6CO2nchbYEc3X3J6WrmTTDto7yMPqVSZTUyY5Tjbid+Ab8gLnATtygYtiDIJGQRRn2ZOiA==} dev: true - /locate-path/3.0.0: + /locate-path@3.0.0: resolution: {integrity: sha512-7AO748wWnIhNqAuaty2ZWHkQHRSNfPVIsPIfwEOWO22AmaoVrWavlOcMR5nzTLNYvp36X220/maaRsrec1G65A==} engines: {node: '>=6'} dependencies: @@ -15774,91 +17173,91 @@ packages: path-exists: 3.0.0 dev: true - /locate-path/5.0.0: + /locate-path@5.0.0: resolution: {integrity: sha512-t7hw9pI+WvuwNJXwk5zVHpyhIqzg2qTlklJOf0mVxGSbe3Fp2VieZcduNYjaLDoy6p9uGpQEGWG87WpMKlNq8g==} engines: {node: '>=8'} dependencies: p-locate: 4.1.0 dev: true - /locate-path/6.0.0: + /locate-path@6.0.0: resolution: {integrity: sha512-iPZK6eYjbxRu3uB4/WZ3EsEIMJFMqAoopl3R+zuq0UjcAm/MO6KCweDgPfP3elTztoKP3KtnVHxTn2NHBSDVUw==} engines: {node: '>=10'} dependencies: p-locate: 5.0.0 dev: true - /locate-path/7.2.0: + /locate-path@7.2.0: resolution: {integrity: sha512-gvVijfZvn7R+2qyPX8mAuKcFGDf6Nc61GdvGafQsHL0sBIxfKzA+usWn4GFC/bk+QdwPUD4kWFJLhElipq+0VA==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dependencies: p-locate: 6.0.0 dev: true - /lodash.clonedeep/4.5.0: + /lodash.clonedeep@4.5.0: resolution: {integrity: sha512-H5ZhCF25riFd9uB5UCkVKo61m3S/xZk1x4wA6yp/L3RFP6Z/eHH1ymQcGLo7J3GMPfm0V/7m1tryHuGVxpqEBQ==} dev: true - /lodash.debounce/4.0.8: + /lodash.debounce@4.0.8: resolution: {integrity: sha512-FT1yDzDYEoYWhnSGnpE/4Kj1fLZkDFyqRb7fNt6FdYOSxlUWAtp42Eh6Wb0rGIv/m9Bgo7x4GhQbm5Ys4SG5ow==} dev: true - /lodash.defaults/4.2.0: + /lodash.defaults@4.2.0: resolution: {integrity: sha512-qjxPLHd3r5DnsdGacqOMU6pb/avJzdh9tFX2ymgoZE27BmjXrNy/y4LoaiTeAb+O3gL8AfpJGtqfX/ae2leYYQ==} dev: true - /lodash.difference/4.5.0: + /lodash.difference@4.5.0: resolution: {integrity: sha512-dS2j+W26TQ7taQBGN8Lbbq04ssV3emRw4NY58WErlTO29pIqS0HmoT5aJ9+TUQ1N3G+JOZSji4eugsWwGp9yPA==} dev: true - /lodash.escape/4.0.1: + /lodash.escape@4.0.1: resolution: {integrity: sha512-nXEOnb/jK9g0DYMr1/Xvq6l5xMD7GDG55+GSYIYmS0G4tBk/hURD4JR9WCavs04t33WmJx9kCyp9vJ+mr4BOUw==} dev: true - /lodash.flatten/4.4.0: + /lodash.flatten@4.4.0: resolution: {integrity: sha512-C5N2Z3DgnnKr0LOpv/hKCgKdb7ZZwafIrsesve6lmzvZIRZRGaZ/l6Q8+2W7NaT+ZwO3fFlSCzCzrDCFdJfZ4g==} dev: true - /lodash.flattendeep/4.4.0: + /lodash.flattendeep@4.4.0: resolution: {integrity: sha512-uHaJFihxmJcEX3kT4I23ABqKKalJ/zDrDg0lsFtc1h+3uw49SIJ5beyhx5ExVRti3AvKoOJngIj7xz3oylPdWQ==} dev: true - /lodash.isequal/4.5.0: + /lodash.isequal@4.5.0: resolution: {integrity: sha512-pDo3lu8Jhfjqls6GkMgpahsF9kCyayhgykjyLMNFTKWrpVdAQtYyB4muAMWozBB4ig/dtWAmsMxLEI8wuz+DYQ==} dev: true - /lodash.isplainobject/4.0.6: + /lodash.isplainobject@4.0.6: resolution: {integrity: sha512-oSXzaWypCMHkPC3NvBEaPHf0KsA5mvPrOPgQWDsbg8n7orZ290M0BmC/jgRZ4vcJ6DTAhjrsSYgdsW/F+MFOBA==} dev: true - /lodash.merge/4.6.2: + /lodash.merge@4.6.2: resolution: {integrity: sha512-0KpjqXRVvrYyCsX1swR/XTK0va6VQkQM6MNo7PqW77ByjAhoARA8EfrP1N4+KlKj8YS0ZUCtRT/YUuhyYDujIQ==} dev: true - /lodash.once/4.1.1: + /lodash.once@4.1.1: resolution: {integrity: sha512-Sb487aTOCr9drQVL8pIxOzVhafOjZN9UU54hiN8PU3uAiSV7lx1yYNpbNmex2PK6dSJoNTSJUUswT651yww3Mg==} dev: true - /lodash.sortby/4.7.0: + /lodash.sortby@4.7.0: resolution: {integrity: sha512-HDWXG8isMntAyRF5vZ7xKuEvOhT4AhlRt/3czTSjvGUxjYCBVRQY48ViDHyfYz9VIoBkW4TMGQNapx+l3RUwdA==} dev: true - /lodash.union/4.6.0: + /lodash.union@4.6.0: resolution: {integrity: sha512-c4pB2CdGrGdjMKYLA+XiRDO7Y0PRQbm/Gzg8qMj+QH+pFVAoTp5sBpO0odL3FjoPCGjK96p6qsP+yQoiLoOBcw==} dev: true - /lodash.uniq/4.5.0: + /lodash.uniq@4.5.0: resolution: {integrity: sha512-xfBaXQd9ryd9dlSDvnvI0lvxfLJlYAZzXomUYzLKtUeOQvOP5piqAWuGtrhWeqaXK9hhoM/iyJc5AV+XfsX3HQ==} dev: true - /lodash.zip/4.2.0: + /lodash.zip@4.2.0: resolution: {integrity: sha512-C7IOaBBK/0gMORRBd8OETNx3kmOkgIWIPvyDpZSCTwUrpYmgZwJkjZeOD8ww4xbOUOs4/attY+pciKvadNfFbg==} dev: true - /lodash/4.17.21: + /lodash@4.17.21: resolution: {integrity: sha512-v2kDEe57lecTulaDIuNTPy3Ry4gLGJ6Z1O3vE1krgXZNrsQ+LFTGHVxVjcXPs17LhbZVGedAJv8XZ1tvj5FvSg==} - /log-symbols/4.1.0: + /log-symbols@4.1.0: resolution: {integrity: sha512-8XPvpAA8uyhfteu8pIvQxpJZ7SYYdpUivZpGy6sFsBuKRY/7rQGavedeB8aK+Zkyq6upMFVL/9AW6vOYzfRyLg==} engines: {node: '>=10'} dependencies: @@ -15866,7 +17265,7 @@ packages: is-unicode-supported: 0.1.0 dev: true - /log-update/4.0.0: + /log-update@4.0.0: resolution: {integrity: sha512-9fkkDevMefjg0mmzWFBW8YkFP91OrizzkW3diF7CpG+S2EYdy4+TVfGwz1zeF8x7hCx1ovSPTOE9Ngib74qqUg==} engines: {node: '>=10'} dependencies: @@ -15876,7 +17275,7 @@ packages: wrap-ansi: 6.2.0 dev: true - /log-update/5.0.1: + /log-update@5.0.1: resolution: {integrity: sha512-5UtUDQ/6edw4ofyljDNcOVJQ4c7OjDro4h3y8e1GQL5iYElYclVHJ3zeWchylvMaKnDbDilC8irOVyexnA/Slw==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dependencies: @@ -15887,22 +17286,22 @@ packages: wrap-ansi: 8.1.0 dev: true - /loglevel-plugin-prefix/0.8.4: + /loglevel-plugin-prefix@0.8.4: resolution: {integrity: sha512-WpG9CcFAOjz/FtNht+QJeGpvVl/cdR6P0z6OcXSkr8wFJOsV2GRj2j10JLfjuA4aYkcKCNIEqRGCyTife9R8/g==} dev: true - /loglevel/1.8.1: + /loglevel@1.8.1: resolution: {integrity: sha512-tCRIJM51SHjAayKwC+QAg8hT8vg6z7GSgLJKGvzuPb1Wc+hLzqtuVLxp6/HzSPOozuK+8ErAhy7U/sVzw8Dgfg==} engines: {node: '>= 0.6.0'} dev: true - /loose-envify/1.4.0: + /loose-envify@1.4.0: resolution: {integrity: sha512-lyuxPGr/Wfhrlem2CL/UcnUc1zcqKAImBDzukY7Y5F/yQiNdko6+fRLevlw1HgMySw7f611UIY408EtxRSoK3Q==} hasBin: true dependencies: js-tokens: 4.0.0 - /loud-rejection/1.6.0: + /loud-rejection@1.6.0: resolution: {integrity: sha512-RPNliZOFkqFumDhvYqOaNY4Uz9oJM2K9tC6JWsJJsNdhuONW4LQHRBpb0qf4pJApVffI5N39SwzWZJuEhfd7eQ==} engines: {node: '>=0.10.0'} dependencies: @@ -15911,79 +17310,79 @@ packages: dev: true optional: true - /loupe/2.3.6: + /loupe@2.3.6: resolution: {integrity: sha512-RaPMZKiMy8/JruncMU5Bt6na1eftNoo++R4Y+N2FrxkDVTrGvcyzFTsaGif4QTeKESheMGegbhw6iUAq+5A8zA==} dependencies: get-func-name: 2.0.0 dev: false - /lower-case/2.0.2: + /lower-case@2.0.2: resolution: {integrity: sha512-7fm3l3NAF9WfN6W3JOmf5drwpVqX78JtoGJ3A6W0a6ZnldM41w2fV5D490psKFTpMds8TJse/eHLFFsNHHjHgg==} dependencies: tslib: 2.6.0 dev: true - /lowercase-keys/3.0.0: + /lowercase-keys@3.0.0: resolution: {integrity: sha512-ozCC6gdQ+glXOQsveKD0YsDy8DSQFjDTz4zyzEHNV5+JP5D62LmfDZ6o1cycFx9ouG940M5dE8C8CTewdj2YWQ==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dev: true - /lru-cache/10.0.0: + /lru-cache@10.0.0: resolution: {integrity: sha512-svTf/fzsKHffP42sujkO/Rjs37BCIsQVRCeNYIm9WN8rgT7ffoUnRtZCqU+6BqcSBdv8gwJeTz8knJpgACeQMw==} engines: {node: 14 || >=16.14} dev: true - /lru-cache/4.1.5: + /lru-cache@4.1.5: resolution: {integrity: sha512-sWZlbEP2OsHNkXrMl5GYk/jKk70MBng6UU4YI/qGDYbgf6YbP4EvmqISbXCoJiRKs+1bSpFHVgQxvJ17F2li5g==} dependencies: pseudomap: 1.0.2 yallist: 2.1.2 dev: true - /lru-cache/5.1.1: + /lru-cache@5.1.1: resolution: {integrity: sha512-KpNARQA3Iwv+jTA0utUVVbrh+Jlrr1Fv0e56GGzAFOXN7dk/FviaDW8LHmK52DlcH4WP2n6gI8vN1aesBFgo9w==} dependencies: yallist: 3.1.1 - /lru-cache/6.0.0: + /lru-cache@6.0.0: resolution: {integrity: sha512-Jo6dJ04CmSjuznwJSS3pUeWmd/H0ffTlkXXgwZi+eq1UCmqQwCh+eLsYOYCwY991i2Fah4h1BEMCx4qThGbsiA==} engines: {node: '>=10'} dependencies: yallist: 4.0.0 dev: true - /lz-string/1.5.0: + /lz-string@1.5.0: resolution: {integrity: sha512-h5bgJWpxJNswbU7qCrV0tIKQCaS3blPDrqKWx+QxzuzL1zGUzij9XCWLrSLsJPu5t+eWA/ycetzYAO5IOMcWAQ==} hasBin: true dev: true - /magic-string/0.25.9: + /magic-string@0.25.9: resolution: {integrity: sha512-RmF0AsMzgt25qzqqLc1+MbHmhdx0ojF2Fvs4XnOqz2ZOBXzzkEwc/dJQZCYHAn7v1jbVOjAZfK8msRn4BxO4VQ==} dependencies: sourcemap-codec: 1.4.8 dev: true - /magic-string/0.26.7: + /magic-string@0.26.7: resolution: {integrity: sha512-hX9XH3ziStPoPhJxLq1syWuZMxbDvGNbVchfrdCtanC7D13888bMFow61x8axrx+GfHLtVeAx2kxL7tTGRl+Ow==} engines: {node: '>=12'} dependencies: sourcemap-codec: 1.4.8 dev: true - /magic-string/0.27.0: + /magic-string@0.27.0: resolution: {integrity: sha512-8UnnX2PeRAPZuN12svgR9j7M1uWMovg/CEnIwIG0LFkXSJJe4PdfUGiTGl8V9bsBHFUtfVINcSyYxd7q+kx9fA==} engines: {node: '>=12'} dependencies: '@jridgewell/sourcemap-codec': 1.4.15 dev: true - /magic-string/0.30.1: + /magic-string@0.30.1: resolution: {integrity: sha512-mbVKXPmS0z0G4XqFDCTllmDQ6coZzn94aMlb0o/A4HEHJCKcanlDZwYJgwnkmgD3jyWhUgj9VsPrfd972yPffA==} engines: {node: '>=12'} dependencies: '@jridgewell/sourcemap-codec': 1.4.15 - /make-dir/2.1.0: + /make-dir@2.1.0: resolution: {integrity: sha512-LS9X+dc8KLxXCb8dni79fLIIUA5VyZoyjSMCwTluaXA0o27cCK0bhXkpgw+sTXVpPy/lSO57ilRixqk0vDmtRA==} engines: {node: '>=6'} dependencies: @@ -15991,64 +17390,64 @@ packages: semver: 5.7.2 dev: true - /make-dir/3.1.0: + /make-dir@3.1.0: resolution: {integrity: sha512-g3FeP20LNwhALb/6Cz6Dd4F2ngze0jz7tbzrD2wAV+o9FeNHe4rL+yK2md0J/fiSf1sa1ADhXqi5+oVwOM/eGw==} engines: {node: '>=8'} dependencies: semver: 6.3.1 - /make-error/1.3.6: + /make-error@1.3.6: resolution: {integrity: sha512-s8UhlNe7vPKomQhC1qFelMokr/Sc3AgNbso3n74mVPA5LTZwkB9NlXf4XPamLxJE8h0gh73rM94xvwRT2CVInw==} dev: true - /makeerror/1.0.12: + /makeerror@1.0.12: resolution: {integrity: sha512-JmqCvUhmt43madlpFzG4BQzG2Z3m6tvQDNKdClZnO3VbIudJYmxsT0FNJMeiB2+JTSlTQTSbU8QdesVmwJcmLg==} dependencies: tmpl: 1.0.5 dev: true - /map-cache/0.2.2: + /map-cache@0.2.2: resolution: {integrity: sha512-8y/eV9QQZCiyn1SprXSrCmqJN0yNRATe+PO8ztwqrvrbdRLA3eYJF0yaR0YayLWkMbsQSKWS9N2gPcGEc4UsZg==} engines: {node: '>=0.10.0'} dev: true - /map-obj/1.0.1: + /map-obj@1.0.1: resolution: {integrity: sha512-7N/q3lyZ+LVCp7PzuxrJr4KMbBE2hW7BT7YNia330OFxIf4d3r5zVpicP2650l7CPN6RM9zOJRl3NGpqSiw3Eg==} engines: {node: '>=0.10.0'} dev: true optional: true - /map-or-similar/1.5.0: + /map-or-similar@1.5.0: resolution: {integrity: sha512-0aF7ZmVon1igznGI4VS30yugpduQW3y3GkcgGJOp7d8x8QrizhigUxjI/m2UojsXXto+jLAH3KSz+xOJTiORjg==} dev: true - /map-visit/1.0.0: + /map-visit@1.0.0: resolution: {integrity: sha512-4y7uGv8bd2WdM9vpQsiQNo41Ln1NvhvDRuVt0k2JZQ+ezN2uaQes7lZeZ+QQUHOLQAtDaBJ+7wCbi+ab/KFs+w==} engines: {node: '>=0.10.0'} dependencies: object-visit: 1.0.1 dev: true - /mark.js/8.11.1: + /mark.js@8.11.1: resolution: {integrity: sha512-1I+1qpDt4idfgLQG+BNWmrqku+7/2bi5nLf4YwF8y8zXvmfiTBY3PV3ZibfrjBueCByROpuBjLLFCajqkgYoLQ==} dev: true - /markdown-escapes/1.0.4: + /markdown-escapes@1.0.4: resolution: {integrity: sha512-8z4efJYk43E0upd0NbVXwgSTQs6cT3T06etieCMEg7dRbzCbxUCK/GHlX8mhHRDcp+OLlHkPKsvqQTCvsRl2cg==} dev: true - /marky/1.2.5: + /marky@1.2.5: resolution: {integrity: sha512-q9JtQJKjpsVxCRVgQ+WapguSbKC3SQ5HEzFGPAJMStgh3QjCawp00UKv3MTTAArTmGmmPUvllHZoNbZ3gs0I+Q==} dev: true - /match-sorter/6.3.1: + /match-sorter@6.3.1: resolution: {integrity: sha512-mxybbo3pPNuA+ZuCUhm5bwNkXrJTbsk5VWbR5wiwz/GC6LIiegBGn2w3O08UG/jdbYLinw51fSQ5xNU1U3MgBw==} dependencies: '@babel/runtime': 7.22.6 remove-accents: 0.4.2 dev: false - /md5.js/1.3.5: + /md5.js@1.3.5: resolution: {integrity: sha512-xitP+WxNPcTTOgnTJcrhM0xvdPepipPSf3I8EIpGKeFLjt3PlJLIDG3u8EX53ZIubkb+5U2+3rELYpEhHhzdkg==} dependencies: hash-base: 3.1.0 @@ -16056,19 +17455,19 @@ packages: safe-buffer: 5.2.1 dev: true - /mdast-squeeze-paragraphs/4.0.0: + /mdast-squeeze-paragraphs@4.0.0: resolution: {integrity: sha512-zxdPn69hkQ1rm4J+2Cs2j6wDEv7O17TfXTJ33tl/+JPIoEmtV9t2ZzBM5LPHE8QlHsmVD8t3vPKCyY3oH+H8MQ==} dependencies: unist-util-remove: 2.1.0 dev: true - /mdast-util-definitions/4.0.0: + /mdast-util-definitions@4.0.0: resolution: {integrity: sha512-k8AJ6aNnUkB7IE+5azR9h81O5EQ/cTDXtWdMq9Kk5KcEW/8ritU5CeLg/9HhOC++nALHBlaogJ5jz0Ybk3kPMQ==} dependencies: unist-util-visit: 2.0.3 dev: true - /mdast-util-from-markdown/0.8.5: + /mdast-util-from-markdown@0.8.5: resolution: {integrity: sha512-2hkTXtYYnr+NubD/g6KGBS/0mFmBcifAsI0yIWRiRo0PjVs6SSOSOdtzbp6kSGnShDN6G5aWZpKQ2lWRy27mWQ==} dependencies: '@types/mdast': 3.0.12 @@ -16080,7 +17479,7 @@ packages: - supports-color dev: true - /mdast-util-to-hast/10.0.1: + /mdast-util-to-hast@10.0.1: resolution: {integrity: sha512-BW3LM9SEMnjf4HXXVApZMt8gLQWVNXc3jryK0nJu/rOXPOnlkUjmdkDlmxMirpbU9ILncGFIwLH/ubnWBbcdgA==} dependencies: '@types/mdast': 3.0.12 @@ -16093,48 +17492,48 @@ packages: unist-util-visit: 2.0.3 dev: true - /mdast-util-to-string/1.1.0: + /mdast-util-to-string@1.1.0: resolution: {integrity: sha512-jVU0Nr2B9X3MU4tSK7JP1CMkSvOj7X5l/GboG1tKRw52lLF1x2Ju92Ms9tNetCcbfX3hzlM73zYo2NKkWSfF/A==} dev: true - /mdast-util-to-string/2.0.0: + /mdast-util-to-string@2.0.0: resolution: {integrity: sha512-AW4DRS3QbBayY/jJmD8437V1Gombjf8RSOUCMFBuo5iHi58AGEgVCKQ+ezHkZZDpAQS75hcBMpLqjpJTjtUL7w==} dev: true - /mdn-data/2.0.30: + /mdn-data@2.0.30: resolution: {integrity: sha512-GaqWWShW4kv/G9IEucWScBx9G1/vsFZZJUO+tD26M8J8z3Kw5RDQjaoZe03YAClgeS/SWPOcb4nkFBTEi5DUEA==} dev: true - /mdurl/1.0.1: + /mdurl@1.0.1: resolution: {integrity: sha512-/sKlQJCBYVY9Ers9hqzKou4H6V5UWc/M59TH2dvkt+84itfnq7uFOMLpOiOS4ujvHP4etln18fmIxA5R5fll0g==} dev: true - /media-typer/0.3.0: + /media-typer@0.3.0: resolution: {integrity: sha512-dq+qelQ9akHpcOl/gUVRTxVIOkAJ1wR3QAvb4RsVjS8oVoFjDGTc679wJYmUmknUF5HwMLOgb5O+a3KxfWapPQ==} engines: {node: '>= 0.6'} dev: true - /memfs/3.5.3: + /memfs@3.5.3: resolution: {integrity: sha512-UERzLsxzllchadvbPs5aolHh65ISpKpM+ccLbOJ8/vvpBKmAWf+la7dXFy7Mr0ySHbdHrFv5kGFCUHHe6GFEmw==} engines: {node: '>= 4.0.0'} dependencies: fs-monkey: 1.0.4 dev: true - /memoizerific/1.11.3: + /memoizerific@1.11.3: resolution: {integrity: sha512-/EuHYwAPdLtXwAwSZkh/Gutery6pD2KYd44oQLhAvQp/50mpyduZh8Q7PYHXTCJ+wuXxt7oij2LXyIJOOYFPog==} dependencies: map-or-similar: 1.5.0 dev: true - /memory-fs/0.4.1: + /memory-fs@0.4.1: resolution: {integrity: sha512-cda4JKCxReDXFXRqOHPQscuIYg1PvxbE2S2GP45rnwfEK+vZaXC8C1OFvdHIbgw0DLzowXGVoxLaAmlgRy14GQ==} dependencies: errno: 0.1.8 readable-stream: 2.3.8 dev: true - /memory-fs/0.5.0: + /memory-fs@0.5.0: resolution: {integrity: sha512-jA0rdU5KoQMC0e6ppoNRtpp6vjFq6+NY7r8hywnC7V+1Xj/MtHwGIbB1QaK/dunyjWteJzmkpd7ooeWg10T7GA==} engines: {node: '>=4.3.0 <5.0.0 || >=5.10'} dependencies: @@ -16142,12 +17541,12 @@ packages: readable-stream: 2.3.8 dev: true - /memorystream/0.3.1: + /memorystream@0.3.1: resolution: {integrity: sha512-S3UwM3yj5mtUSEfP41UZmt/0SCoVYUcU1rkXv+BQ5Ig8ndL4sPoJNBUJERafdPb5jjHJGuMgytgKvKIf58XNBw==} engines: {node: '>= 0.10.0'} dev: true - /meow/3.7.0: + /meow@3.7.0: resolution: {integrity: sha512-TNdwZs0skRlpPpCUK25StC4VH+tP5GgeY1HQOOGP+lQ2xtdkN2VtT/5tiX9k3IWpkBPV9b3LsAWXn4GGi/PrSA==} engines: {node: '>=0.10.0'} dependencies: @@ -16164,44 +17563,44 @@ packages: dev: true optional: true - /merge-anything/5.1.7: + /merge-anything@5.1.7: resolution: {integrity: sha512-eRtbOb1N5iyH0tkQDAoQ4Ipsp/5qSR79Dzrz8hEPxRX10RWWR/iQXdoKmBSRCThY1Fh5EhISDtpSc93fpxUniQ==} engines: {node: '>=12.13'} dependencies: is-what: 4.1.15 dev: true - /merge-descriptors/1.0.1: + /merge-descriptors@1.0.1: resolution: {integrity: sha512-cCi6g3/Zr1iqQi6ySbseM1Xvooa98N0w31jzUYrXPX2xqObmFGHJ0tQ5u74H3mVh7wLouTseZyYIq39g8cNp1w==} dev: true - /merge-stream/2.0.0: + /merge-stream@2.0.0: resolution: {integrity: sha512-abv/qOcuPfk3URPfDzmZU1LKmuw8kT+0nIHvKrKgFrwifol/doWcdA4ZqsWQ8ENrFKkd67Mfpo/LovbIUsbt3w==} dev: true - /merge2/1.4.1: + /merge2@1.4.1: resolution: {integrity: sha512-8q7VEgMJW4J8tcfVPy8g09NcQwZdbwFEqhe/WZkoIzjn/3TGDwtOCYtXGxA3O8tPzpczCCDgv+P2P5y00ZJOOg==} engines: {node: '>= 8'} - /methods/1.1.2: + /methods@1.1.2: resolution: {integrity: sha512-iclAHeNqNm68zFtnZ0e+1L2yUIdvzNoauKU4WBA3VvH/vPFieF7qfRlwUZU+DA9P9bPXIS90ulxoUoCH23sV2w==} engines: {node: '>= 0.6'} dev: true - /microevent.ts/0.1.1: + /microevent.ts@0.1.1: resolution: {integrity: sha512-jo1OfR4TaEwd5HOrt5+tAZ9mqT4jmpNAusXtyfNzqVm9uiSYFZlKM1wYL4oU7azZW/PxQW53wM0S6OR1JHNa2g==} dev: true - /micromark/2.11.4: + /micromark@2.11.4: resolution: {integrity: sha512-+WoovN/ppKolQOFIAajxi7Lu9kInbPxFuTBVEavFcL8eAfVstoc5MocPmqBeAdBOJV00uaVjegzH4+MA0DN/uA==} dependencies: - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) parse-entities: 2.0.0 transitivePeerDependencies: - supports-color dev: true - /micromatch/3.1.10: + /micromatch@3.1.10: resolution: {integrity: sha512-MWikgl9n9M3w+bpsY3He8L+w9eF9338xRl8IAO5viDizwSzziFEyUzo2xrrloB64ADbTf8uA8vRqqttDTOmccg==} engines: {node: '>=0.10.0'} dependencies: @@ -16222,18 +17621,18 @@ packages: - supports-color dev: true - /micromatch/4.0.5: + /micromatch@4.0.5: resolution: {integrity: sha512-DMy+ERcEW2q8Z2Po+WNXuw3c5YaUSFjAO5GsJqfEl7UjvtIuFKO6ZrKvcItdy98dwFI2N1tg3zNIdKaQT+aNdA==} engines: {node: '>=8.6'} dependencies: braces: 3.0.2 picomatch: 2.3.1 - /microseconds/0.2.0: + /microseconds@0.2.0: resolution: {integrity: sha512-n7DHHMjR1avBbSpsTBj6fmMGh2AGrifVV4e+WYc3Q9lO+xnSZ3NyhcBND3vzzatt05LFhoKFRxrIyklmLlUtyA==} dev: false - /miller-rabin/4.0.1: + /miller-rabin@4.0.1: resolution: {integrity: sha512-115fLhvZVqWwHPbClyntxEVfVDfl9DLLTuJvq3g2O/Oxi8AiNouAHvDSzHS0viUJc+V5vm3eq91Xwqn9dp4jRA==} hasBin: true dependencies: @@ -16241,141 +17640,141 @@ packages: brorand: 1.1.0 dev: true - /mime-db/1.52.0: + /mime-db@1.52.0: resolution: {integrity: sha512-sPU4uV7dYlvtWJxwwxHD0PuihVNiE7TyAbQ5SWxDCB9mUYvOgroQOwYQQOKPJ8CIbE+1ETVlOoK1UC2nU3gYvg==} engines: {node: '>= 0.6'} dev: true - /mime-types/2.1.35: + /mime-types@2.1.35: resolution: {integrity: sha512-ZDY+bPm5zTTF+YpCrAU9nK0UgICYPT0QtT1NZWFv4s++TNkcgVaT0g6+4R2uI4MjQjzysHB1zxuWL50hzaeXiw==} engines: {node: '>= 0.6'} dependencies: mime-db: 1.52.0 dev: true - /mime/1.6.0: + /mime@1.6.0: resolution: {integrity: sha512-x0Vn8spI+wuJ1O6S7gnbaQg8Pxh4NNHb7KSINmEWKiPE4RKOplvijn+NkmYmmRgP68mc70j2EbeTFRsrswaQeg==} engines: {node: '>=4'} hasBin: true dev: true - /mime/2.6.0: + /mime@2.6.0: resolution: {integrity: sha512-USPkMeET31rOMiarsBNIHZKLGgvKc/LrjofAnBlOttf5ajRvqiRA8QsenbcooctK6d6Ts6aqZXBA+XbkKthiQg==} engines: {node: '>=4.0.0'} hasBin: true dev: true - /mime/3.0.0: + /mime@3.0.0: resolution: {integrity: sha512-jSCU7/VB1loIWBZe14aEYHU/+1UMEHoaO7qxCOVJOw9GgH72VAWppxNcjU+x9a2k3GSIBXNKxXQFqRvvZ7vr3A==} engines: {node: '>=10.0.0'} hasBin: true dev: true - /mimic-fn/2.1.0: + /mimic-fn@2.1.0: resolution: {integrity: sha512-OqbOk5oEQeAZ8WXWydlu9HJjz9WVdEIvamMCcXmuqUYjTknH/sqsWvhQ3vgwKFRR1HpjvNBKQ37nbJgYzGqGcg==} engines: {node: '>=6'} dev: true - /mimic-fn/4.0.0: + /mimic-fn@4.0.0: resolution: {integrity: sha512-vqiC06CuhBTUdZH+RYl8sFrL096vA45Ok5ISO6sE/Mr1jRbGH4Csnhi8f3wKVl7x8mO4Au7Ir9D3Oyv1VYMFJw==} engines: {node: '>=12'} dev: true - /mimic-response/3.1.0: + /mimic-response@3.1.0: resolution: {integrity: sha512-z0yWI+4FDrrweS8Zmt4Ej5HdJmky15+L2e6Wgn3+iK5fWzb6T3fhNFq2+MeTRb064c6Wr4N/wv0DzQTjNzHNGQ==} engines: {node: '>=10'} dev: true - /mimic-response/4.0.0: + /mimic-response@4.0.0: resolution: {integrity: sha512-e5ISH9xMYU0DzrT+jl8q2ze9D6eWBto+I8CNpe+VI+K2J/F/k3PdkdTdz4wvGVH4NTpo+NRYTVIuMQEMMcsLqg==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dev: true - /min-document/2.19.0: + /min-document@2.19.0: resolution: {integrity: sha512-9Wy1B3m3f66bPPmU5hdA4DR4PB2OfDU/+GS3yAB7IQozE3tqXaVv2zOjgla7MEGSRv95+ILmOuvhLkOK6wJtCQ==} dependencies: dom-walk: 0.1.2 dev: true - /min-indent/1.0.1: + /min-indent@1.0.1: resolution: {integrity: sha512-I9jwMn07Sy/IwOj3zVkVik2JTvgpaykDZEigL6Rx6N9LbMywwUSMtxET+7lVoDLLd3O3IXwJwvuuns8UB/HeAg==} engines: {node: '>=4'} dev: true - /minimalistic-assert/1.0.1: + /minimalistic-assert@1.0.1: resolution: {integrity: sha512-UtJcAD4yEaGtjPezWuO9wC4nwUnVH/8/Im3yEHQP4b67cXlD/Qr9hdITCU1xDbSEXg2XKNaP8jsReV7vQd00/A==} dev: true - /minimalistic-crypto-utils/1.0.1: + /minimalistic-crypto-utils@1.0.1: resolution: {integrity: sha512-JIYlbt6g8i5jKfJ3xz7rF0LXmv2TkDxBLUkiBeZ7bAx4GnnNMr8xFpGnOxn6GhTEHx3SjRrZEoU+j04prX1ktg==} dev: true - /minimatch/3.1.2: + /minimatch@3.1.2: resolution: {integrity: sha512-J7p63hRiAjw1NDEww1W7i37+ByIrOWO5XQQAzZ3VOcL0PNybwpfmV/N05zFAzwQ9USyEcX6t3UO+K5aqBQOIHw==} dependencies: brace-expansion: 1.1.11 - /minimatch/5.1.6: + /minimatch@5.1.6: resolution: {integrity: sha512-lKwV/1brpG6mBUFHtb7NUmtABCb2WZZmm2wNiOA5hAb8VdCS4B3dtMWyvcoViccwAW/COERjXLt0zP1zXUN26g==} engines: {node: '>=10'} dependencies: brace-expansion: 2.0.1 dev: true - /minimatch/9.0.3: + /minimatch@9.0.3: resolution: {integrity: sha512-RHiac9mvaRw0x3AYRgDC1CxAP7HTcNrrECeA8YYJeWnpo+2Q5CegtZjaotWTWxDG3UeGA1coE05iH1mPjT/2mg==} engines: {node: '>=16 || 14 >=14.17'} dependencies: brace-expansion: 2.0.1 dev: true - /minimist/1.2.8: + /minimist@1.2.8: resolution: {integrity: sha512-2yyAR8qBkN3YuheJanUpWC5U3bb5osDywNB8RzDVlDwDHbocAJveqqj1u8+SVD7jkWT4yvsHCpWqqWqAxb0zCA==} dev: true - /minipass-collect/1.0.2: + /minipass-collect@1.0.2: resolution: {integrity: sha512-6T6lH0H8OG9kITm/Jm6tdooIbogG9e0tLgpY6mphXSm/A9u8Nq1ryBG+Qspiub9LjWlBPsPS3tWQ/Botq4FdxA==} engines: {node: '>= 8'} dependencies: minipass: 3.3.6 dev: true - /minipass-flush/1.0.5: + /minipass-flush@1.0.5: resolution: {integrity: sha512-JmQSYYpPUqX5Jyn1mXaRwOda1uQ8HP5KAT/oDSLCzt1BYRhQU0/hDtsB1ufZfEEzMZ9aAVmsBw8+FWsIXlClWw==} engines: {node: '>= 8'} dependencies: minipass: 3.3.6 dev: true - /minipass-pipeline/1.2.4: + /minipass-pipeline@1.2.4: resolution: {integrity: sha512-xuIq7cIOt09RPRJ19gdi4b+RiNvDFYe5JH+ggNvBqGqpQXcru3PcRmOZuHBKWK1Txf9+cQ+HMVN4d6z46LZP7A==} engines: {node: '>=8'} dependencies: minipass: 3.3.6 dev: true - /minipass/3.3.6: + /minipass@3.3.6: resolution: {integrity: sha512-DxiNidxSEK+tHG6zOIklvNOwm3hvCrbUrdtzY74U6HKTJxvIDfOUL5W5P2Ghd3DTkhhKPYGqeNUIh5qcM4YBfw==} engines: {node: '>=8'} dependencies: yallist: 4.0.0 dev: true - /minipass/5.0.0: + /minipass@5.0.0: resolution: {integrity: sha512-3FnjYuehv9k6ovOEbyOswadCDPX1piCfhV8ncmYtHOjuPwylVWsghTLo7rabjC3Rx5xD4HDx8Wm1xnMF7S5qFQ==} engines: {node: '>=8'} dev: true - /minipass/7.0.2: + /minipass@7.0.2: resolution: {integrity: sha512-eL79dXrE1q9dBbDCLg7xfn/vl7MS4F1gvJAgjJrQli/jbQWdUttuVawphqpffoIYfRdq78LHx6GP4bU/EQ2ATA==} engines: {node: '>=16 || 14 >=14.17'} dev: true - /minisearch/6.1.0: + /minisearch@6.1.0: resolution: {integrity: sha512-PNxA/X8pWk+TiqPbsoIYH0GQ5Di7m6326/lwU/S4mlo4wGQddIcf/V//1f9TB0V4j59b57b+HZxt8h3iMROGvg==} dev: true - /minizlib/2.1.2: + /minizlib@2.1.2: resolution: {integrity: sha512-bAxsR8BVfj60DWXHE3u30oHzfl4G7khkSuPW+qvpd7jFRHm7dLxOjUk1EHACJ/hxLY8phGJ0YhYHZo7jil7Qdg==} engines: {node: '>= 8'} dependencies: @@ -16383,7 +17782,7 @@ packages: yallist: 4.0.0 dev: true - /mississippi/3.0.0: + /mississippi@3.0.0: resolution: {integrity: sha512-x471SsVjUtBRtcvd4BzKE9kFC+/2TeWgKCgw0bZcw1b9l2X3QX5vCWgF+KaZaYm87Ss//rHnWryupDrgLvmSkA==} engines: {node: '>=4.0.0'} dependencies: @@ -16399,11 +17798,11 @@ packages: through2: 2.0.5 dev: true - /mitt/3.0.0: + /mitt@3.0.0: resolution: {integrity: sha512-7dX2/10ITVyqh4aOSVI9gdape+t9l2/8QxHrFmUXu4EEUpdlxl6RudZUPZoc+zuY2hk1j7XxVroIVIan/pD/SQ==} dev: true - /mixin-deep/1.3.2: + /mixin-deep@1.3.2: resolution: {integrity: sha512-WRoDn//mXBiJ1H40rqa3vH0toePwSsGb45iInWlTySa+Uu4k3tYUSxa2v1KqAiLtvlrSzaExqS1gtk96A9zvEA==} engines: {node: '>=0.10.0'} dependencies: @@ -16411,24 +17810,24 @@ packages: is-extendable: 1.0.1 dev: true - /mkdirp-classic/0.5.3: + /mkdirp-classic@0.5.3: resolution: {integrity: sha512-gKLcREMhtuZRwRAfqP3RFW+TK4JqApVBtOIftVgjuABpAtpxhPGaDcfvbhNvD0B8iD1oUr/txX35NjcaY6Ns/A==} dev: true - /mkdirp/0.5.6: + /mkdirp@0.5.6: resolution: {integrity: sha512-FP+p8RB8OWpF3YZBCrP5gtADmtXApB5AMLn+vdyA+PyxCjrCs00mjyUozssO33cwDeT3wNGdLxJ5M//YqtHAJw==} hasBin: true dependencies: minimist: 1.2.8 dev: true - /mkdirp/1.0.4: + /mkdirp@1.0.4: resolution: {integrity: sha512-vVqVZQyf3WLx2Shd0qJ9xuvqgAyKPLAiqITEtqW0oIUjzo3PePDd6fW9iFz30ef7Ysp/oiWqbhszeGWW2T6Gzw==} engines: {node: '>=10'} hasBin: true dev: true - /mlly/1.4.0: + /mlly@1.4.0: resolution: {integrity: sha512-ua8PAThnTwpprIaU47EPeZ/bPUVp2QYBbWMphUQpVdBI3Lgqzm5KZQ45Agm3YJedHXaIHl6pBGabaLSUPPSptg==} dependencies: acorn: 8.10.0 @@ -16436,26 +17835,26 @@ packages: pkg-types: 1.0.3 ufo: 1.1.2 - /modern-node-polyfills/0.1.3_rollup@3.26.2: + /modern-node-polyfills@0.1.3(rollup@3.26.2): resolution: {integrity: sha512-/4dB85Sdkt9MjWwtpKnsNTYhh0+fqjFC4ZEgDP4B0e6kyzbGUnX4NDxTUCaVwRLVF9gcEDcRQjol8pn05B3TUQ==} dependencies: '@jspm/core': 2.0.0-beta.24 - '@rollup/pluginutils': 3.1.0_rollup@3.26.2 + '@rollup/pluginutils': 3.1.0(rollup@3.26.2) esbuild: 0.14.54 local-pkg: 0.4.3 transitivePeerDependencies: - rollup dev: false - /moment/2.29.4: + /moment@2.29.4: resolution: {integrity: sha512-5LC9SOxjSc2HF6vO2CyuTDNivEdoz2IvyJJGj6X8DJ0eFyfszE0QiEd+iXmBvUP3WHxSjFH/vIsA0EN00cgr8w==} dev: true - /moo/0.5.2: + /moo@0.5.2: resolution: {integrity: sha512-iSAJLHYKnX41mKcJKjqvnAN9sf0LMDTXDEvFv+ffuRR9a1MIuXLjMNL6EsnDHSkKLTWNqQQ5uo61P4EbU4NU+Q==} dev: true - /move-concurrently/1.0.1: + /move-concurrently@1.0.1: resolution: {integrity: sha512-hdrFxZOycD/g6A6SoI2bB5NA/5NEqD0569+S47WZhPvm46sD50ZHdYaFmnua5lndde9rCHGjmfK7Z8BuCt/PcQ==} dependencies: aproba: 1.2.0 @@ -16466,40 +17865,40 @@ packages: run-queue: 1.0.3 dev: true - /mri/1.2.0: + /mri@1.2.0: resolution: {integrity: sha512-tzzskb3bG8LvYGFF/mDTpq3jpI6Q9wc3LEmBaghu+DdCssd1FakN7Bc0hVNmEyGq1bq3RgfkCb3cmQLpNPOroA==} engines: {node: '>=4'} dev: true - /mrmime/1.0.1: + /mrmime@1.0.1: resolution: {integrity: sha512-hzzEagAgDyoU1Q6yg5uI+AorQgdvMCur3FcKf7NhMKWsaYg+RnbTyHRa/9IlLF9rf455MOCtcqqrQQ83pPP7Uw==} engines: {node: '>=10'} - /ms/2.0.0: + /ms@2.0.0: resolution: {integrity: sha512-Tpp60P6IUJDTuOq/5Z8cdskzJujfwqfOTkrwIwj7IRISpnkJnT6SyJ4PCPnGMoFjC9ddhal5KVIYtAt97ix05A==} dev: true - /ms/2.1.1: + /ms@2.1.1: resolution: {integrity: sha512-tgp+dl5cGk28utYktBsrFqA7HKgrhgPsg6Z/EfhWI4gl1Hwq8B/GmY/0oXZ6nF8hDVesS/FpnYaD/kOWhYQvyg==} dev: true - /ms/2.1.2: + /ms@2.1.2: resolution: {integrity: sha512-sGkPx+VjMtmA6MX27oA4FBFELFCZZ4S4XqeGOXCv68tT+jb3vk/RyaKWP0PTKyWtmLSM0b+adUTEvbs1PEaH2w==} - /ms/2.1.3: + /ms@2.1.3: resolution: {integrity: sha512-6FlzubTLZG3J2a/NVCAleEhjzq5oxgHyaCU9yYXvcLsvoVaHJq/s5xXI6/XXP6tz7R9xAOtHnSO/tXtF3WRTlA==} dev: true - /msw-storybook-addon/1.8.0_msw@0.49.3: + /msw-storybook-addon@1.8.0(msw@0.49.3): resolution: {integrity: sha512-dw3vZwqjixmiur0vouRSOax7wPSu9Og2Hspy9JZFHf49bZRjwDiLF0Pfn2NXEkGviYJOJiGxS1ejoTiUwoSg4A==} peerDependencies: msw: '>=0.35.0 <2.0.0' dependencies: is-node-process: 1.2.0 - msw: 0.49.3_typescript@4.9.5 + msw: 0.49.3(typescript@4.9.5) dev: true - /msw/0.49.3_typescript@4.9.5: + /msw@0.49.3(typescript@4.9.5): resolution: {integrity: sha512-kRCbDNbNnRq5LC1H/NUceZlrPAvSrMH6Or0mirIuH69NY84xwDruPn/hkXTovIK1KwDwbk+ZdoSyJlpiekLxEA==} engines: {node: '>=14'} hasBin: true @@ -16535,7 +17934,7 @@ packages: - supports-color dev: true - /msw/1.2.2: + /msw@1.2.2(typescript@5.1.6): resolution: {integrity: sha512-GsW3PE/Es/a1tYThXcM8YHOZ1S1MtivcS3He/LQbbTCx3rbWJYCtWD5XXyJ53KlNPT7O1VI9sCW3xMtgFe8XpQ==} engines: {node: '>=14'} hasBin: true @@ -16564,22 +17963,23 @@ packages: path-to-regexp: 6.2.1 strict-event-emitter: 0.4.6 type-fest: 2.19.0 + typescript: 5.1.6 yargs: 17.7.2 transitivePeerDependencies: - encoding - supports-color dev: true - /mute-stream/0.0.8: + /mute-stream@0.0.8: resolution: {integrity: sha512-nnbWWOkoWyUsTjKrhgD0dcz22mdkSnpYqbEjIm2nhwhuxlSkpywJmBo8h0ZqJdkp73mb90SssHkN4rsRaBAfAA==} dev: true - /mute-stream/1.0.0: + /mute-stream@1.0.0: resolution: {integrity: sha512-avsJQhyd+680gKXyG/sQc0nXaC6rBkPOfyHYcFb9+hdkqQkR9bdnkJ0AMZhke0oesPqIO+mFFJ+IdBc7mst4IA==} engines: {node: ^14.17.0 || ^16.13.0 || >=18.0.0} dev: true - /mz/2.7.0: + /mz@2.7.0: resolution: {integrity: sha512-z81GNO7nnYMEhrGh9LeymoE4+Yr0Wn5McHIZMK5cfQCl+NDX08sCZgUc9/6MHni9IWuFLm1Z3HTCXu2z9fN62Q==} dependencies: any-promise: 1.3.0 @@ -16587,23 +17987,23 @@ packages: thenify-all: 1.6.0 dev: true - /nan/2.17.0: + /nan@2.17.0: resolution: {integrity: sha512-2ZTgtl0nJsO0KQCjEpxcIr5D+Yv90plTitZt9JBfQvVJDS5seMl3FOvsh3+9CoYWXf/1l5OaZzzF6nDm4cagaQ==} dev: true optional: true - /nano-time/1.0.0: + /nano-time@1.0.0: resolution: {integrity: sha512-flnngywOoQ0lLQOTRNexn2gGSNuM9bKj9RZAWSzhQ+UJYaAFG9bac4DW9VHjUAzrOaIcajHybCTHe/bkvozQqA==} dependencies: big-integer: 1.6.51 dev: false - /nanoid/3.3.6: + /nanoid@3.3.6: resolution: {integrity: sha512-BGcqMMJuToF7i1rt+2PWSNVnWIkGCU78jBG3RxO/bZlnZPK2Cmi2QaffxGO/2RvWi9sL+FAiRiXMgsyxQ1DIDA==} engines: {node: ^10 || ^12 || ^13.7 || ^14 || >=15.0.1} hasBin: true - /nanomatch/1.2.13: + /nanomatch@1.2.13: resolution: {integrity: sha512-fpoe2T0RbHwBTBUOftAfBPaDEi06ufaUai0mE6Yn1kacc3SnTErfb/h+X94VXzI64rKFHYImXSvdwGGCmwOqCA==} engines: {node: '>=0.10.0'} dependencies: @@ -16622,19 +18022,19 @@ packages: - supports-color dev: true - /napi-build-utils/1.0.2: + /napi-build-utils@1.0.2: resolution: {integrity: sha512-ONmRUqK7zj7DWX0D9ADe03wbwOBZxNAfF20PlGfCWQcD3+/MakShIHrMqx9YwPTfxDdF1zLeL+RGZiR9kGMLdg==} dev: true - /natural-compare-lite/1.4.0: + /natural-compare-lite@1.4.0: resolution: {integrity: sha512-Tj+HTDSJJKaZnfiuw+iaF9skdPpTo2GtEly5JHnWV/hfv2Qj/9RKsGISQtLh2ox3l5EAGw487hnBee0sIJ6v2g==} dev: true - /natural-compare/1.4.0: + /natural-compare@1.4.0: resolution: {integrity: sha512-OWND8ei3VtNC9h7V60qff3SVobHr996CTwgxubgyQYEpg290h9J0buyECNNJexkFm5sOajh5G116RYA1c8ZMSw==} dev: true - /nearley/2.20.1: + /nearley@2.20.1: resolution: {integrity: sha512-+Mc8UaAebFzgV+KpI5n7DasuuQCHA89dmwm7JXw3TV43ukfNQ9DnBH3Mdb2g/I4Fdxc26pwimBWvjIw0UAILSQ==} hasBin: true dependencies: @@ -16644,20 +18044,20 @@ packages: randexp: 0.4.6 dev: true - /negotiator/0.6.3: + /negotiator@0.6.3: resolution: {integrity: sha512-+EUsqGPLsM+j/zdChZjsnX51g4XrHFOIXwfnCVPGlQk/k5giakcKsuxCObBRu6DSm9opw/O6slWbJdghQM4bBg==} engines: {node: '>= 0.6'} dev: true - /neo-async/2.6.2: + /neo-async@2.6.2: resolution: {integrity: sha512-Yd3UES5mWCSqR+qNT93S3UoYUkqAZ9lLg8a7g9rimsWmYGK8cVToA4/sF3RrshdyV3sAGMXVUmpMYOw+dLpOuw==} dev: true - /nested-error-stacks/2.1.1: + /nested-error-stacks@2.1.1: resolution: {integrity: sha512-9iN1ka/9zmX1ZvLV9ewJYEk9h7RyRRtqdK0woXcqohu8EWIerfPUjYJPg0ULy0UqP7cslmdGc8xKDJcojlKiaw==} dev: true - /next/12.1.5_zpnidt7m3osuk7shl3s4oenomq: + /next@12.1.5(@babel/core@7.22.8)(react-dom@18.0.0)(react@18.0.0): resolution: {integrity: sha512-YGHDpyfgCfnT5GZObsKepmRnne7Kzp7nGrac07dikhutWQug7hHg85/+sPJ4ZW5Q2pDkb+n0FnmLkmd44htIJQ==} engines: {node: '>=12.22.0'} hasBin: true @@ -16679,8 +18079,8 @@ packages: caniuse-lite: 1.0.30001515 postcss: 8.4.5 react: 18.0.0 - react-dom: 18.0.0_react@18.0.0 - styled-jsx: 5.0.1_react@18.0.0 + react-dom: 18.0.0(react@18.0.0) + styled-jsx: 5.0.1(@babel/core@7.22.8)(react@18.0.0) optionalDependencies: '@next/swc-android-arm-eabi': 12.1.5 '@next/swc-android-arm64': 12.1.5 @@ -16699,44 +18099,44 @@ packages: - babel-plugin-macros dev: false - /nice-try/1.0.5: + /nice-try@1.0.5: resolution: {integrity: sha512-1nh45deeb5olNY7eX82BkPO7SSxR5SSYJiPTrTdFUVYwAl8CKMA5N9PjTYkHiRjisVcxcQ1HXdLhx2qxxJzLNQ==} dev: true - /no-case/3.0.4: + /no-case@3.0.4: resolution: {integrity: sha512-fgAN3jGAh+RoxUGZHTSOLJIqUc2wmoBwGR4tbpNAKmmovFoWq0OdRkb0VkldReO2a2iBT/OEulG9XSUc10r3zg==} dependencies: lower-case: 2.0.2 tslib: 2.6.0 dev: true - /node-abi/3.45.0: + /node-abi@3.45.0: resolution: {integrity: sha512-iwXuFrMAcFVi/ZoZiqq8BzAdsLw9kxDfTC0HMyjXfSL/6CSDAGD5UmR7azrAgWV1zKYq7dUUMj4owusBWKLsiQ==} engines: {node: '>=10'} dependencies: semver: 7.5.4 dev: true - /node-addon-api/6.1.0: + /node-addon-api@6.1.0: resolution: {integrity: sha512-+eawOlIgy680F0kBzPUNFhMZGtJ1YmqM6l4+Crf4IkImjYrO/mqPwRMh352g23uIaQKFItcQ64I7KMaJxHgAVA==} dev: true - /node-dir/0.1.17: + /node-dir@0.1.17: resolution: {integrity: sha512-tmPX422rYgofd4epzrNoOXiE8XFZYOcCq1vD7MAXCDO+O+zndlA2ztdKKMa+EeuBG5tHETpr4ml4RGgpqDCCAg==} engines: {node: '>= 0.10.5'} dependencies: minimatch: 3.1.2 dev: true - /node-fetch-native/0.1.8: + /node-fetch-native@0.1.8: resolution: {integrity: sha512-ZNaury9r0NxaT2oL65GvdGDy+5PlSaHTovT6JV5tOW07k1TQmgC0olZETa4C9KZg0+6zBr99ctTYa3Utqj9P/Q==} dev: true - /node-fetch-native/1.2.0: + /node-fetch-native@1.2.0: resolution: {integrity: sha512-5IAMBTl9p6PaAjYCnMv5FmqIF6GcZnawAVnzaCG0rX2aYZJ4CxEkZNtVPuTRug7fL7wyM5BQYTlAzcyMPi6oTQ==} dev: true - /node-fetch/2.6.12: + /node-fetch@2.6.12: resolution: {integrity: sha512-C/fGU2E8ToujUivIO0H+tpQ6HWo4eEmchoPIoXtxCrVghxdKq+QOHqEZW7tuP3KlV3bC8FRMO5nMCC7Zm1VP6g==} engines: {node: 4.x || >=6.0.0} peerDependencies: @@ -16747,7 +18147,7 @@ packages: dependencies: whatwg-url: 5.0.0 - /node-fetch/2.6.7: + /node-fetch@2.6.7: resolution: {integrity: sha512-ZjMPFEfVx5j+y2yF35Kzx5sF7kDzxuDj6ziH4FFbOp87zKDZNx8yExJIb05OGF4Nlt9IHFIMBkRl41VdvcNdbQ==} engines: {node: 4.x || >=6.0.0} peerDependencies: @@ -16759,11 +18159,11 @@ packages: whatwg-url: 5.0.0 dev: true - /node-int64/0.4.0: + /node-int64@0.4.0: resolution: {integrity: sha512-O5lz91xSOeoXP6DulyHfllpq+Eg00MWitZIbtPfoSEvqIHdl5gfcY6hYzDWnj0qD5tz52PI08u9qUvSVeUBeHw==} dev: true - /node-libs-browser/2.2.1: + /node-libs-browser@2.2.1: resolution: {integrity: sha512-h/zcD8H9kaDZ9ALUWwlBUDo6TKF8a7qBSCSEGfjTVIYeqsioSKaAX+BN7NgiMGp6iSIXZ3PxgCu8KS3b71YK5Q==} dependencies: assert: 1.5.0 @@ -16791,10 +18191,10 @@ packages: vm-browserify: 1.1.2 dev: true - /node-releases/2.0.13: + /node-releases@2.0.13: resolution: {integrity: sha512-uYr7J37ae/ORWdZeQ1xxMJe3NtdmqMC/JZK+geofDrkLUApKRHPd18/TxtBOJ4A0/+uUIliorNrfYV6s1b02eQ==} - /nopt/6.0.0: + /nopt@6.0.0: resolution: {integrity: sha512-ZwLpbTgdhuZUnZzjd7nb1ZV+4DoiC6/sfiVKok72ym/4Tlf+DFdlHYmT2JPmcNNWV6Pi3SDf1kT+A4r9RTuT9g==} engines: {node: ^12.13.0 || ^14.15.0 || >=16.0.0} hasBin: true @@ -16802,7 +18202,7 @@ packages: abbrev: 1.1.1 dev: true - /normalize-package-data/2.5.0: + /normalize-package-data@2.5.0: resolution: {integrity: sha512-/5CMN3T0R4XTj4DcGaexo+roZSdSFW/0AOOTROrjxzCG1wrWXEsGbRKevjlIL+ZDE4sZlJr5ED4YW0yqmkK+eA==} dependencies: hosted-git-info: 2.8.9 @@ -16811,7 +18211,7 @@ packages: validate-npm-package-license: 3.0.4 dev: true - /normalize-package-data/3.0.3: + /normalize-package-data@3.0.3: resolution: {integrity: sha512-p2W1sgqij3zMMyRC067Dg16bfzVH+w7hyegmpIvZ4JNjqtGOVAIvLmjBx3yP7YTe9vKJgkoNOPjwQGogDoMXFA==} engines: {node: '>=10'} dependencies: @@ -16821,29 +18221,29 @@ packages: validate-npm-package-license: 3.0.4 dev: true - /normalize-path/2.1.1: + /normalize-path@2.1.1: resolution: {integrity: sha512-3pKJwH184Xo/lnH6oyP1q2pMd7HcypqqmRs91/6/i2CGtWwIKGCkOOMTm/zXbgTEWHw1uNpNi/igc3ePOYHb6w==} engines: {node: '>=0.10.0'} dependencies: remove-trailing-separator: 1.1.0 dev: true - /normalize-path/3.0.0: + /normalize-path@3.0.0: resolution: {integrity: sha512-6eZs5Ls3WtCisHWp9S2GUy8dqkpGi4BVSz3GaqiE6ezub0512ESztXUwUB6C6IKbQkY2Pnb/mD4WYojCRwcwLA==} engines: {node: '>=0.10.0'} dev: true - /normalize-range/0.1.2: + /normalize-range@0.1.2: resolution: {integrity: sha512-bdok/XvKII3nUpklnV6P2hxtMNrCboOjAcyBuQnWEhO665FwrSNRxU+AqpsyvO6LgGYPspN+lu5CLtw4jPRKNA==} engines: {node: '>=0.10.0'} dev: true - /normalize-url/8.0.0: + /normalize-url@8.0.0: resolution: {integrity: sha512-uVFpKhj5MheNBJRTiMZ9pE/7hD1QTeEvugSJW/OmLzAp78PB5O6adfMNTvmfKhXBkvCzC+rqifWcVYpGFwTjnw==} engines: {node: '>=14.16'} dev: true - /notistack/2.0.8_tr5jdv7ejqexso4qfp7vkl3yhi: + /notistack@2.0.8(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(@mui/material@5.14.0)(react-dom@18.2.0)(react@18.2.0): resolution: {integrity: sha512-/IY14wkFp5qjPgKNvAdfL5Jp6q90+MjgKTPh4c81r/lW70KeuX6b9pE/4f8L4FG31cNudbN9siiFS5ql1aSLRw==} peerDependencies: '@emotion/react': ^11.4.1 @@ -16857,16 +18257,16 @@ packages: '@emotion/styled': optional: true dependencies: - '@emotion/react': 11.11.1_react@18.2.0 - '@emotion/styled': 11.11.0_xo5t6f4ryb2nvjgwj2cxjowrye - '@mui/material': 5.14.0_vizhjgize6w4e5tnsjmztd65da + '@emotion/react': 11.11.1(react@18.2.0) + '@emotion/styled': 11.11.0(@emotion/react@11.11.1)(react@18.2.0) + '@mui/material': 5.14.0(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(react-dom@18.2.0)(react@18.2.0) clsx: 1.2.1 hoist-non-react-statics: 3.3.2 react: 18.2.0 - react-dom: 18.2.0_react@18.2.0 + react-dom: 18.2.0(react@18.2.0) dev: false - /npm-run-all/4.1.5: + /npm-run-all@4.1.5: resolution: {integrity: sha512-Oo82gJDAVcaMdi3nuoKFavkIHBRVqQ1qvMb+9LHk/cF4P6B2m8aP04hGf7oL6wZ9BuGwX1onlLhpuoofSyoQDQ==} engines: {node: '>= 4'} hasBin: true @@ -16882,28 +18282,28 @@ packages: string.prototype.padend: 3.1.4 dev: true - /npm-run-path/2.0.2: + /npm-run-path@2.0.2: resolution: {integrity: sha512-lJxZYlT4DW/bRUtFh1MQIWqmLwQfAxnqWG4HhEdjMlkrJYnJn0Jrr2u3mgxqaWsdiBc76TYkTG/mhrnYTuzfHw==} engines: {node: '>=4'} dependencies: path-key: 2.0.1 dev: true - /npm-run-path/4.0.1: + /npm-run-path@4.0.1: resolution: {integrity: sha512-S48WzZW777zhNIrn7gxOlISNAqi9ZC/uQFnRdbeIHhZhCA6UqpkOT8T1G7BvfdgP4Er8gF4sUbaS0i7QvIfCWw==} engines: {node: '>=8'} dependencies: path-key: 3.1.1 dev: true - /npm-run-path/5.1.0: + /npm-run-path@5.1.0: resolution: {integrity: sha512-sJOdmRGrY2sjNTRMbSvluQqg+8X7ZK61yvzBEIDhz4f8z1TZFYABsqjjCBd/0PUNE9M6QDgHJXQkGUEm7Q+l9Q==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dependencies: path-key: 4.0.0 dev: true - /npmlog/5.0.1: + /npmlog@5.0.1: resolution: {integrity: sha512-AqZtDUWOMKs1G/8lwylVjrdYgqA4d9nu8hc+0gzRxlDb1I10+FHBGMXs6aiQHFdCUUlqH99MUMuLfzWDNDtfxw==} dependencies: are-we-there-yet: 2.0.0 @@ -16912,25 +18312,25 @@ packages: set-blocking: 2.0.0 dev: true - /nth-check/2.1.1: + /nth-check@2.1.1: resolution: {integrity: sha512-lqjrjmaOoAnWfMmBPL+XNnynZh2+swxiX3WUE0s4yEHI6m+AwrK2UZOimIRl3X/4QctVqS8AiZjFqyOGrMXb/w==} dependencies: boolbase: 1.0.0 dev: true - /num2fraction/1.2.2: + /num2fraction@1.2.2: resolution: {integrity: sha512-Y1wZESM7VUThYY+4W+X4ySH2maqcA+p7UR+w8VWNWVAd6lwuXXWz/w/Cz43J/dI2I+PS6wD5N+bJUF+gjWvIqg==} dev: true - /nwsapi/2.2.7: + /nwsapi@2.2.7: resolution: {integrity: sha512-ub5E4+FBPKwAZx0UwIQOjYWGHTEq5sPqHQNRN8Z9e4A7u3Tj1weLJsL59yH9vmvqEtBHaOmT6cYQKIZOxp35FQ==} dev: true - /object-assign/4.1.1: + /object-assign@4.1.1: resolution: {integrity: sha512-rJgTQnkUnH1sFw8yT6VSU3zD3sWmu6sZhIseY8VX+GRu3P6F7Fu+JNDoXfklElbLJSnc3FUQHVe4cU5hj+BcUg==} engines: {node: '>=0.10.0'} - /object-copy/0.1.0: + /object-copy@0.1.0: resolution: {integrity: sha512-79LYn6VAb63zgtmAteVOWo9Vdj71ZVBy3Pbse+VqxDpEP83XuujMrGqHIwAXJ5I/aM0zU7dIyIAhifVTPrNItQ==} engines: {node: '>=0.10.0'} dependencies: @@ -16939,11 +18339,11 @@ packages: kind-of: 3.2.2 dev: true - /object-inspect/1.12.3: + /object-inspect@1.12.3: resolution: {integrity: sha512-geUvdk7c+eizMNUDkRpW1wJwgfOiOeHbxBR/hLXK1aT6zmVSO0jsQcs7fj6MGw89jC/cjGfLcNOrtMYtGqm81g==} dev: true - /object-is/1.1.5: + /object-is@1.1.5: resolution: {integrity: sha512-3cyDsyHgtmi7I7DfSSI2LDp6SK2lwvtbg0p0R1e0RvTqF5ceGx+K2dfSjm1bKDMVCFEDAQvy+o8c6a7VujOddw==} engines: {node: '>= 0.4'} dependencies: @@ -16951,19 +18351,19 @@ packages: define-properties: 1.2.0 dev: true - /object-keys/1.1.1: + /object-keys@1.1.1: resolution: {integrity: sha512-NuAESUOUMrlIXOfHKzD6bpPu3tYt3xvjNdRIQ+FeT0lNb4K8WR70CaDxhuNguS2XG+GjkyMwOzsN5ZktImfhLA==} engines: {node: '>= 0.4'} dev: true - /object-visit/1.0.1: + /object-visit@1.0.1: resolution: {integrity: sha512-GBaMwwAVK9qbQN3Scdo0OyvgPW7l3lnaVMj84uTOZlswkX0KpF6fyDBJhtTthf7pymztoN36/KEr1DyhF96zEA==} engines: {node: '>=0.10.0'} dependencies: isobject: 3.0.1 dev: true - /object.assign/4.1.4: + /object.assign@4.1.4: resolution: {integrity: sha512-1mxKf0e58bvyjSCtKYY4sRe9itRk3PJpquJOjeIkz885CczcI4IvJJDLPS72oowuSh+pBxUFROpX+TU++hxhZQ==} engines: {node: '>= 0.4'} dependencies: @@ -16973,7 +18373,7 @@ packages: object-keys: 1.1.1 dev: true - /object.entries/1.1.6: + /object.entries@1.1.6: resolution: {integrity: sha512-leTPzo4Zvg3pmbQ3rDK69Rl8GQvIqMWubrkxONG9/ojtFE2rD9fjMKfSI5BxW3osRH1m6VdzmqK8oAY9aT4x5w==} engines: {node: '>= 0.4'} dependencies: @@ -16982,7 +18382,7 @@ packages: es-abstract: 1.21.2 dev: true - /object.fromentries/2.0.6: + /object.fromentries@2.0.6: resolution: {integrity: sha512-VciD13dswC4j1Xt5394WR4MzmAQmlgN72phd/riNp9vtD7tp4QQWJ0R4wvclXcafgcYK8veHRed2W6XeGBvcfg==} engines: {node: '>= 0.4'} dependencies: @@ -16991,7 +18391,7 @@ packages: es-abstract: 1.21.2 dev: true - /object.getownpropertydescriptors/2.1.6: + /object.getownpropertydescriptors@2.1.6: resolution: {integrity: sha512-lq+61g26E/BgHv0ZTFgRvi7NMEPuAxLkFU7rukXjc/AlwH4Am5xXVnIXy3un1bg/JPbXHrixRkK1itUzzPiIjQ==} engines: {node: '>= 0.8'} dependencies: @@ -17002,14 +18402,14 @@ packages: safe-array-concat: 1.0.0 dev: true - /object.pick/1.3.0: + /object.pick@1.3.0: resolution: {integrity: sha512-tqa/UMy/CCoYmj+H5qc07qvSL9dqcs/WZENZ1JbtWBlATP+iVOe778gE6MSijnyCnORzDuX6hU+LA4SZ09YjFQ==} engines: {node: '>=0.10.0'} dependencies: isobject: 3.0.1 dev: true - /object.values/1.1.6: + /object.values@1.1.6: resolution: {integrity: sha512-FVVTkD1vENCsAcwNs9k6jea2uHC/X0+JcjG8YA60FN5CMaJmG95wT9jek/xX9nornqGRrBkKtzuAu2wuHpKqvw==} engines: {node: '>= 0.4'} dependencies: @@ -17018,19 +18418,19 @@ packages: es-abstract: 1.21.2 dev: true - /objectorarray/1.0.5: + /objectorarray@1.0.5: resolution: {integrity: sha512-eJJDYkhJFFbBBAxeh8xW+weHlkI28n2ZdQV/J/DNfWfSKlGEf2xcfAbZTv3riEXHAhL9SVOTs2pRmXiSTf78xg==} dev: true - /oblivious-set/1.0.0: + /oblivious-set@1.0.0: resolution: {integrity: sha512-z+pI07qxo4c2CulUHCDf9lcqDlMSo72N/4rLUpRXf6fu+q8vjt8y0xS+Tlf8NTJDdTXHbdeO1n3MlbctwEoXZw==} dev: false - /obuf/1.1.2: + /obuf@1.1.2: resolution: {integrity: sha512-PX1wu0AmAdPqOL1mWhqmlOd8kOIZQwGZw6rh7uby9fTc5lhaOWFLX3I6R1hrF9k3zUY40e6igsLGkDXK92LJNg==} dev: true - /ofetch/1.1.1: + /ofetch@1.1.1: resolution: {integrity: sha512-SSMoktrp9SNLi20BWfB/BnnKcL0RDigXThD/mZBeQxkIRv1xrd9183MtLdsqRYLYSqW0eTr5t8w8MqjNhvoOQQ==} dependencies: destr: 2.0.0 @@ -17038,11 +18438,11 @@ packages: ufo: 1.1.2 dev: true - /ohash/1.1.2: + /ohash@1.1.2: resolution: {integrity: sha512-9CIOSq5945rI045GFtcO3uudyOkYVY1nyfFxVQp+9BRgslr8jPNiSSrsFGg/BNTUFOLqx0P5tng6G32brIPw0w==} dev: true - /ohmyfetch/0.4.21: + /ohmyfetch@0.4.21: resolution: {integrity: sha512-VG7f/JRvqvBOYvL0tHyEIEG7XHWm7OqIfAs6/HqwWwDfjiJ1g0huIpe5sFEmyb+7hpFa1EGNH2aERWR72tlClw==} dependencies: destr: 1.2.2 @@ -17051,42 +18451,42 @@ packages: undici: 5.22.1 dev: true - /on-exit-leak-free/2.1.0: + /on-exit-leak-free@2.1.0: resolution: {integrity: sha512-VuCaZZAjReZ3vUwgOB8LxAosIurDiAW0s13rI1YwmaP++jvcxP77AWoQvenZebpCA2m8WC1/EosPYPMjnRAp/w==} dev: true - /on-finished/2.4.1: + /on-finished@2.4.1: resolution: {integrity: sha512-oVlzkg3ENAhCk2zdv7IJwd/QUD4z2RxRwpkcGY8psCVcCYZNq4wYnVWALHM+brtuJjePWiYF/ClmuDr8Ch5+kg==} engines: {node: '>= 0.8'} dependencies: ee-first: 1.1.1 dev: true - /on-headers/1.0.2: + /on-headers@1.0.2: resolution: {integrity: sha512-pZAE+FJLoyITytdqK0U5s+FIpjN0JP3OzFi/u8Rx+EV5/W+JTWGXG8xFzevE7AjBfDqHv/8vL8qQsIhHnqRkrA==} engines: {node: '>= 0.8'} dev: true - /once/1.4.0: + /once@1.4.0: resolution: {integrity: sha512-lNaJgI+2Q5URQBkccEKHTQOPaXdUxnZZElQTZY0MFUAuaEqe1E+Nyvgdz/aIyNi6Z9MzO5dv1H8n58/GELp3+w==} dependencies: wrappy: 1.0.2 - /onetime/5.1.2: + /onetime@5.1.2: resolution: {integrity: sha512-kbpaSSGJTWdAY5KPVeMOKXSrPtr8C8C7wodJbcsd51jRnmD+GZu8Y0VoU6Dm5Z4vWr0Ig/1NKuWRKf7j5aaYSg==} engines: {node: '>=6'} dependencies: mimic-fn: 2.1.0 dev: true - /onetime/6.0.0: + /onetime@6.0.0: resolution: {integrity: sha512-1FlR+gjXK7X+AsAHso35MnyN5KqGwJRi/31ft6x0M194ht7S+rWAvd7PHss9xSKMzE0asv1pyIHaJYq+BbacAQ==} engines: {node: '>=12'} dependencies: mimic-fn: 4.0.0 dev: true - /open/7.4.2: + /open@7.4.2: resolution: {integrity: sha512-MVHddDVweXZF3awtlAS+6pgKLlm/JgxZ90+/NBurBoQctVOOB/zDdVjcyPzQ+0laDGbsWgrRkflI65sQeOgT9Q==} engines: {node: '>=8'} dependencies: @@ -17094,7 +18494,7 @@ packages: is-wsl: 2.2.0 dev: true - /open/8.4.2: + /open@8.4.2: resolution: {integrity: sha512-7x81NCL719oNbsq/3mh+hVrAWmFuEYUqrq/Iw3kUzH8ReypT9QQ0BLoJS7/G9k6N81XjW4qHWtjWwe/9eLy1EQ==} engines: {node: '>=12'} dependencies: @@ -17103,14 +18503,14 @@ packages: is-wsl: 2.2.0 dev: true - /optimism/0.16.2: + /optimism@0.16.2: resolution: {integrity: sha512-zWNbgWj+3vLEjZNIh/okkY2EUfX+vB9TJopzIZwT1xxaMqC5hRLLraePod4c5n4He08xuXNH+zhKFFCu390wiQ==} dependencies: '@wry/context': 0.7.3 '@wry/trie': 0.3.2 dev: false - /optionator/0.9.3: + /optionator@0.9.3: resolution: {integrity: sha512-JjCoypp+jKn1ttEFExxhetCKeJt9zhAgAve5FXHixTvFDW/5aEktX9bufBKLRRMdU7bNtpLfcGu94B3cdEJgjg==} engines: {node: '>= 0.8.0'} dependencies: @@ -17122,7 +18522,7 @@ packages: type-check: 0.4.0 dev: true - /ora/5.4.1: + /ora@5.4.1: resolution: {integrity: sha512-5b6Y85tPxZZ7QytO+BQzysW31HJku27cRIlkbAXaNx+BdcVi+LlRFmVXzeF6a7JCwJpyw5c4b+YSVImQIrBpuQ==} engines: {node: '>=10'} dependencies: @@ -17137,154 +18537,154 @@ packages: wcwidth: 1.0.1 dev: true - /os-browserify/0.3.0: + /os-browserify@0.3.0: resolution: {integrity: sha512-gjcpUc3clBf9+210TRaDWbf+rZZZEshZ+DlXMRCeAjp0xhTrnQsKHypIy1J3d5hKdUzj69t708EHtU8P6bUn0A==} dev: true - /os-homedir/1.0.2: + /os-homedir@1.0.2: resolution: {integrity: sha512-B5JU3cabzk8c67mRRd3ECmROafjYMXbuzlwtqdM8IbS8ktlTix8aFGb2bAGKrSRIlnfKwovGUUr72JUPyOb6kQ==} engines: {node: '>=0.10.0'} dev: true optional: true - /os-tmpdir/1.0.2: + /os-tmpdir@1.0.2: resolution: {integrity: sha512-D2FR03Vir7FIu45XBY20mTb+/ZSWB00sjU9jdQXt83gDrI4Ztz5Fs7/yy74g2N5SVQY4xY1qDr4rNddwYRVX0g==} engines: {node: '>=0.10.0'} dev: true - /ospath/1.2.2: + /ospath@1.2.2: resolution: {integrity: sha512-o6E5qJV5zkAbIDNhGSIlyOhScKXgQrSRMilfph0clDfM0nEnBOlKlH4sWDmG95BW/CvwNz0vmm7dJVtU2KlMiA==} dev: true - /outvariant/1.4.0: + /outvariant@1.4.0: resolution: {integrity: sha512-AlWY719RF02ujitly7Kk/0QlV+pXGFDHrHf9O2OKqyqgBieaPOIeuSkL8sRK6j2WK+/ZAURq2kZsY0d8JapUiw==} dev: true - /p-all/2.1.0: + /p-all@2.1.0: resolution: {integrity: sha512-HbZxz5FONzz/z2gJfk6bFca0BCiSRF8jU3yCsWOen/vR6lZjfPOu/e7L3uFzTW1i0H8TlC3vqQstEJPQL4/uLA==} engines: {node: '>=6'} dependencies: p-map: 2.1.0 dev: true - /p-cancelable/3.0.0: + /p-cancelable@3.0.0: resolution: {integrity: sha512-mlVgR3PGuzlo0MmTdk4cXqXWlwQDLnONTAg6sm62XkMJEiRxN3GL3SffkYvqwonbkJBcrI7Uvv5Zh9yjvn2iUw==} engines: {node: '>=12.20'} dev: true - /p-event/4.2.0: + /p-event@4.2.0: resolution: {integrity: sha512-KXatOjCRXXkSePPb1Nbi0p0m+gQAwdlbhi4wQKJPI1HsMQS9g+Sqp2o+QHziPr7eYJyOZet836KoHEVM1mwOrQ==} engines: {node: '>=8'} dependencies: p-timeout: 3.2.0 dev: true - /p-filter/2.1.0: + /p-filter@2.1.0: resolution: {integrity: sha512-ZBxxZ5sL2HghephhpGAQdoskxplTwr7ICaehZwLIlfL6acuVgZPm8yBNuRAFBGEqtD/hmUeq9eqLg2ys9Xr/yw==} engines: {node: '>=8'} dependencies: p-map: 2.1.0 dev: true - /p-finally/1.0.0: + /p-finally@1.0.0: resolution: {integrity: sha512-LICb2p9CB7FS+0eR1oqWnHhp0FljGLZCWBE9aix0Uye9W8LTQPwMTYVGWQWIw9RdQiDg4+epXQODwIYJtSJaow==} engines: {node: '>=4'} dev: true - /p-iteration/1.1.8: + /p-iteration@1.1.8: resolution: {integrity: sha512-IMFBSDIYcPNnW7uWYGrBqmvTiq7W0uB0fJn6shQZs7dlF3OvrHOre+JT9ikSZ7gZS3vWqclVgoQSvToJrns7uQ==} engines: {node: '>=8.0.0'} dev: true - /p-limit/2.3.0: + /p-limit@2.3.0: resolution: {integrity: sha512-//88mFWSJx8lxCzwdAABTJL2MyWB12+eIY7MDL2SqLmAkeKU9qxRvWuSyTjm3FUmpBEMuFfckAIqEaVGUDxb6w==} engines: {node: '>=6'} dependencies: p-try: 2.2.0 dev: true - /p-limit/3.1.0: + /p-limit@3.1.0: resolution: {integrity: sha512-TYOanM3wGwNGsZN2cVTYPArw454xnXj5qmWF1bEoAc4+cU/ol7GVh7odevjp1FNHduHc3KZMcFduxU5Xc6uJRQ==} engines: {node: '>=10'} dependencies: yocto-queue: 0.1.0 dev: true - /p-limit/4.0.0: + /p-limit@4.0.0: resolution: {integrity: sha512-5b0R4txpzjPWVw/cXXUResoD4hb6U/x9BH08L7nw+GN1sezDzPdxeRvpc9c433fZhBan/wusjbCsqwqm4EIBIQ==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dependencies: yocto-queue: 1.0.0 - /p-locate/3.0.0: + /p-locate@3.0.0: resolution: {integrity: sha512-x+12w/To+4GFfgJhBEpiDcLozRJGegY+Ei7/z0tSLkMmxGZNybVMSfWj9aJn8Z5Fc7dBUNJOOVgPv2H7IwulSQ==} engines: {node: '>=6'} dependencies: p-limit: 2.3.0 dev: true - /p-locate/4.1.0: + /p-locate@4.1.0: resolution: {integrity: sha512-R79ZZ/0wAxKGu3oYMlz8jy/kbhsNrS7SKZ7PxEHBgJ5+F2mtFW2fK2cOtBh1cHYkQsbzFV7I+EoRKe6Yt0oK7A==} engines: {node: '>=8'} dependencies: p-limit: 2.3.0 dev: true - /p-locate/5.0.0: + /p-locate@5.0.0: resolution: {integrity: sha512-LaNjtRWUBY++zB5nE/NwcaoMylSPk+S+ZHNB1TzdbMJMny6dynpAGt7X/tl/QYq3TIeE6nxHppbo2LGymrG5Pw==} engines: {node: '>=10'} dependencies: p-limit: 3.1.0 dev: true - /p-locate/6.0.0: + /p-locate@6.0.0: resolution: {integrity: sha512-wPrq66Llhl7/4AGC6I+cqxT07LhXvWL08LNXz1fENOw0Ap4sRZZ/gZpTTJ5jpurzzzfS2W/Ge9BY3LgLjCShcw==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dependencies: p-limit: 4.0.0 dev: true - /p-map/2.1.0: + /p-map@2.1.0: resolution: {integrity: sha512-y3b8Kpd8OAN444hxfBbFfj1FY/RjtTd8tzYwhUqNYXx0fXx2iX4maP4Qr6qhIKbQXI02wTLAda4fYUbDagTUFw==} engines: {node: '>=6'} dev: true - /p-map/3.0.0: + /p-map@3.0.0: resolution: {integrity: sha512-d3qXVTF/s+W+CdJ5A29wywV2n8CQQYahlgz2bFiA+4eVNJbHJodPZ+/gXwPGh0bOqA+j8S+6+ckmvLGPk1QpxQ==} engines: {node: '>=8'} dependencies: aggregate-error: 3.1.0 dev: true - /p-map/4.0.0: + /p-map@4.0.0: resolution: {integrity: sha512-/bjOqmgETBYB5BoEeGVea8dmvHb2m9GLy1E9W43yeyfP6QQCZGFNa+XRceJEuDB6zqr+gKpIAmlLebMpykw/MQ==} engines: {node: '>=10'} dependencies: aggregate-error: 3.1.0 dev: true - /p-timeout/3.2.0: + /p-timeout@3.2.0: resolution: {integrity: sha512-rhIwUycgwwKcP9yTOOFK/AKsAopjjCakVqLHePO3CC6Mir1Z99xT+R63jZxAT5lFZLa2inS5h+ZS2GvR99/FBg==} engines: {node: '>=8'} dependencies: p-finally: 1.0.0 dev: true - /p-try/2.2.0: + /p-try@2.2.0: resolution: {integrity: sha512-R4nPAVTAU0B9D35/Gk3uJf/7XYbQcyohSKdvAxIRSNghFl4e71hVoGnBNQz9cWaXxO2I10KTC+3jMdvvoKw6dQ==} engines: {node: '>=6'} dev: true - /package-name-regex/2.0.6: + /package-name-regex@2.0.6: resolution: {integrity: sha512-gFL35q7kbE/zBaPA3UKhp2vSzcPYx2ecbYuwv1ucE9Il6IIgBDweBlH8D68UFGZic2MkllKa2KHCfC1IQBQUYA==} engines: {node: '>=12'} dev: true - /pako/1.0.11: + /pako@1.0.11: resolution: {integrity: sha512-4hLB8Py4zZce5s4yd9XzopqwVv/yGNhV1Bl8NTmCq1763HeK2+EwVTv+leGeL13Dnh2wfbqowVPXCIO0z4taYw==} dev: true - /parallel-transform/1.2.0: + /parallel-transform@1.2.0: resolution: {integrity: sha512-P2vSmIu38uIlvdcU7fDkyrxj33gTUy/ABO5ZUbGowxNCopBq/OoD42bP4UmMrJoPyk4Uqf0mu3mtWBhHCZD8yg==} dependencies: cyclist: 1.0.2 @@ -17292,20 +18692,20 @@ packages: readable-stream: 2.3.8 dev: true - /param-case/3.0.4: + /param-case@3.0.4: resolution: {integrity: sha512-RXlj7zCYokReqWpOPH9oYivUzLYZ5vAPIfEmCTNViosC78F8F0H9y7T7gG2M39ymgutxF5gcFEsyZQSph9Bp3A==} dependencies: dot-case: 3.0.4 tslib: 2.6.0 dev: true - /parent-module/1.0.1: + /parent-module@1.0.1: resolution: {integrity: sha512-GQ2EWRpQV8/o+Aw8YqtfZZPfNRWZYkbidE9k5rpl/hC3vtHHBfGm2Ifi6qWV+coDGkrUKZAxE3Lot5kcsRlh+g==} engines: {node: '>=6'} dependencies: callsites: 3.1.0 - /parse-asn1/5.1.6: + /parse-asn1@5.1.6: resolution: {integrity: sha512-RnZRo1EPU6JBnra2vGHj0yhp6ebyjBZpmUCLHWiFhxlzvBCCpAuZ7elsBp1PVAbQN0/04VD/19rfzlBSwLstMw==} dependencies: asn1.js: 5.4.1 @@ -17315,12 +18715,12 @@ packages: safe-buffer: 5.2.1 dev: true - /parse-code-context/1.0.0: + /parse-code-context@1.0.0: resolution: {integrity: sha512-OZQaqKaQnR21iqhlnPfVisFjBWjhnMl5J9MgbP8xC+EwoVqbXrq78lp+9Zb3ahmLzrIX5Us/qbvBnaS3hkH6OA==} engines: {node: '>=6'} dev: true - /parse-entities/2.0.0: + /parse-entities@2.0.0: resolution: {integrity: sha512-kkywGpCcRYhqQIchaWqZ875wzpS/bMKhz5HnN3p7wveJTkTtyAB/AlnS0f8DFSqYW1T82t6yEAkEcB+A1I3MbQ==} dependencies: character-entities: 1.2.4 @@ -17331,7 +18731,7 @@ packages: is-hexadecimal: 1.0.4 dev: true - /parse-json/2.2.0: + /parse-json@2.2.0: resolution: {integrity: sha512-QR/GGaKCkhwk1ePQNYDRKYZ3mwU9ypsKhB0XyFnLQdomyEqk3e8wpW3V5Jp88zbxK4n5ST1nqo+g9juTpownhQ==} engines: {node: '>=0.10.0'} dependencies: @@ -17339,7 +18739,7 @@ packages: dev: true optional: true - /parse-json/4.0.0: + /parse-json@4.0.0: resolution: {integrity: sha512-aOIos8bujGN93/8Ox/jPLh7RwVnPEysynVFE+fQZyg6jKELEHwzgKdLRFHUgXJL6kylijVSBC4BvN9OmsB48Rw==} engines: {node: '>=4'} dependencies: @@ -17347,7 +18747,7 @@ packages: json-parse-better-errors: 1.0.2 dev: true - /parse-json/5.2.0: + /parse-json@5.2.0: resolution: {integrity: sha512-ayCKvm/phCGxOkYRSCM82iDwct8/EonSEgCSxWxD7ve6jHggsFl4fZVQBPRNgQoKiuV/odhFrGzQXZwbifC8Rg==} engines: {node: '>=8'} dependencies: @@ -17356,49 +18756,49 @@ packages: json-parse-even-better-errors: 2.3.1 lines-and-columns: 1.2.4 - /parse5-htmlparser2-tree-adapter/7.0.0: + /parse5-htmlparser2-tree-adapter@7.0.0: resolution: {integrity: sha512-B77tOZrqqfUfnVcOrUvfdLbz4pu4RopLD/4vmu3HUPswwTA8OH0EMW9BlWR2B0RCoiZRAHEUu7IxeP1Pd1UU+g==} dependencies: domhandler: 5.0.3 parse5: 7.1.2 dev: true - /parse5/6.0.1: + /parse5@6.0.1: resolution: {integrity: sha512-Ofn/CTFzRGTTxwpNEs9PP93gXShHcTq255nzRYSKe8AkVpZY7e1fpmTfOyoIvjP5HG7Z2ZM7VS9PPhQGW2pOpw==} dev: true - /parse5/7.1.2: + /parse5@7.1.2: resolution: {integrity: sha512-Czj1WaSVpaoj0wbhMzLmWD69anp2WH7FXMB9n1Sy8/ZFF9jolSQVMu1Ij5WIyGmcBmhk7EOndpO4mIpihVqAXw==} dependencies: entities: 4.5.0 dev: true - /parseurl/1.3.3: + /parseurl@1.3.3: resolution: {integrity: sha512-CiyeOxFT/JZyN5m0z9PfXw4SCBJ6Sygz1Dpl0wqjlhDEGGBP1GnsUVEL0p63hoG1fcj3fHynXi9NYO4nWOL+qQ==} engines: {node: '>= 0.8'} dev: true - /pascal-case/3.1.2: + /pascal-case@3.1.2: resolution: {integrity: sha512-uWlGT3YSnK9x3BQJaOdcZwrnV6hPpd8jFH1/ucpiLRPh/2zCVJKS19E4GvYHvaCcACn3foXZ0cLB9Wrx1KGe5g==} dependencies: no-case: 3.0.4 tslib: 2.6.0 dev: true - /pascalcase/0.1.1: + /pascalcase@0.1.1: resolution: {integrity: sha512-XHXfu/yOQRy9vYOtUDVMN60OEJjW013GoObG1o+xwQTpB9eYJX/BjXMsdW13ZDPruFhYYn0AG22w0xgQMwl3Nw==} engines: {node: '>=0.10.0'} dev: true - /path-browserify/0.0.1: + /path-browserify@0.0.1: resolution: {integrity: sha512-BapA40NHICOS+USX9SN4tyhq+A2RrN/Ws5F0Z5aMHDp98Fl86lX8Oti8B7uN93L4Ifv4fHOEA+pQw87gmMO/lQ==} dev: true - /path-dirname/1.0.2: + /path-dirname@1.0.2: resolution: {integrity: sha512-ALzNPpyNq9AqXMBjeymIjFDAkAFH06mHJH/cSBHAgU0s4vfpBn6b2nf8tiRLvagKD8RbTpq2FKTBg7cl9l3c7Q==} dev: true - /path-exists/2.1.0: + /path-exists@2.1.0: resolution: {integrity: sha512-yTltuKuhtNeFJKa1PiRzfLAU5182q1y4Eb4XCJ3PBqyzEDkAZRzBrKKBct682ls9reBVHf9udYLN5Nd+K1B9BQ==} engines: {node: '>=0.10.0'} dependencies: @@ -17406,44 +18806,44 @@ packages: dev: true optional: true - /path-exists/3.0.0: + /path-exists@3.0.0: resolution: {integrity: sha512-bpC7GYwiDYQ4wYLe+FA8lhRjhQCMcQGuSgGGqDkg/QerRWw9CmGRT0iSOVRSZJ29NMLZgIzqaljJ63oaL4NIJQ==} engines: {node: '>=4'} dev: true - /path-exists/4.0.0: + /path-exists@4.0.0: resolution: {integrity: sha512-ak9Qy5Q7jYb2Wwcey5Fpvg2KoAc/ZIhLSLOSBmRmygPsGwkVVt0fZa0qrtMz+m6tJTAHfZQ8FnmB4MG4LWy7/w==} engines: {node: '>=8'} dev: true - /path-exists/5.0.0: + /path-exists@5.0.0: resolution: {integrity: sha512-RjhtfwJOxzcFmNOi6ltcbcu4Iu+FL3zEj83dk4kAS+fVpTxXLO1b38RvJgT/0QwvV/L3aY9TAnyv0EOqW4GoMQ==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dev: true - /path-is-absolute/1.0.1: + /path-is-absolute@1.0.1: resolution: {integrity: sha512-AVbw3UJ2e9bq64vSaS9Am0fje1Pa8pbGqTTsmXfaIiMpnr5DlDhfJOuLj9Sf95ZPVDAUerDfEk88MPmPe7UCQg==} engines: {node: '>=0.10.0'} - /path-key/2.0.1: + /path-key@2.0.1: resolution: {integrity: sha512-fEHGKCSmUSDPv4uoj8AlD+joPlq3peND+HRYyxFz4KPw4z926S/b8rIuFs2FYJg3BwsxJf6A9/3eIdLaYC+9Dw==} engines: {node: '>=4'} dev: true - /path-key/3.1.1: + /path-key@3.1.1: resolution: {integrity: sha512-ojmeN0qd+y0jszEtoY48r0Peq5dwMEkIlCOu6Q5f41lfkswXuKtYrhgoTpLnyIcHm24Uhqx+5Tqm2InSwLhE6Q==} engines: {node: '>=8'} dev: true - /path-key/4.0.0: + /path-key@4.0.0: resolution: {integrity: sha512-haREypq7xkM7ErfgIyA0z+Bj4AGKlMSdlQE2jvJo6huWD1EdkKYV+G/T4nq0YEF2vgTT8kqMFKo1uHn950r4SQ==} engines: {node: '>=12'} dev: true - /path-parse/1.0.7: + /path-parse@1.0.7: resolution: {integrity: sha512-LDJzPVEEEPR+y48z93A0Ed0yXb8pAByGWo/k5YYdYgpY2/2EsOsksJrq7lOHxryrVOn1ejG6oAp8ahvOIQD8sw==} - /path-scurry/1.10.1: + /path-scurry@1.10.1: resolution: {integrity: sha512-MkhCqzzBEpPvxxQ71Md0b1Kk51W01lrYvlMzSUaIzNsODdd7mqhiimSZlr+VegAz5Z6Vzt9Xg2ttE//XBhH3EQ==} engines: {node: '>=16 || 14 >=14.17'} dependencies: @@ -17451,15 +18851,15 @@ packages: minipass: 7.0.2 dev: true - /path-to-regexp/0.1.7: + /path-to-regexp@0.1.7: resolution: {integrity: sha512-5DFkuoqlv1uYQKxy8omFBeJPQcdoE07Kv2sferDCrAq1ohOU+MSDswDIbnx3YAM60qIOnYa53wBhXW0EbMonrQ==} dev: true - /path-to-regexp/6.2.1: + /path-to-regexp@6.2.1: resolution: {integrity: sha512-JLyh7xT1kizaEvcaXOQwOc2/Yhw6KZOvPf1S8401UyLk86CU79LN3vl7ztXGm/pZ+YjoyAJ4rxmHwbkBXJX+yw==} dev: true - /path-type/1.1.0: + /path-type@1.1.0: resolution: {integrity: sha512-S4eENJz1pkiQn9Znv33Q+deTOKmbl+jj1Fl+qiP/vYezj+S8x+J3Uo0ISrx/QoEvIlOaDWJhPaRd1flJ9HXZqg==} engines: {node: '>=0.10.0'} dependencies: @@ -17469,29 +18869,29 @@ packages: dev: true optional: true - /path-type/3.0.0: + /path-type@3.0.0: resolution: {integrity: sha512-T2ZUsdZFHgA3u4e5PfPbjd7HDDpxPnQb5jN0SrDsjNSuVXHJqtwTnWqG0B1jZrgmJ/7lj1EmVIByWt1gxGkWvg==} engines: {node: '>=4'} dependencies: pify: 3.0.0 dev: true - /path-type/4.0.0: + /path-type@4.0.0: resolution: {integrity: sha512-gDKb8aZMDeD/tZWs9P6+q0J9Mwkdl6xMV8TjnGP3qJVJ06bdMgkbBlLU8IdfOsIsFz2BW1rNVT3XuNEl8zPAvw==} engines: {node: '>=8'} - /pathe/0.3.9: + /pathe@0.3.9: resolution: {integrity: sha512-6Y6s0vT112P3jD8dGfuS6r+lpa0qqNrLyHPOwvXMnyNTQaYiwgau2DP3aNDsR13xqtGj7rrPo+jFUATpU6/s+g==} dev: true - /pathe/1.1.1: + /pathe@1.1.1: resolution: {integrity: sha512-d+RQGp0MAYTIaDBIMmOfMwz3E+LOZnxx1HZd5R18mmCZY0QBlK0LDZfPc8FW8Ed2DlvsuE6PRjroDY+wg4+j/Q==} - /pathval/1.1.1: + /pathval@1.1.1: resolution: {integrity: sha512-Dp6zGqpTdETdR63lehJYPeIOqpiNBNtc7BpWSLrOje7UaIsE5aY92r/AunQA7rsXvet3lrJ3JnZX29UPTKXyKQ==} dev: false - /pbkdf2/3.1.2: + /pbkdf2@3.1.2: resolution: {integrity: sha512-iuh7L6jA7JEGu2WxDwtQP1ddOpaJNC4KlDEFfdQajSGgGPNi4OyDc2R7QnbY2bR9QjBVGwgvTdNJZoE7RaxUMA==} engines: {node: '>=0.12'} dependencies: @@ -17502,19 +18902,19 @@ packages: sha.js: 2.4.11 dev: true - /pend/1.2.0: + /pend@1.2.0: resolution: {integrity: sha512-F3asv42UuXchdzt+xXqfW1OGlVBe+mxa2mqI0pg5yAHZPvFmY3Y6drSf/GQ1A86WgWEN9Kzh/WrgKa6iGcHXLg==} dev: true - /perfect-debounce/1.0.0: + /perfect-debounce@1.0.0: resolution: {integrity: sha512-xCy9V055GLEqoFaHoC1SoLIaLmWctgCUaBaWxDZ7/Zx4CTyX7cJQLJOok/orfjZAh9kEYpjJa4d0KcJmCbctZA==} dev: true - /performance-now/2.1.0: + /performance-now@2.1.0: resolution: {integrity: sha512-7EAHlyLHI56VEIdK57uwHdHKIaAGbnXPiw0yWbarQZOKaKpvUIgW0jWRVLiatnM+XXlSwsanIBH/hzGMJulMow==} dev: true - /periscopic/3.1.0: + /periscopic@3.1.0: resolution: {integrity: sha512-vKiQ8RRtkl9P+r/+oefh25C3fhybptkHKCZSPlcXiJux2tJF55GnEj3BVn4A5gKfq9NWWXXrxkHBwVPUfH0opw==} dependencies: '@types/estree': 1.0.1 @@ -17522,45 +18922,45 @@ packages: is-reference: 3.0.1 dev: true - /picocolors/0.2.1: + /picocolors@0.2.1: resolution: {integrity: sha512-cMlDqaLEqfSaW8Z7N5Jw+lyIW869EzT73/F5lhtY9cLGoVxSXznfgfXMO0Z5K0o0Q2TkTXq+0KFsdnSe3jDViA==} dev: true - /picocolors/1.0.0: + /picocolors@1.0.0: resolution: {integrity: sha512-1fygroTLlHu66zi26VoTDv8yRgm0Fccecssto+MhsZ0D/DGW2sm8E8AjW7NU5VVTRt5GxbeZ5qBuJr+HyLYkjQ==} - /picomatch/2.3.1: + /picomatch@2.3.1: resolution: {integrity: sha512-JU3teHTNjmE2VCGFzuY8EXzCDVwEqB2a8fsIvwaStHhAWJEeVd1o1QD80CU6+ZdEXXSLbSsuLwJjkCBWqRQUVA==} engines: {node: '>=8.6'} - /pidtree/0.3.1: + /pidtree@0.3.1: resolution: {integrity: sha512-qQbW94hLHEqCg7nhby4yRC7G2+jYHY4Rguc2bjw7Uug4GIJuu1tvf2uHaZv5Q8zdt+WKJ6qK1FOI6amaWUo5FA==} engines: {node: '>=0.10'} hasBin: true dev: true - /pidtree/0.6.0: + /pidtree@0.6.0: resolution: {integrity: sha512-eG2dWTVw5bzqGRztnHExczNxt5VGsE6OwTeCG3fdUf9KBsZzO3R5OIIIzWR+iZA0NtZ+RDVdaoE2dK1cn6jH4g==} engines: {node: '>=0.10'} hasBin: true dev: true - /pify/2.3.0: + /pify@2.3.0: resolution: {integrity: sha512-udgsAY+fTnvv7kI7aaxbqwWNb0AHiB0qBO89PZKPkoTmGOgdbrHDKD+0B2X4uTfJ/FT1R09r9gTsjUjNJotuog==} engines: {node: '>=0.10.0'} dev: true - /pify/3.0.0: + /pify@3.0.0: resolution: {integrity: sha512-C3FsVNH1udSEX48gGX1xfvwTWfsYWj5U+8/uK15BGzIGrKoUpghX8hWZwa/OFnakBiiVNmBvemTJR5mcy7iPcg==} engines: {node: '>=4'} dev: true - /pify/4.0.1: + /pify@4.0.1: resolution: {integrity: sha512-uB80kBFb/tfd68bVleG9T5GGsGPjJrLAUpR5PZIrhBnIaRTQRjqdJSsIKkOP6OAIFbj7GOrcudc5pNjZ+geV2g==} engines: {node: '>=6'} dev: true - /pinkie-promise/2.0.1: + /pinkie-promise@2.0.1: resolution: {integrity: sha512-0Gni6D4UcLTbv9c57DfxDGdr41XfgUjqWZu492f0cIGr16zDU06BWP/RAEvOuo7CQ0CNjHaLlM59YJJFm3NWlw==} engines: {node: '>=0.10.0'} dependencies: @@ -17568,24 +18968,24 @@ packages: dev: true optional: true - /pinkie/2.0.4: + /pinkie@2.0.4: resolution: {integrity: sha512-MnUuEycAemtSaeFSjXKW/aroV7akBbY+Sv+RkyqFjgAe73F+MR0TBWKBRDkmfWq/HiFmdavfZ1G7h4SPZXaCSg==} engines: {node: '>=0.10.0'} dev: true optional: true - /pino-abstract-transport/1.0.0: + /pino-abstract-transport@1.0.0: resolution: {integrity: sha512-c7vo5OpW4wIS42hUVcT5REsL8ZljsUfBjqV/e2sFxmFEFZiq1XLUp5EYLtuDH6PEHq9W1egWqRbnLUP5FuZmOA==} dependencies: readable-stream: 4.4.2 split2: 4.2.0 dev: true - /pino-std-serializers/6.2.2: + /pino-std-serializers@6.2.2: resolution: {integrity: sha512-cHjPPsE+vhj/tnhCy/wiMh3M3z3h/j15zHQX+S9GkTBgqJuTuJzYJ4gUyACLhDaJ7kk9ba9iRDmbH2tJU03OiA==} dev: true - /pino/8.14.1: + /pino@8.14.1: resolution: {integrity: sha512-8LYNv7BKWXSfS+k6oEc6occy5La+q2sPwU3q2ljTX5AZk7v+5kND2o5W794FyRaqha6DJajmkNRsWtPpFyMUdw==} hasBin: true dependencies: @@ -17602,47 +19002,47 @@ packages: thread-stream: 2.3.0 dev: true - /pirates/4.0.6: + /pirates@4.0.6: resolution: {integrity: sha512-saLsH7WeYYPiD25LDuLRRY/i+6HaPYr6G1OUlN39otzkSTxKnubR9RTxS3/Kk50s1g2JTgFwWQDQyplC5/SHZg==} engines: {node: '>= 6'} dev: true - /pixelmatch/5.3.0: + /pixelmatch@5.3.0: resolution: {integrity: sha512-o8mkY4E/+LNUf6LzX96ht6k6CEDi65k9G2rjMtBe9Oo+VPKSvl+0GKHuH/AlG+GA5LPG/i5hrekkxUc3s2HU+Q==} hasBin: true dependencies: pngjs: 6.0.0 dev: true - /pkg-dir/3.0.0: + /pkg-dir@3.0.0: resolution: {integrity: sha512-/E57AYkoeQ25qkxMj5PBOVgF8Kiu/h7cYS30Z5+R7WaiCCBfLq58ZI/dSeaEKb9WVJV5n/03QwrN3IeWIFllvw==} engines: {node: '>=6'} dependencies: find-up: 3.0.0 dev: true - /pkg-dir/4.2.0: + /pkg-dir@4.2.0: resolution: {integrity: sha512-HRDzbaKjC+AOWVXxAU/x54COGeIv9eb+6CkDSQoNTt4XyWoIJvuPsXizxu/Fr23EiekbtZwmh1IcIG/l/a10GQ==} engines: {node: '>=8'} dependencies: find-up: 4.1.0 dev: true - /pkg-dir/5.0.0: + /pkg-dir@5.0.0: resolution: {integrity: sha512-NPE8TDbzl/3YQYY7CSS228s3g2ollTFnc+Qi3tqmqJp9Vg2ovUpixcJEo2HJScN2Ez+kEaal6y70c0ehqJBJeA==} engines: {node: '>=10'} dependencies: find-up: 5.0.0 dev: true - /pkg-types/1.0.3: + /pkg-types@1.0.3: resolution: {integrity: sha512-nN7pYi0AQqJnoLPC9eHFQ8AcyaixBUOwvqc5TDnIKCMEE6I0y8P7OKA7fPexsXGCGxQDl/cmrLAp26LhcwxZ4A==} dependencies: jsonc-parser: 3.2.0 mlly: 1.4.0 pathe: 1.1.1 - /playwright-chromium/1.36.0: + /playwright-chromium@1.36.0: resolution: {integrity: sha512-AU4/euzKqiIeK7JMsxMlgVx3jRFOnXF0vkptF9mfqeNSETVYCbovZ9EpwJ3Kzm/vVAmIlpHp+VoXdX2bi+05Zg==} engines: {node: '>=16'} hasBin: true @@ -17651,13 +19051,13 @@ packages: playwright-core: 1.36.0 dev: true - /playwright-core/1.36.0: + /playwright-core@1.36.0: resolution: {integrity: sha512-7RTr8P6YJPAqB+8j5ATGHqD6LvLLM39sYVNsslh78g8QeLcBs5750c6+msjrHUwwGt+kEbczBj1XB22WMwn+WA==} engines: {node: '>=16'} hasBin: true dev: true - /playwright/1.36.0: + /playwright@1.36.0: resolution: {integrity: sha512-ODVOTp5WoRMxDJY3liMmC+wVNicc0cQB17gASvQ+zLBggVK9a2x3gdT5mbl7av+zomvtdirWOqqfD+O6qIrFgw==} engines: {node: '>=16'} hasBin: true @@ -17666,55 +19066,55 @@ packages: playwright-core: 1.36.0 dev: true - /pluralize/8.0.0: + /pluralize@8.0.0: resolution: {integrity: sha512-Nc3IT5yHzflTfbjgqWcCPpo7DaKy4FnpB0l/zCAW0Tc7jxAiuqSxHasntB3D7887LSrA93kDJ9IXovxJYxyLCA==} engines: {node: '>=4'} dev: true - /pngjs/3.4.0: + /pngjs@3.4.0: resolution: {integrity: sha512-NCrCHhWmnQklfH4MtJMRjZ2a8c80qXeMlQMv2uVp9ISJMTt562SbGd6n2oq0PaPgKm7Z6pL9E2UlLIhC+SHL3w==} engines: {node: '>=4.0.0'} dev: true - /pngjs/6.0.0: + /pngjs@6.0.0: resolution: {integrity: sha512-TRzzuFRRmEoSW/p1KVAmiOgPco2Irlah+bGFCeNfJXxxYGwSw7YwAOAcd7X28K/m5bjBWKsC29KyoMfHbypayg==} engines: {node: '>=12.13.0'} dev: true - /pnp-webpack-plugin/1.6.4_typescript@4.9.5: + /pnp-webpack-plugin@1.6.4(typescript@4.9.5): resolution: {integrity: sha512-7Wjy+9E3WwLOEL30D+m8TSTF7qJJUJLONBnwQp0518siuMxUQUbgZwssaFX+QKlZkjHZcw/IpZCt/H0srrntSg==} engines: {node: '>=6'} dependencies: - ts-pnp: 1.2.0_typescript@4.9.5 + ts-pnp: 1.2.0(typescript@4.9.5) transitivePeerDependencies: - typescript dev: true - /pnpm/8.6.6: + /pnpm@8.6.6: resolution: {integrity: sha512-a51bIJyCmvstgCvsWf6SgZnsXfWmwAW1pHWEaH2gN3vqQGC58yLFL/oKBwcZWH0mjpMzBWRXdS9dLdN6GAK2Rw==} engines: {node: '>=16.14'} hasBin: true dev: true - /polished/4.2.2: + /polished@4.2.2: resolution: {integrity: sha512-Sz2Lkdxz6F2Pgnpi9U5Ng/WdWAUZxmHrNPoVlm3aAemxoy2Qy7LGjQg4uf8qKelDAUW94F4np3iH2YPf2qefcQ==} engines: {node: '>=10'} dependencies: '@babel/runtime': 7.22.6 dev: true - /posix-character-classes/0.1.1: + /posix-character-classes@0.1.1: resolution: {integrity: sha512-xTgYBc3fuo7Yt7JbiuFxSYGToMoz8fLoE6TC9Wx1P/u+LfeThMOAqmuyECnlBaaJb+u1m9hHiXUEtwW4OzfUJg==} engines: {node: '>=0.10.0'} dev: true - /postcss-flexbugs-fixes/4.2.1: + /postcss-flexbugs-fixes@4.2.1: resolution: {integrity: sha512-9SiofaZ9CWpQWxOwRh1b/r85KD5y7GgvsNt1056k6OYLvWUun0czCvogfJgylC22uJTwW1KzY3Gz65NZRlvoiQ==} dependencies: postcss: 7.0.39 dev: true - /postcss-load-config/3.1.4_ts-node@10.9.1: + /postcss-load-config@3.1.4(ts-node@10.9.1): resolution: {integrity: sha512-6DiM4E7v4coTE4uzA8U//WhtPwyhiim3eyjEMFCnUpzbrkK9wJHgKDT2mR+HbtSrd/NubVaYTOpSpjUl8NQeRg==} engines: {node: '>= 10'} peerDependencies: @@ -17727,11 +19127,11 @@ packages: optional: true dependencies: lilconfig: 2.1.0 - ts-node: 10.9.1_pqdfkuhuhnwv2d7uogwywwxtqq + ts-node: 10.9.1(@types/node@18.16.19)(typescript@5.1.6) yaml: 1.10.2 dev: true - /postcss-loader/4.3.0_gzaxsinx64nntyd3vmdqwl7coe: + /postcss-loader@4.3.0(postcss@7.0.39)(webpack@4.46.0): resolution: {integrity: sha512-M/dSoIiNDOo8Rk0mUqoj4kpGq91gcxCfb9PoyZVdZ76/AuhxylHDYZblNE8o+EQ9AMSASeMFEKxZf5aU6wlx1Q==} engines: {node: '>= 10.13.0'} peerDependencies: @@ -17747,14 +19147,14 @@ packages: webpack: 4.46.0 dev: true - /postcss-modules-extract-imports/2.0.0: + /postcss-modules-extract-imports@2.0.0: resolution: {integrity: sha512-LaYLDNS4SG8Q5WAWqIJgdHPJrDDr/Lv775rMBFUbgjTz6j34lUznACHcdRWroPvXANP2Vj7yNK57vp9eFqzLWQ==} engines: {node: '>= 6'} dependencies: postcss: 7.0.39 dev: true - /postcss-modules-local-by-default/3.0.3: + /postcss-modules-local-by-default@3.0.3: resolution: {integrity: sha512-e3xDq+LotiGesympRlKNgaJ0PCzoUIdpH0dj47iWAui/kyTgh3CiAr1qP54uodmJhl6p9rN6BoNcdEDVJx9RDw==} engines: {node: '>= 6'} dependencies: @@ -17764,7 +19164,7 @@ packages: postcss-value-parser: 4.2.0 dev: true - /postcss-modules-scope/2.2.0: + /postcss-modules-scope@2.2.0: resolution: {integrity: sha512-YyEgsTMRpNd+HmyC7H/mh3y+MeFWevy7V1evVhJWewmMbjDHIbZbOXICC2y+m1xI1UVfIT1HMW/O04Hxyu9oXQ==} engines: {node: '>= 6'} dependencies: @@ -17772,14 +19172,14 @@ packages: postcss-selector-parser: 6.0.13 dev: true - /postcss-modules-values/3.0.0: + /postcss-modules-values@3.0.0: resolution: {integrity: sha512-1//E5jCBrZ9DmRX+zCtmQtRSV6PV42Ix7Bzj9GbwJceduuf7IqP8MgeTXuRDHOWj2m0VzZD5+roFWDuU8RQjcg==} dependencies: icss-utils: 4.1.1 postcss: 7.0.39 dev: true - /postcss-selector-parser/6.0.13: + /postcss-selector-parser@6.0.13: resolution: {integrity: sha512-EaV1Gl4mUEV4ddhDnv/xtj7sxwrwxdetHdWUGnT4VJQf+4d05v6lHYZr8N573k5Z0BViss7BDhfWtKS3+sfAqQ==} engines: {node: '>=4'} dependencies: @@ -17787,15 +19187,15 @@ packages: util-deprecate: 1.0.2 dev: true - /postcss-value-parser/3.3.1: + /postcss-value-parser@3.3.1: resolution: {integrity: sha512-pISE66AbVkp4fDQ7VHBwRNXzAAKJjw4Vw7nWI/+Q3vuly7SNfgYXvm6i5IgFylHGK5sP/xHAbB7N49OS4gWNyQ==} dev: false - /postcss-value-parser/4.2.0: + /postcss-value-parser@4.2.0: resolution: {integrity: sha512-1NNCs6uurfkVbeXG4S8JFT9t19m45ICnif8zWLd5oPSZ50QnwMfK+H3jv408d4jw/7Bttv5axS5IiHoLaVNHeQ==} dev: true - /postcss/7.0.39: + /postcss@7.0.39: resolution: {integrity: sha512-yioayjNbHn6z1/Bywyb2Y4s3yvDAeXGOyxqD+LnVOinq6Mdmd++SW2wUNVzavyyHxd6+DxzWGIuosg6P1Rj8uA==} engines: {node: '>=6.0.0'} dependencies: @@ -17803,7 +19203,7 @@ packages: source-map: 0.6.1 dev: true - /postcss/8.4.25: + /postcss@8.4.25: resolution: {integrity: sha512-7taJ/8t2av0Z+sQEvNzCkpDynl0tX3uJMCODi6nT3PfASC7dYCWV9aQ+uiCf+KBD4SEFcu+GvJdGdwzQ6OSjCw==} engines: {node: ^10 || ^12 || >=14} dependencies: @@ -17811,7 +19211,7 @@ packages: picocolors: 1.0.0 source-map-js: 1.0.2 - /postcss/8.4.5: + /postcss@8.4.5: resolution: {integrity: sha512-jBDboWM8qpaqwkMwItqTQTiFikhs/67OYVvblFFTM7MrZjt6yMKd6r2kgXizEbTTljacm4NldIlZnhbjr84QYg==} engines: {node: ^10 || ^12 || >=14} dependencies: @@ -17820,11 +19220,11 @@ packages: source-map-js: 1.0.2 dev: false - /preact/10.16.0: + /preact@10.16.0: resolution: {integrity: sha512-XTSj3dJ4roKIC93pald6rWuB2qQJO9gO2iLLyTe87MrjQN+HklueLsmskbywEWqCHlclgz3/M4YLL2iBr9UmMA==} dev: true - /prebuild-install/7.1.1: + /prebuild-install@7.1.1: resolution: {integrity: sha512-jAXscXWMcCK8GgCoHOfIr0ODh5ai8mj63L2nWrjuAgXE6tDyYGnx4/8o/rCgU+B4JSyZBKbeZqzhtwtC3ovxjw==} engines: {node: '>=10'} hasBin: true @@ -17843,12 +19243,12 @@ packages: tunnel-agent: 0.6.0 dev: true - /prelude-ls/1.2.1: + /prelude-ls@1.2.1: resolution: {integrity: sha512-vkcDPrRZo1QZLbn5RLGPpg/WmIQ65qoWWhcGKf/b5eplkkarX0m9z8ppCat4mlOqUsWpyNuYgO3VRyrYHSzX5g==} engines: {node: '>= 0.8.0'} dev: true - /prettier-plugin-svelte/2.10.1_jlgs5vq3kify7hyf3gm4oz2klm: + /prettier-plugin-svelte@2.10.1(prettier@2.8.8)(svelte@3.59.2): resolution: {integrity: sha512-Wlq7Z5v2ueCubWo0TZzKc9XHcm7TDxqcuzRuGd0gcENfzfT4JZ9yDlCbEgxWgiPmLHkBjfOtpAWkcT28MCDpUQ==} peerDependencies: prettier: ^1.16.4 || ^2.0.0 @@ -17858,36 +19258,36 @@ packages: svelte: 3.59.2 dev: true - /prettier/2.3.0: + /prettier@2.3.0: resolution: {integrity: sha512-kXtO4s0Lz/DW/IJ9QdWhAf7/NmPWQXkFr/r/WkR3vyI+0v8amTDxiaQSLzs8NBlytfLWX/7uQUMIW677yLKl4w==} engines: {node: '>=10.13.0'} hasBin: true dev: true - /prettier/2.8.8: + /prettier@2.8.8: resolution: {integrity: sha512-tdN8qQGvNjw4CHbY+XXk0JgCXn9QiF21a55rBe5LJAU+kDyC4WQn4+awm2Xfk2lQMk5fKup9XgzTZtGkjBdP9Q==} engines: {node: '>=10.13.0'} hasBin: true dev: true - /pretty-bytes/5.6.0: + /pretty-bytes@5.6.0: resolution: {integrity: sha512-FFw039TmrBqFK8ma/7OL3sDz/VytdtJr044/QUJtH0wK9lb9jLq9tJyIxUwtQJHwar2BqtiA4iCWSwo9JLkzFg==} engines: {node: '>=6'} dev: true - /pretty-bytes/6.1.0: + /pretty-bytes@6.1.0: resolution: {integrity: sha512-Rk753HI8f4uivXi4ZCIYdhmG1V+WKzvRMg/X+M42a6t7D07RcmopXJMDNk6N++7Bl75URRGsb40ruvg7Hcp2wQ==} engines: {node: ^14.13.1 || >=16.0.0} dev: true - /pretty-error/2.1.2: + /pretty-error@2.1.2: resolution: {integrity: sha512-EY5oDzmsX5wvuynAByrmY0P0hcp+QpnAKbJng2A2MPjVKXCxrDSUkzghVJ4ZGPIv+JC4gX8fPUWscC0RtjsWGw==} dependencies: lodash: 4.17.21 renderkid: 2.0.7 dev: true - /pretty-format/27.5.1: + /pretty-format@27.5.1: resolution: {integrity: sha512-Qb1gy5OrP5+zDf2Bvnzdl3jsTf1qXVMazbvCoKhtKqVs4/YK4ozX4gKQJJVyNe+cajNPn0KoC0MC3FUmaHWEmQ==} engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: @@ -17896,7 +19296,7 @@ packages: react-is: 17.0.2 dev: true - /pretty-format/29.6.1: + /pretty-format@29.6.1: resolution: {integrity: sha512-7jRj+yXO0W7e4/tSJKoR7HRIHLPPjtNaUGG2xxKQnGvPNRkgWcQ0AZX6P4KBRJN4FcTBWb3sa7DVUJmocYuoog==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: @@ -17904,12 +19304,12 @@ packages: ansi-styles: 5.2.0 react-is: 18.2.0 - /pretty-hrtime/1.0.3: + /pretty-hrtime@1.0.3: resolution: {integrity: sha512-66hKPCr+72mlfiSjlEB1+45IjXSqvVAIy6mocupoww4tBFE9R9IhwwUGoI4G++Tc9Aq+2rxOt0RFU6gPcrte0A==} engines: {node: '>= 0.8'} dev: true - /pretty/2.0.0: + /pretty@2.0.0: resolution: {integrity: sha512-G9xUchgTEiNpormdYBl+Pha50gOUovT18IvAe7EYMZ1/f9W/WWMPRn+xI68yXNMUk3QXHDwo/1wV/4NejVNe1w==} engines: {node: '>=0.10.0'} dependencies: @@ -17918,34 +19318,25 @@ packages: js-beautify: 1.14.8 dev: true - /process-nextick-args/2.0.1: + /process-nextick-args@2.0.1: resolution: {integrity: sha512-3ouUOpQhtgrbOa17J7+uxOTpITYWaGP7/AhoR3+A+/1e9skrzelGi/dXzEYyvbxubEF6Wn2ypscTKiKJFFn1ag==} dev: true - /process-warning/2.2.0: + /process-warning@2.2.0: resolution: {integrity: sha512-/1WZ8+VQjR6avWOgHeEPd7SDQmFQ1B5mC1eRXsCm5TarlNmx/wCsa5GEaxGm05BORRtyG/Ex/3xq3TuRvq57qg==} dev: true - /process/0.11.10: + /process@0.11.10: resolution: {integrity: sha512-cdGef/drWFoydD1JsMzuFf8100nZl+GT+yacc2bEced5f9Rjk4z+WtFUTBu9PhOi9j/jfmBPu0mMEY4wIdAF8A==} engines: {node: '>= 0.6.0'} dev: true - /progress/2.0.3: + /progress@2.0.3: resolution: {integrity: sha512-7PiHtLll5LdnKIMw100I+8xJXR5gW2QwWYkT6iJva0bXitZKa/XMrSbdmg3r2Xnaidz9Qumd0VPaMrZlF9V9sA==} engines: {node: '>=0.4.0'} dev: true - /promise-inflight/1.0.1: - resolution: {integrity: sha512-6zWPyEOFaQBJYcGMHBKTKJ3u6TBsnMFOIZSa6ce1e/ZrrsOlnHRHbabMjLiBYKp+n44X9eUI6VUPaukCXHuG4g==} - peerDependencies: - bluebird: '*' - peerDependenciesMeta: - bluebird: - optional: true - dev: true - - /promise-inflight/1.0.1_bluebird@3.7.2: + /promise-inflight@1.0.1(bluebird@3.7.2): resolution: {integrity: sha512-6zWPyEOFaQBJYcGMHBKTKJ3u6TBsnMFOIZSa6ce1e/ZrrsOlnHRHbabMjLiBYKp+n44X9eUI6VUPaukCXHuG4g==} peerDependencies: bluebird: '*' @@ -17956,7 +19347,7 @@ packages: bluebird: 3.7.2 dev: true - /promise.allsettled/1.0.6: + /promise.allsettled@1.0.6: resolution: {integrity: sha512-22wJUOD3zswWFqgwjNHa1965LvqTX87WPu/lreY2KSd7SVcERfuZ4GfUaOnJNnvtoIv2yXT/W00YIGMetXtFXg==} engines: {node: '>= 0.4'} dependencies: @@ -17968,7 +19359,7 @@ packages: iterate-value: 1.0.2 dev: true - /promise.prototype.finally/3.1.4: + /promise.prototype.finally@3.1.4: resolution: {integrity: sha512-nNc3YbgMfLzqtqvO/q5DP6RR0SiHI9pUPGzyDf1q+usTwCN2kjvAnJkBb7bHe3o+fFSBPpsGMoYtaSi+LTNqng==} engines: {node: '>= 0.4'} dependencies: @@ -17977,7 +19368,7 @@ packages: es-abstract: 1.21.2 dev: true - /prompts/2.4.2: + /prompts@2.4.2: resolution: {integrity: sha512-NxNv/kLguCA7p3jE8oL2aEBsrJWgAakBpgmgK6lpPWV+WuOmY6r2/zbAVnP+T8bQlA0nzHXSJSJW0Hq7ylaD2Q==} engines: {node: '>= 6'} dependencies: @@ -17985,24 +19376,24 @@ packages: sisteransi: 1.0.5 dev: true - /prop-types/15.8.1: + /prop-types@15.8.1: resolution: {integrity: sha512-oj87CgZICdulUohogVAR7AjlC0327U4el4L6eAvOqCeudMDVU0NThNaV+b9Df4dXgSP1gXMTnPdhfe/2qDH5cg==} dependencies: loose-envify: 1.4.0 object-assign: 4.1.1 react-is: 16.13.1 - /property-information/5.6.0: + /property-information@5.6.0: resolution: {integrity: sha512-YUHSPk+A30YPv+0Qf8i9Mbfe/C0hdPXk1s1jPVToV8pk8BQtpw10ct89Eo7OWkutrwqvT0eicAxlOg3dOAu8JA==} dependencies: xtend: 4.0.2 dev: true - /proto-list/1.2.4: + /proto-list@1.2.4: resolution: {integrity: sha512-vtK/94akxsTMhe0/cbfpR+syPuszcuwhqVjJq26CuNDgFGj682oRBXOP5MJpv2r7JtE8MsiepGIqvvOTBwn2vA==} dev: true - /proxy-addr/2.0.7: + /proxy-addr@2.0.7: resolution: {integrity: sha512-llQsMLSUDUPT44jdrU/O37qlnifitDP+ZwrmmZcoSKyLKvtZxpyV0n2/bD/N4tBAAZ/gJEdZU7KMraoK1+XYAg==} engines: {node: '>= 0.10'} dependencies: @@ -18010,27 +19401,27 @@ packages: ipaddr.js: 1.9.1 dev: true - /proxy-from-env/1.0.0: + /proxy-from-env@1.0.0: resolution: {integrity: sha512-F2JHgJQ1iqwnHDcQjVBsq3n/uoaFL+iPW/eAeL7kVxy/2RrWaN4WroKjjvbsoRtv0ftelNyC01bjRhn/bhcf4A==} dev: true - /proxy-from-env/1.1.0: + /proxy-from-env@1.1.0: resolution: {integrity: sha512-D+zkORCbA9f1tdWRK0RaCR3GPv50cMxcrz4X8k5LTSUD1Dkw47mKJEZQNunItRTkWwgtaUSo1RVFRIG9ZXiFYg==} dev: true - /prr/1.0.1: + /prr@1.0.1: resolution: {integrity: sha512-yPw4Sng1gWghHQWj0B3ZggWUm4qVbPwPFcRG8KyxiU7J2OHFSoEHKS+EZ3fv5l1t9CyCiop6l/ZYeWbrgoQejw==} dev: true - /pseudomap/1.0.2: + /pseudomap@1.0.2: resolution: {integrity: sha512-b/YwNhb8lk1Zz2+bXXpS/LK9OisiZZ1SNsSLxN1x2OXVEhW2Ckr/7mWE5vrC1ZTiJlD9g19jWszTmJsB+oEpFQ==} dev: true - /psl/1.9.0: + /psl@1.9.0: resolution: {integrity: sha512-E/ZsdU4HLs/68gYzgGTkMicWTLPdAftJLfJFlLUAAKZGkStNU72sZjT66SnMDVOfOWY/YAoiD7Jxa9iHvngcag==} dev: true - /public-encrypt/4.0.3: + /public-encrypt@4.0.3: resolution: {integrity: sha512-zVpa8oKZSz5bTMTFClc1fQOnyyEzpl5ozpi1B5YcvBrdohMjH2rfsBtyXcuNuwjsDIXmBYlF2N5FlJYhR29t8Q==} dependencies: bn.js: 4.12.0 @@ -18041,21 +19432,21 @@ packages: safe-buffer: 5.2.1 dev: true - /pump/2.0.1: + /pump@2.0.1: resolution: {integrity: sha512-ruPMNRkN3MHP1cWJc9OWr+T/xDP0jhXYCLfJcBuX54hhfIBnaQmAUMfDcG4DM5UMWByBbJY69QSphm3jtDKIkA==} dependencies: end-of-stream: 1.4.4 once: 1.4.0 dev: true - /pump/3.0.0: + /pump@3.0.0: resolution: {integrity: sha512-LwZy+p3SFs1Pytd/jYct4wpv49HiYCqd9Rlc5ZVdk0V+8Yzv6jR5Blk3TRmPL1ft69TxP0IMZGJ+WPFU2BFhww==} dependencies: end-of-stream: 1.4.4 once: 1.4.0 dev: true - /pumpify/1.5.1: + /pumpify@1.5.1: resolution: {integrity: sha512-oClZI37HvuUJJxSKKrC17bZ9Cu0ZYhEAGPsPUy9KlMUmv9dKX2o77RUmq7f3XjIxbwyGwYzbzQ1L2Ks8sIradQ==} dependencies: duplexify: 3.7.1 @@ -18063,16 +19454,16 @@ packages: pump: 2.0.1 dev: true - /punycode/1.4.1: + /punycode@1.4.1: resolution: {integrity: sha512-jmYNElW7yvO7TV33CjSmvSiE2yco3bV2czu/OzDKdMNVZQWfxCblURLhf+47syQRBntjfLdd/H0egrzIG+oaFQ==} dev: true - /punycode/2.3.0: + /punycode@2.3.0: resolution: {integrity: sha512-rRV+zQD8tVFys26lAGR9WUuS4iUAngJScM+ZRSKtvl5tKeZ2t5bvdNFdNHBW9FWR4guGHlgmsZ1G7BSm2wTbuA==} engines: {node: '>=6'} dev: true - /puppeteer-core/20.3.0: + /puppeteer-core@20.3.0(typescript@5.1.6): resolution: {integrity: sha512-264pBrIui5bO6NJeOcbJrLa0OCwmA4+WK00JMrLIKTfRiqe2gx8KWTzLsjyw/bizErp3TKS7vt/I0i5fTC+mAw==} engines: {node: '>=16.0.0'} peerDependencies: @@ -18081,11 +19472,12 @@ packages: typescript: optional: true dependencies: - '@puppeteer/browsers': 1.3.0 - chromium-bidi: 0.4.9_5222unh4tkeylqma7dhccidrk4 + '@puppeteer/browsers': 1.3.0(typescript@5.1.6) + chromium-bidi: 0.4.9(devtools-protocol@0.0.1120988) cross-fetch: 3.1.6 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) devtools-protocol: 0.0.1120988 + typescript: 5.1.6 ws: 8.13.0 transitivePeerDependencies: - bufferutil @@ -18094,16 +19486,16 @@ packages: - utf-8-validate dev: true - /puppeteer/13.7.0: + /puppeteer@13.7.0: resolution: {integrity: sha512-U1uufzBjz3+PkpCxFrWzh4OrMIdIb2ztzCu0YEPfRHjHswcSwHZswnK+WdsOQJsRV8WeTg3jLhJR4D867+fjsA==} engines: {node: '>=10.18.1'} deprecated: < 19.4.0 is no longer supported requiresBuild: true dependencies: cross-fetch: 3.1.5 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) devtools-protocol: 0.0.981744 - extract-zip: 2.0.1 + extract-zip: 2.0.1(supports-color@8.1.1) https-proxy-agent: 5.0.1 pkg-dir: 4.2.0 progress: 2.0.3 @@ -18119,75 +19511,75 @@ packages: - utf-8-validate dev: true - /qs/6.10.4: + /qs@6.10.4: resolution: {integrity: sha512-OQiU+C+Ds5qiH91qh/mg0w+8nwQuLjM4F4M/PbmhDOoYehPh+Fb0bDjtR1sOvy7YKxvj28Y/M0PhP5uVX0kB+g==} engines: {node: '>=0.6'} dependencies: side-channel: 1.0.4 dev: true - /qs/6.11.0: + /qs@6.11.0: resolution: {integrity: sha512-MvjoMCJwEarSbUYk5O+nmoSzSutSsTwF85zcHPQ9OrlFoZOYIjaqBAJIqIXjptyD5vThxGq52Xu/MaJzRkIk4Q==} engines: {node: '>=0.6'} dependencies: side-channel: 1.0.4 dev: true - /qs/6.11.2: + /qs@6.11.2: resolution: {integrity: sha512-tDNIz22aBzCDxLtVH++VnTfzxlfeK5CbqohpSqpJgj1Wg/cQbStNAz3NuqCs5vV+pjBsK4x4pN9HlVh7rcYRiA==} engines: {node: '>=0.6'} dependencies: side-channel: 1.0.4 dev: true - /query-selector-shadow-dom/1.0.1: + /query-selector-shadow-dom@1.0.1: resolution: {integrity: sha512-lT5yCqEBgfoMYpf3F2xQRK7zEr1rhIIZuceDK6+xRkJQ4NMbHTwXqk4NkwDwQMNqXgG9r9fyHnzwNVs6zV5KRw==} dev: true - /querystring-es3/0.2.1: + /querystring-es3@0.2.1: resolution: {integrity: sha512-773xhDQnZBMFobEiztv8LIl70ch5MSF/jUQVlhwFyBILqq96anmoctVIYz+ZRp0qbCKATTn6ev02M3r7Ga5vqA==} engines: {node: '>=0.4.x'} dev: true - /querystringify/2.2.0: + /querystringify@2.2.0: resolution: {integrity: sha512-FIqgj2EUvTa7R50u0rGsyTftzjYmv/a3hO345bZNrqabNqjtgiDMgmo4mkUjd+nzU5oF3dClKqFIPUKybUyqoQ==} dev: true - /queue-microtask/1.2.3: + /queue-microtask@1.2.3: resolution: {integrity: sha512-NuaNSa6flKT5JaSYQzJok04JzTL1CA6aGhv5rfLW3PgqA+M2ChpZQnAC8h8i4ZFkBS8X5RqkDBHA7r4hej3K9A==} - /queue-tick/1.0.1: + /queue-tick@1.0.1: resolution: {integrity: sha512-kJt5qhMxoszgU/62PLP1CJytzd2NKetjSRnyuj31fDd3Rlcz3fzlFdFLD1SItunPwyqEOkca6GbV612BWfaBag==} dev: true - /quick-format-unescaped/4.0.4: + /quick-format-unescaped@4.0.4: resolution: {integrity: sha512-tYC1Q1hgyRuHgloV/YXs2w15unPVh8qfu/qCTfhTYamaw7fyhumKa2yGpdSo87vY32rIclj+4fWYQXUMs9EHvg==} dev: true - /quick-lru/5.1.1: + /quick-lru@5.1.1: resolution: {integrity: sha512-WuyALRjWPDGtt/wzJiadO5AXY+8hZ80hVpe6MyivgraREW751X3SbhRvG3eLKOYN+8VEvqLcf3wdnt44Z4S4SA==} engines: {node: '>=10'} dev: true - /raf/3.4.1: + /raf@3.4.1: resolution: {integrity: sha512-Sq4CW4QhwOHE8ucn6J34MqtZCeWFP2aQSmrlroYgqAV1PjStIhJXxYuTgUIfkEk7zTLjmIjLmU5q+fbD1NnOJA==} dependencies: performance-now: 2.1.0 dev: true - /railroad-diagrams/1.0.0: + /railroad-diagrams@1.0.0: resolution: {integrity: sha512-cz93DjNeLY0idrCNOH6PviZGRN9GJhsdm9hpn1YCS879fj4W+x5IFJhhkRZcwVgMmFF7R82UA/7Oh+R8lLZg6A==} dev: true - /ramda/0.28.0: + /ramda@0.28.0: resolution: {integrity: sha512-9QnLuG/kPVgWvMQ4aODhsBUFKOUmnbUnsSXACv+NCQZcHbeb+v8Lodp8OVxtRULN1/xOyYLLaL6npE6dMq5QTA==} dev: true - /ramda/0.29.0: + /ramda@0.29.0: resolution: {integrity: sha512-BBea6L67bYLtdbOqfp8f58fPMqEwx0doL+pAi8TZyp2YWz8R9G8z9x75CZI8W+ftqhFHCpEX2cRnUUXK130iKA==} dev: true - /randexp/0.4.6: + /randexp@0.4.6: resolution: {integrity: sha512-80WNmd9DA0tmZrw9qQa62GPPWfuXJknrmVmLcxvq4uZBdYqb1wYoKTmnlGUchvVWe0XiLupYkBoXVOxz3C8DYQ==} engines: {node: '>=0.12'} dependencies: @@ -18195,25 +19587,25 @@ packages: ret: 0.1.15 dev: true - /randombytes/2.1.0: + /randombytes@2.1.0: resolution: {integrity: sha512-vYl3iOX+4CKUWuxGi9Ukhie6fsqXqS9FE2Zaic4tNFD2N2QQaXOMFbuKK4QmDHC0JO6B1Zp41J0LpT0oR68amQ==} dependencies: safe-buffer: 5.2.1 dev: true - /randomfill/1.0.4: + /randomfill@1.0.4: resolution: {integrity: sha512-87lcbR8+MhcWcUiQ+9e+Rwx8MyR2P7qnt15ynUlbm3TU/fjbgz4GsvfSUDTemtCCtVCqb4ZcEFlyPNTh9bBTLw==} dependencies: randombytes: 2.1.0 safe-buffer: 5.2.1 dev: true - /range-parser/1.2.1: + /range-parser@1.2.1: resolution: {integrity: sha512-Hrgsx+orqoygnmhFbKaHE6c296J+HTAQXoxEF6gNupROmmGJRoyzfG3ccAveqCBrwr/2yxQ5BVd/GTl5agOwSg==} engines: {node: '>= 0.6'} dev: true - /raw-body/2.5.1: + /raw-body@2.5.1: resolution: {integrity: sha512-qqJBtEyVgS0ZmPGdCFPWJ3FreoqvG4MVQln/kCgF7Olq95IbOp0/BWyMwbdtn4VTvkM8Y7khCQ2Xgk/tcrCXig==} engines: {node: '>= 0.8'} dependencies: @@ -18223,7 +19615,7 @@ packages: unpipe: 1.0.0 dev: true - /raw-loader/4.0.2_webpack@4.46.0: + /raw-loader@4.0.2(webpack@4.46.0): resolution: {integrity: sha512-ZnScIV3ag9A4wPX/ZayxL/jZH+euYb6FcUinPcgiQW0+UBtEv0O6Q3lGd3cqJ+GHH+rksEv3Pj99oxJ3u3VIKA==} engines: {node: '>= 10.13.0'} peerDependencies: @@ -18234,7 +19626,15 @@ packages: webpack: 4.46.0 dev: true - /rc/1.2.8: + /rc9@2.1.1: + resolution: {integrity: sha512-lNeOl38Ws0eNxpO3+wD1I9rkHGQyj1NU1jlzv4go2CtEnEQEUfqnIvZG7W+bC/aXdJ27n5x/yUjb6RoT9tko+Q==} + dependencies: + defu: 6.1.2 + destr: 2.0.0 + flat: 5.0.2 + dev: true + + /rc@1.2.8: resolution: {integrity: sha512-y3bGgqKj3QBdxLbLkomlohkvsA8gdAiUQlSBJnBhfn+BPxg4bc62d8TcBW15wavDfgexCgccckhcZvywyQYPOw==} hasBin: true dependencies: @@ -18244,15 +19644,7 @@ packages: strip-json-comments: 2.0.1 dev: true - /rc9/2.1.1: - resolution: {integrity: sha512-lNeOl38Ws0eNxpO3+wD1I9rkHGQyj1NU1jlzv4go2CtEnEQEUfqnIvZG7W+bC/aXdJ27n5x/yUjb6RoT9tko+Q==} - dependencies: - defu: 6.1.2 - destr: 2.0.0 - flat: 5.0.2 - dev: true - - /react-docgen-typescript/2.2.2_typescript@4.9.5: + /react-docgen-typescript@2.2.2(typescript@4.9.5): resolution: {integrity: sha512-tvg2ZtOpOi6QDwsb3GZhOjDkkX0h8Z2gipvTg6OVMUyoYoURhEiRNePT8NZItTVCDh39JJHnLdfCOkzoLbFnTg==} peerDependencies: typescript: '>= 4.3.x' @@ -18260,7 +19652,7 @@ packages: typescript: 4.9.5 dev: true - /react-docgen/5.4.3: + /react-docgen@5.4.3: resolution: {integrity: sha512-xlLJyOlnfr8lLEEeaDZ+X2J/KJoe6Nr9AzxnkdQWush5hz2ZSu66w6iLMOScMmxoSHWpWMn+k3v5ZiyCfcWsOA==} engines: {node: '>=8.10.0'} hasBin: true @@ -18279,7 +19671,7 @@ packages: - supports-color dev: true - /react-docgen/6.0.1: + /react-docgen@6.0.1: resolution: {integrity: sha512-K+EHJrADKJYpmojACrebABRb5e6RvW8cSeJ/0950Km5YnrSglebHeMm/uGSv/DpBvsZOsMGVQoYb8XjCA3r0NQ==} engines: {node: '>=14.18.0'} dependencies: @@ -18297,7 +19689,7 @@ packages: - supports-color dev: true - /react-dom/17.0.2_react@17.0.2: + /react-dom@17.0.2(react@17.0.2): resolution: {integrity: sha512-s4h96KtLDUQlsENhMn1ar8t2bEa+q/YAtj8pPPdIjPDGBDIVNsrD9aXNWqspUe6AzKCIG0C1HZZLqLV7qpOBGA==} peerDependencies: react: 17.0.2 @@ -18307,7 +19699,7 @@ packages: react: 17.0.2 scheduler: 0.20.2 - /react-dom/18.0.0_react@18.0.0: + /react-dom@18.0.0(react@18.0.0): resolution: {integrity: sha512-XqX7uzmFo0pUceWFCt7Gff6IyIMzFUn7QMZrbrQfGxtaxXZIcGQzoNpRLE3fQLnS4XzLLPMZX2T9TRcSrasicw==} peerDependencies: react: ^18.0.0 @@ -18316,7 +19708,7 @@ packages: react: 18.0.0 scheduler: 0.21.0 - /react-dom/18.2.0_react@18.2.0: + /react-dom@18.2.0(react@18.2.0): resolution: {integrity: sha512-6IMTriUmvsjHUjNtEDudZfuDQUoWXVxKHhlEGSk81n4YFS+r/Kl99wXiwlVXtPBtJenozv2P+hxDsw9eA7Xo6g==} peerDependencies: react: ^18.2.0 @@ -18325,7 +19717,7 @@ packages: react: 18.2.0 scheduler: 0.23.0 - /react-element-to-jsx-string/14.3.4_sfoxds7t5ydpegc3knd667wn6m: + /react-element-to-jsx-string@14.3.4(react-dom@17.0.2)(react@17.0.2): resolution: {integrity: sha512-t4ZwvV6vwNxzujDQ+37bspnLwA4JlgUPWhLjBJWsNIDceAf6ZKUTCjdm08cN6WeZ5pTMKiCJkmAYnpmR4Bm+dg==} peerDependencies: react: ^0.14.8 || ^15.0.1 || ^16.0.0 || ^17.0.1 @@ -18334,11 +19726,11 @@ packages: '@base2/pretty-print-object': 1.0.1 is-plain-object: 5.0.0 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) react-is: 17.0.2 dev: true - /react-inspector/5.1.1_react@17.0.2: + /react-inspector@5.1.1(react@17.0.2): resolution: {integrity: sha512-GURDaYzoLbW8pMGXwYPDBIv6nqei4kK7LPRZ9q9HCZF54wqXz/dnylBp/kfE9XmekBhHvLDdcYeyIwSrvtOiWg==} peerDependencies: react: ^16.8.4 || ^17.0.0 @@ -18349,21 +19741,21 @@ packages: react: 17.0.2 dev: true - /react-is/16.13.1: + /react-is@16.13.1: resolution: {integrity: sha512-24e6ynE2H+OKt4kqsOvNd8kBpV65zoxbA4BVsEOB3ARVWQki/DHzaUoC5KuON/BiccDaCCTZBuOcfZs70kR8bQ==} - /react-is/17.0.2: + /react-is@17.0.2: resolution: {integrity: sha512-w2GsyukL62IJnlaff/nRegPQR94C/XXamvMWmSHRJ4y7Ts/4ocGRmTHvOs8PSE6pB3dWOrD/nueuU5sduBsQ4w==} dev: true - /react-is/18.2.0: + /react-is@18.2.0: resolution: {integrity: sha512-xWGDIW6x921xtzPkhiULtthJHoJvBbF3q26fzloPCK0hsvxtPVelvftw3zjbHWSkR2km9Z+4uxbDDK/6Zw9B8w==} - /react-lifecycles-compat/3.0.4: + /react-lifecycles-compat@3.0.4: resolution: {integrity: sha512-fBASbA6LnOU9dOU2eW7aQ8xmYBSXUIWr+UmF9b1efZBazGNO+rcXT/icdKnYm2pTwcRylVUYwW7H1PHfLekVzA==} dev: false - /react-query/3.39.3_sfoxds7t5ydpegc3knd667wn6m: + /react-query@3.39.3(react-dom@17.0.2)(react@17.0.2): resolution: {integrity: sha512-nLfLz7GiohKTJDuT4us4X3h/8unOh+00MLb2yJoGTPjxKs2bc1iDhkNx2bd5MKklXnOD3NrVZ+J2UXujA5In4g==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -18379,25 +19771,25 @@ packages: broadcast-channel: 3.7.0 match-sorter: 6.3.1 react: 17.0.2 - react-dom: 17.0.2_react@17.0.2 + react-dom: 17.0.2(react@17.0.2) dev: false - /react-refresh/0.11.0: + /react-refresh@0.11.0: resolution: {integrity: sha512-F27qZr8uUqwhWZboondsPx8tnC3Ct3SxZA3V5WyEvujRyyNv0VYPhoBg1gZ8/MV5tubQp76Trw8lTv9hzRBa+A==} engines: {node: '>=0.10.0'} dev: true - /react-refresh/0.13.0: + /react-refresh@0.13.0: resolution: {integrity: sha512-XP8A9BT0CpRBD+NYLLeIhld/RqG9+gktUjW1FkE+Vm7OCinbG1SshcK5tb9ls4kzvjZr9mOQc7HYgBngEyPAXg==} engines: {node: '>=0.10.0'} dev: true - /react-refresh/0.14.0: + /react-refresh@0.14.0: resolution: {integrity: sha512-wViHqhAd8OHeLS/IRMJjTSDHF3U9eWi62F/MledQGPdJGDhodXJ9PBLNGr6WWL7qlH12Mt3TyTpbS+hGXMjCzQ==} engines: {node: '>=0.10.0'} dev: true - /react-resize-detector/8.1.0_biqbaboplfbrettd7655fr4n2y: + /react-resize-detector@8.1.0(react-dom@18.2.0)(react@18.2.0): resolution: {integrity: sha512-S7szxlaIuiy5UqLhLL1KY3aoyGHbZzsTpYal9eYMwCyKqoqoVLCmIgAgNyIM1FhnP2KyBygASJxdhejrzjMb+w==} peerDependencies: react: ^16.0.0 || ^17.0.0 || ^18.0.0 @@ -18405,10 +19797,10 @@ packages: dependencies: lodash: 4.17.21 react: 18.2.0 - react-dom: 18.2.0_react@18.2.0 + react-dom: 18.2.0(react@18.2.0) dev: false - /react-router-dom/6.14.1_biqbaboplfbrettd7655fr4n2y: + /react-router-dom@6.14.1(react-dom@18.2.0)(react@18.2.0): resolution: {integrity: sha512-ssF6M5UkQjHK70fgukCJyjlda0Dgono2QGwqGvuk7D+EDGHdacEN3Yke2LTMjkrpHuFwBfDFsEjGVXBDmL+bWw==} engines: {node: '>=14'} peerDependencies: @@ -18417,11 +19809,11 @@ packages: dependencies: '@remix-run/router': 1.7.1 react: 18.2.0 - react-dom: 18.2.0_react@18.2.0 - react-router: 6.14.1_react@18.2.0 + react-dom: 18.2.0(react@18.2.0) + react-router: 6.14.1(react@18.2.0) dev: false - /react-router/6.14.1_react@18.2.0: + /react-router@6.14.1(react@18.2.0): resolution: {integrity: sha512-U4PfgvG55LdvbQjg5Y9QRWyVxIdO1LlpYT7x+tMAxd9/vmiPuJhIwdxZuIQLN/9e3O4KFDHYfR9gzGeYMasW8g==} engines: {node: '>=14'} peerDependencies: @@ -18431,7 +19823,7 @@ packages: react: 18.2.0 dev: false - /react-shallow-renderer/16.15.0_react@17.0.2: + /react-shallow-renderer@16.15.0(react@17.0.2): resolution: {integrity: sha512-oScf2FqQ9LFVQgA73vr86xl2NaOIX73rh+YFqcOp68CWj56tSfgtGKrEbyhCj0rSijyG9M1CYprTh39fBi5hzA==} peerDependencies: react: ^16.0.0 || ^17.0.0 || ^18.0.0 @@ -18441,7 +19833,7 @@ packages: react-is: 17.0.2 dev: true - /react-smooth/2.0.3_biqbaboplfbrettd7655fr4n2y: + /react-smooth@2.0.3(prop-types@15.8.1)(react-dom@18.2.0)(react@18.2.0): resolution: {integrity: sha512-yl4y3XiMorss7ayF5QnBiSprig0+qFHui8uh7Hgg46QX5O+aRMRKlfGGNGLHno35JkQSvSYY8eCWkBfHfrSHfg==} peerDependencies: prop-types: ^15.6.0 @@ -18449,12 +19841,13 @@ packages: react-dom: ^15.0.0 || ^16.0.0 || ^17.0.0 || ^18.0.0 dependencies: fast-equals: 5.0.1 + prop-types: 15.8.1 react: 18.2.0 - react-dom: 18.2.0_react@18.2.0 - react-transition-group: 2.9.0_biqbaboplfbrettd7655fr4n2y + react-dom: 18.2.0(react@18.2.0) + react-transition-group: 2.9.0(react-dom@18.2.0)(react@18.2.0) dev: false - /react-test-renderer/17.0.2_react@17.0.2: + /react-test-renderer@17.0.2(react@17.0.2): resolution: {integrity: sha512-yaQ9cB89c17PUb0x6UfWRs7kQCorVdHlutU1boVPEsB8IDZH6n9tHxMacc3y0JoXOJUsZb/t/Mb8FUWMKaM7iQ==} peerDependencies: react: 17.0.2 @@ -18462,11 +19855,11 @@ packages: object-assign: 4.1.1 react: 17.0.2 react-is: 17.0.2 - react-shallow-renderer: 16.15.0_react@17.0.2 + react-shallow-renderer: 16.15.0(react@17.0.2) scheduler: 0.20.2 dev: true - /react-transition-group/2.9.0_biqbaboplfbrettd7655fr4n2y: + /react-transition-group@2.9.0(react-dom@18.2.0)(react@18.2.0): resolution: {integrity: sha512-+HzNTCHpeQyl4MJ/bdE0u6XRMe9+XG/+aL4mCxVN4DnPBQ0/5bfHWPDuOZUzYdMj94daZaZdCCc1Dzt9R/xSSg==} peerDependencies: react: '>=15.0.0' @@ -18476,11 +19869,11 @@ packages: loose-envify: 1.4.0 prop-types: 15.8.1 react: 18.2.0 - react-dom: 18.2.0_react@18.2.0 + react-dom: 18.2.0(react@18.2.0) react-lifecycles-compat: 3.0.4 dev: false - /react-transition-group/4.4.5_biqbaboplfbrettd7655fr4n2y: + /react-transition-group@4.4.5(react-dom@18.2.0)(react@18.2.0): resolution: {integrity: sha512-pZcd1MCJoiKiBR2NRxeCRg13uCXbydPnmB4EOeRrY7480qNWO8IIgQG6zlDkm6uRMsURXPuKq0GWtiM59a5Q6g==} peerDependencies: react: '>=16.6.0' @@ -18491,29 +19884,29 @@ packages: loose-envify: 1.4.0 prop-types: 15.8.1 react: 18.2.0 - react-dom: 18.2.0_react@18.2.0 + react-dom: 18.2.0(react@18.2.0) dev: false - /react/17.0.2: + /react@17.0.2: resolution: {integrity: sha512-gnhPt75i/dq/z3/6q/0asP78D0u592D5L1pd7M8P+dck6Fu/jJeL6iVVK23fptSUZj8Vjf++7wXA8UNclGQcbA==} engines: {node: '>=0.10.0'} dependencies: loose-envify: 1.4.0 object-assign: 4.1.1 - /react/18.0.0: + /react@18.0.0: resolution: {integrity: sha512-x+VL6wbT4JRVPm7EGxXhZ8w8LTROaxPXOqhlGyVSrv0sB1jkyFGgXxJ8LVoPRLvPR6/CIZGFmfzqUa2NYeMr2A==} engines: {node: '>=0.10.0'} dependencies: loose-envify: 1.4.0 - /react/18.2.0: + /react@18.2.0: resolution: {integrity: sha512-/3IjMdb2L9QbBdWiW5e3P2/npwMBaU9mHCSCUzNln0ZCYbcfTsGbTJrU/kGemdH2IWmB2ioZ+zkxtmq6g09fGQ==} engines: {node: '>=0.10.0'} dependencies: loose-envify: 1.4.0 - /read-pkg-up/1.0.1: + /read-pkg-up@1.0.1: resolution: {integrity: sha512-WD9MTlNtI55IwYUS27iHh9tK3YoIVhxis8yKhLpTqWtml739uXc9NWTpxoHkfZf3+DkCCsXox94/VWZniuZm6A==} engines: {node: '>=0.10.0'} dependencies: @@ -18522,7 +19915,7 @@ packages: dev: true optional: true - /read-pkg-up/7.0.1: + /read-pkg-up@7.0.1: resolution: {integrity: sha512-zK0TB7Xd6JpCLmlLmufqykGE+/TlOePD6qKClNW7hHDKFh/J7/7gCWGR7joEQEW1bKq3a3yUZSObOoWLFQ4ohg==} engines: {node: '>=8'} dependencies: @@ -18531,7 +19924,7 @@ packages: type-fest: 0.8.1 dev: true - /read-pkg-up/9.1.0: + /read-pkg-up@9.1.0: resolution: {integrity: sha512-vaMRR1AC1nrd5CQM0PhlRsO5oc2AAigqr7cCrZ/MW/Rsaflz4RlgzkpL4qoU/z1F6wrbd85iFv1OQj/y5RdGvg==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dependencies: @@ -18540,7 +19933,7 @@ packages: type-fest: 2.19.0 dev: true - /read-pkg/1.1.0: + /read-pkg@1.1.0: resolution: {integrity: sha512-7BGwRHqt4s/uVbuyoeejRn4YmFnYZiFl4AuaeXHlgZf3sONF0SOGlxs2Pw8g6hCKupo08RafIO5YXFNOKTfwsQ==} engines: {node: '>=0.10.0'} dependencies: @@ -18550,7 +19943,7 @@ packages: dev: true optional: true - /read-pkg/3.0.0: + /read-pkg@3.0.0: resolution: {integrity: sha512-BLq/cCO9two+lBgiTYNqD6GdtK8s4NpaWrl6/rCO9w0TUS8oJl7cmToOZfRYllKTISY6nt1U7jQ53brmKqY6BA==} engines: {node: '>=4'} dependencies: @@ -18559,7 +19952,7 @@ packages: path-type: 3.0.0 dev: true - /read-pkg/5.2.0: + /read-pkg@5.2.0: resolution: {integrity: sha512-Ug69mNOpfvKDAc2Q8DRpMjjzdtrnv9HcSMX+4VsZxD1aZ6ZzrIE7rlzXBtWTyhULSMKg076AW6WR5iZpD0JiOg==} engines: {node: '>=8'} dependencies: @@ -18569,7 +19962,7 @@ packages: type-fest: 0.6.0 dev: true - /read-pkg/7.1.0: + /read-pkg@7.1.0: resolution: {integrity: sha512-5iOehe+WF75IccPc30bWTbpdDQLOCc3Uu8bi3Dte3Eueij81yx1Mrufk8qBx/YAbR4uL1FdUr+7BKXDwEtisXg==} engines: {node: '>=12.20'} dependencies: @@ -18579,7 +19972,7 @@ packages: type-fest: 2.19.0 dev: true - /readable-stream/2.3.8: + /readable-stream@2.3.8: resolution: {integrity: sha512-8p0AUk4XODgIewSi0l8Epjs+EVnWiK7NoDIEGU0HhE7+ZyY8D1IMY7odu5lRrFXGg71L15KG8QrPmum45RTtdA==} dependencies: core-util-is: 1.0.3 @@ -18591,7 +19984,7 @@ packages: util-deprecate: 1.0.2 dev: true - /readable-stream/3.6.2: + /readable-stream@3.6.2: resolution: {integrity: sha512-9u/sniCrY3D5WdsERHzHE4G2YCXqoG5FTHUiCC4SIbr6XcLZBY05ya9EKjYek9O5xOAwjGq+1JdGBAS7Q9ScoA==} engines: {node: '>= 6'} dependencies: @@ -18600,7 +19993,7 @@ packages: util-deprecate: 1.0.2 dev: true - /readable-stream/4.4.2: + /readable-stream@4.4.2: resolution: {integrity: sha512-Lk/fICSyIhodxy1IDK2HazkeGjSmezAWX2egdtJnYhtzKEsBPJowlI6F6LPb5tqIQILrMbx22S5o3GuJavPusA==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dependencies: @@ -18611,13 +20004,13 @@ packages: string_decoder: 1.3.0 dev: true - /readdir-glob/1.1.3: + /readdir-glob@1.1.3: resolution: {integrity: sha512-v05I2k7xN8zXvPD9N+z/uhXPaj0sUFCe2rcWZIpBsqxfP7xXFQ0tipAd/wjj1YxWyWtUS5IDJpOG82JKt2EAVA==} dependencies: minimatch: 5.1.6 dev: true - /readdirp/2.2.1: + /readdirp@2.2.1: resolution: {integrity: sha512-1JU/8q+VgFZyxwrJ+SVIOsh+KywWGpds3NTqikiKpDMZWScmAYyKIgqkO+ARvNWJfXeXR1zxz7aHF4u4CyH6vQ==} engines: {node: '>=0.10'} dependencies: @@ -18629,25 +20022,25 @@ packages: dev: true optional: true - /readdirp/3.6.0: + /readdirp@3.6.0: resolution: {integrity: sha512-hOS089on8RduqdbhvQ5Z37A0ESjsqz6qnRcffsMU3495FuTdqSm+7bhJ29JvIOsBDEEnan5DPu9t3To9VRlMzA==} engines: {node: '>=8.10.0'} dependencies: picomatch: 2.3.1 dev: true - /real-require/0.2.0: + /real-require@0.2.0: resolution: {integrity: sha512-57frrGM/OCTLqLOAh0mhVA9VBMHd+9U7Zb2THMGdBUoZVOtGbJzjxsYGDJ3A9AYYCP4hn6y1TVbaOfzWtm5GFg==} engines: {node: '>= 12.13.0'} dev: true - /recharts-scale/0.4.5: + /recharts-scale@0.4.5: resolution: {integrity: sha512-kivNFO+0OcUNu7jQquLXAxz1FIwZj8nrj+YkOKc5694NbjCvcT6aSZiIzNzd2Kul4o4rTto8QVR9lMNtxD4G1w==} dependencies: decimal.js-light: 2.5.1 dev: false - /recharts/2.7.2_biqbaboplfbrettd7655fr4n2y: + /recharts@2.7.2(prop-types@15.8.1)(react-dom@18.2.0)(react@18.2.0): resolution: {integrity: sha512-HMKRBkGoOXHW+7JcRa6+MukPSifNtJlqbc+JreGVNA407VLE/vOP+8n3YYjprDVVIF9E2ZgwWnL3D7K/LUFzBg==} engines: {node: '>=12'} peerDependencies: @@ -18658,17 +20051,18 @@ packages: classnames: 2.3.2 eventemitter3: 4.0.7 lodash: 4.17.21 + prop-types: 15.8.1 react: 18.2.0 - react-dom: 18.2.0_react@18.2.0 + react-dom: 18.2.0(react@18.2.0) react-is: 16.13.1 - react-resize-detector: 8.1.0_biqbaboplfbrettd7655fr4n2y - react-smooth: 2.0.3_biqbaboplfbrettd7655fr4n2y + react-resize-detector: 8.1.0(react-dom@18.2.0)(react@18.2.0) + react-smooth: 2.0.3(prop-types@15.8.1)(react-dom@18.2.0)(react@18.2.0) recharts-scale: 0.4.5 reduce-css-calc: 2.1.8 victory-vendor: 36.6.11 dev: false - /redent/1.0.0: + /redent@1.0.0: resolution: {integrity: sha512-qtW5hKzGQZqKoh6JNSD+4lfitfPKGz42e6QwiRmPM5mmKtR0N41AbJRYu0xJi7nhOJ4WDgRkKvAk6tw4WIwR4g==} engines: {node: '>=0.10.0'} dependencies: @@ -18677,7 +20071,7 @@ packages: dev: true optional: true - /redent/3.0.0: + /redent@3.0.0: resolution: {integrity: sha512-6tDA8g98We0zd0GvVeMT9arEOnTw9qM03L9cJXaCjrip1OO764RDBLBfrB4cwzNGDj5OA5ioymC9GkizgWJDUg==} engines: {node: '>=8'} dependencies: @@ -18685,34 +20079,34 @@ packages: strip-indent: 3.0.0 dev: true - /reduce-css-calc/2.1.8: + /reduce-css-calc@2.1.8: resolution: {integrity: sha512-8liAVezDmUcH+tdzoEGrhfbGcP7nOV4NkGE3a74+qqvE7nt9i4sKLGBuZNOnpI4WiGksiNPklZxva80061QiPg==} dependencies: css-unit-converter: 1.1.2 postcss-value-parser: 3.3.1 dev: false - /regenerate-unicode-properties/10.1.0: + /regenerate-unicode-properties@10.1.0: resolution: {integrity: sha512-d1VudCLoIGitcU/hEg2QqvyGZQmdC0Lf8BqdOMXGFSvJP4bNV1+XqbPQeHHLD51Jh4QJJ225dlIFvY4Ly6MXmQ==} engines: {node: '>=4'} dependencies: regenerate: 1.4.2 dev: true - /regenerate/1.4.2: + /regenerate@1.4.2: resolution: {integrity: sha512-zrceR/XhGYU/d/opr2EKO7aRHUeiBI8qjtfHqADTwZd6Szfy16la6kqD0MIUs5z5hx6AaKa+PixpPrR289+I0A==} dev: true - /regenerator-runtime/0.13.11: + /regenerator-runtime@0.13.11: resolution: {integrity: sha512-kY1AZVr2Ra+t+piVaJ4gxaFaReZVH40AKNo7UCX6W+dEwBo/2oZJzqfuN1qLq1oL45o56cPaTXELwrTh8Fpggg==} - /regenerator-transform/0.15.1: + /regenerator-transform@0.15.1: resolution: {integrity: sha512-knzmNAcuyxV+gQCufkYcvOqX/qIIfHLv0u5x79kRxuGojfYVky1f15TzZEu2Avte8QGepvUNTnLskf8E6X6Vyg==} dependencies: '@babel/runtime': 7.22.6 dev: true - /regex-not/1.0.2: + /regex-not@1.0.2: resolution: {integrity: sha512-J6SDjUgDxQj5NusnOtdFxDwN/+HWykR8GELwctJ7mdqhcyy1xEc4SRFHUXvxTp661YaVKAjfRLZ9cCqS6tn32A==} engines: {node: '>=0.10.0'} dependencies: @@ -18720,12 +20114,12 @@ packages: safe-regex: 1.1.0 dev: true - /regexp-tree/0.1.27: + /regexp-tree@0.1.27: resolution: {integrity: sha512-iETxpjK6YoRWJG5o6hXLwvjYAoW+FEZn9os0PD/b6AP6xQwsa/Y7lCVgIixBbUPMfhu+i2LtdeAqVTgGlQarfA==} hasBin: true dev: true - /regexp.prototype.flags/1.5.0: + /regexp.prototype.flags@1.5.0: resolution: {integrity: sha512-0SutC3pNudRKgquxGoRGIz946MZVHqbNfPjBdxeOhBrdgDKlRoXmYLQN9xRbrR09ZXWeGAdPuif7egofn6v5LA==} engines: {node: '>= 0.4'} dependencies: @@ -18734,12 +20128,12 @@ packages: functions-have-names: 1.2.3 dev: true - /regexpp/3.2.0: + /regexpp@3.2.0: resolution: {integrity: sha512-pq2bWo9mVD43nbts2wGv17XLiNLya+GklZ8kaDLV2Z08gDCsGpnKn9BFMepvWuHCbyVvY7J5o5+BVvoQbmlJLg==} engines: {node: '>=8'} dev: true - /regexpu-core/5.3.2: + /regexpu-core@5.3.2: resolution: {integrity: sha512-RAM5FlZz+Lhmo7db9L298p2vHP5ZywrVXmVXpmAD9GuL5MPH6t9ROw1iA/wfHkQ76Qe7AaPF0nGuim96/IrQMQ==} engines: {node: '>=4'} dependencies: @@ -18751,26 +20145,26 @@ packages: unicode-match-property-value-ecmascript: 2.1.0 dev: true - /regjsparser/0.10.0: + /regjsparser@0.10.0: resolution: {integrity: sha512-qx+xQGZVsy55CH0a1hiVwHmqjLryfh7wQyF5HO07XJ9f7dQMY/gPQHhlyDkIzJKC+x2fUCpCcUODUUUFrm7SHA==} hasBin: true dependencies: jsesc: 0.5.0 dev: true - /regjsparser/0.9.1: + /regjsparser@0.9.1: resolution: {integrity: sha512-dQUtn90WanSNl+7mQKcXAgZxvUe7Z0SqXlgzv0za4LwiUhyzBC58yQO3liFoUgu8GiJVInAhJjkj1N0EtQ5nkQ==} hasBin: true dependencies: jsesc: 0.5.0 dev: true - /relateurl/0.2.7: + /relateurl@0.2.7: resolution: {integrity: sha512-G08Dxvm4iDN3MLM0EsP62EDV9IuhXPR6blNz6Utcp7zyV3tr4HVNINt6MpaRWbxoOHT3Q7YN2P+jaHX8vUbgog==} engines: {node: '>= 0.10'} dev: true - /remark-external-links/8.0.0: + /remark-external-links@8.0.0: resolution: {integrity: sha512-5vPSX0kHoSsqtdftSHhIYofVINC8qmp0nctkeU9YoJwV3YfiBRiI6cbFRJ0oI/1F9xS+bopXG0m2KS8VFscuKA==} dependencies: extend: 3.0.2 @@ -18780,17 +20174,17 @@ packages: unist-util-visit: 2.0.3 dev: true - /remark-footnotes/2.0.0: + /remark-footnotes@2.0.0: resolution: {integrity: sha512-3Clt8ZMH75Ayjp9q4CorNeyjwIxHFcTkaektplKGl2A1jNGEUey8cKL0ZC5vJwfcD5GFGsNLImLG/NGzWIzoMQ==} dev: true - /remark-mdx/1.6.22: + /remark-mdx@1.6.22: resolution: {integrity: sha512-phMHBJgeV76uyFkH4rvzCftLfKCr2RZuF+/gmVcaKrpsihyzmhXjA0BEMDaPTXG5y8qZOKPVo83NAOX01LPnOQ==} dependencies: '@babel/core': 7.12.9 '@babel/helper-plugin-utils': 7.10.4 - '@babel/plugin-proposal-object-rest-spread': 7.12.1_@babel+core@7.12.9 - '@babel/plugin-syntax-jsx': 7.12.1_@babel+core@7.12.9 + '@babel/plugin-proposal-object-rest-spread': 7.12.1(@babel/core@7.12.9) + '@babel/plugin-syntax-jsx': 7.12.1(@babel/core@7.12.9) '@mdx-js/util': 1.6.22 is-alphabetical: 1.0.4 remark-parse: 8.0.3 @@ -18799,7 +20193,7 @@ packages: - supports-color dev: true - /remark-parse/8.0.3: + /remark-parse@8.0.3: resolution: {integrity: sha512-E1K9+QLGgggHxCQtLt++uXltxEprmWzNfg+MxpfHsZlrddKzZ/hZyWHDbK3/Ap8HJQqYJRXP+jHczdL6q6i85Q==} dependencies: ccount: 1.1.0 @@ -18820,7 +20214,7 @@ packages: xtend: 4.0.2 dev: true - /remark-slug/6.1.0: + /remark-slug@6.1.0: resolution: {integrity: sha512-oGCxDF9deA8phWvxFuyr3oSJsdyUAxMFbA0mZ7Y1Sas+emILtO+e5WutF9564gDsEN4IXaQXm5pFo6MLH+YmwQ==} dependencies: github-slugger: 1.5.0 @@ -18828,21 +20222,21 @@ packages: unist-util-visit: 2.0.3 dev: true - /remark-squeeze-paragraphs/4.0.0: + /remark-squeeze-paragraphs@4.0.0: resolution: {integrity: sha512-8qRqmL9F4nuLPIgl92XUuxI3pFxize+F1H0e/W3llTk0UsjJaj01+RrirkMw7P21RKe4X6goQhYRSvNWX+70Rw==} dependencies: mdast-squeeze-paragraphs: 4.0.0 dev: true - /remove-accents/0.4.2: + /remove-accents@0.4.2: resolution: {integrity: sha512-7pXIJqJOq5tFgG1A2Zxti3Ht8jJF337m4sowbuHsW30ZnkQFnDzy9qBNhgzX8ZLW4+UBcXiiR7SwR6pokHsxiA==} dev: false - /remove-trailing-separator/1.1.0: + /remove-trailing-separator@1.1.0: resolution: {integrity: sha512-/hS+Y0u3aOfIETiaiirUFwDBDzmXPvO+jAfKTitUngIPzdKc6Z0LoFjM/CK5PL4C+eKwHohlHAb6H0VFfmmUsw==} dev: true - /renderkid/2.0.7: + /renderkid@2.0.7: resolution: {integrity: sha512-oCcFyxaMrKsKcTY59qnCAtmDVSLfPbrv6A3tVbPdFMMrv5jaK10V6m40cKsoPNhAqN6rmHW9sswW4o3ruSrwUQ==} dependencies: css-select: 4.3.0 @@ -18852,17 +20246,17 @@ packages: strip-ansi: 3.0.1 dev: true - /repeat-element/1.1.4: + /repeat-element@1.1.4: resolution: {integrity: sha512-LFiNfRcSu7KK3evMyYOuCzv3L10TW7yC1G2/+StMjK8Y6Vqd2MG7r/Qjw4ghtuCOjFvlnms/iMmLqpvW/ES/WQ==} engines: {node: '>=0.10.0'} dev: true - /repeat-string/1.6.1: + /repeat-string@1.6.1: resolution: {integrity: sha512-PV0dzCYDNfRi1jCDbJzpW7jNNDRuCOG/jI5ctQcGKt/clZD+YcPS3yIlWuTJMmESC8aevCFmWJy5wjAFgNqN6w==} engines: {node: '>=0.10'} dev: true - /repeating/2.0.1: + /repeating@2.0.1: resolution: {integrity: sha512-ZqtSMuVybkISo2OWvqvm7iHSWngvdaW3IpsT9/uP8v4gMi591LY6h35wdOfvQdWCKFWZWm2Y1Opp4kV7vQKT6A==} engines: {node: '>=0.10.0'} dependencies: @@ -18870,49 +20264,61 @@ packages: dev: true optional: true - /request-progress/3.0.0: + /request-progress@3.0.0: resolution: {integrity: sha512-MnWzEHHaxHO2iWiQuHrUPBi/1WeBf5PkxQqNyNvLl9VAYSdXkP8tQ3pBSeCPD+yw0v0Aq1zosWLz0BdeXpWwZg==} dependencies: throttleit: 1.0.0 dev: true - /require-directory/2.1.1: + /require-directory@2.1.1: resolution: {integrity: sha512-fGxEI7+wsG9xrvdjsrlmL22OMTTiHRwAMroiEeMgq8gzoLC/PQr7RsRDSTLUg/bZAZtF+TVIkHc6/4RIKrui+Q==} engines: {node: '>=0.10.0'} dev: true - /require-from-string/2.0.2: + /require-from-string@2.0.2: resolution: {integrity: sha512-Xf0nWe6RseziFMu+Ap9biiUbmplq6S9/p+7w7YXP/JBHhrUDDUhwa+vANyubuqfZWTveU//DYVGsDG7RKL/vEw==} engines: {node: '>=0.10.0'} dev: true - /requires-port/1.0.0: + /requires-port@1.0.0: resolution: {integrity: sha512-KigOCHcocU3XODJxsu8i/j8T9tzT4adHiecwORRQ0ZZFcp7ahwXuRU1m+yuO90C5ZUyGeGfocHDI14M3L3yDAQ==} dev: true - /resolve-alpn/1.2.1: + /resolve-alpn@1.2.1: resolution: {integrity: sha512-0a1F4l73/ZFZOakJnQ3FvkJ2+gSTQWz/r2KE5OdDY0TxPm5h4GkqkWWfM47T7HsbnOtcJVEF4epCVy6u7Q3K+g==} dev: true - /resolve-from/4.0.0: + /resolve-cwd@3.0.0: + resolution: {integrity: sha512-OrZaX2Mb+rJCpH/6CpSqt9xFVpN++x01XnN2ie9g6P5/3xelLAkXWVADpdz1IHD/KFfEXyE6V0U01OQ3UO2rEg==} + engines: {node: '>=8'} + dependencies: + resolve-from: 5.0.0 + dev: true + + /resolve-from@4.0.0: resolution: {integrity: sha512-pb/MYmXstAkysRFx8piNI1tGFNQIFA3vkE3Gq4EuA1dF6gHp/+vgZqsCGJapvy8N3Q+4o7FwvquPJcnZ7RYy4g==} engines: {node: '>=4'} - /resolve-from/5.0.0: + /resolve-from@5.0.0: resolution: {integrity: sha512-qYg9KP24dD5qka9J47d0aVky0N+b4fTU89LN9iDnjB5waksiC49rvMB0PrUJQGoTmH50XPiqOvAjDfaijGxYZw==} engines: {node: '>=8'} dev: true - /resolve-pkg-maps/1.0.0: + /resolve-pkg-maps@1.0.0: resolution: {integrity: sha512-seS2Tj26TBVOC2NIc2rOe2y2ZO7efxITtLZcGSOnHHNOQ7CkiUBfw0Iw2ck6xkIhPwLhKNLS8BO+hEpngQlqzw==} dev: true - /resolve-url/0.2.1: + /resolve-url@0.2.1: resolution: {integrity: sha512-ZuF55hVUQaaczgOIwqWzkEcEidmlD/xl44x1UZnhOXcYuFN2S6+rcxpG+C1N3So0wvNI3DmJICUFfu2SxhBmvg==} deprecated: https://github.com/lydell/resolve-url#deprecated dev: true - /resolve/1.22.2: + /resolve.exports@1.1.1: + resolution: {integrity: sha512-/NtpHNDN7jWhAaQ9BvBUYZ6YTXsRBgfqWFWP7BZBaoMJO/I3G5OFzvTuWNlZC3aPjins1F+TNrLKsGbH4rfsRQ==} + engines: {node: '>=10'} + dev: true + + /resolve@1.22.2: resolution: {integrity: sha512-Sb+mjNHOULsBv818T40qSPeRiuWLyaGMa5ewydRLFimneixmVy2zdivRl+AF6jaYPC8ERxGDmFSiqui6SfPd+g==} hasBin: true dependencies: @@ -18920,7 +20326,7 @@ packages: path-parse: 1.0.7 supports-preserve-symlinks-flag: 1.0.0 - /resolve/1.22.3: + /resolve@1.22.3: resolution: {integrity: sha512-P8ur/gp/AmbEzjr729bZnLjXK5Z+4P0zhIJgBgzqRih7hL7BOukHGtSTA3ACMY467GRFz3duQsi0bDZdR7DKdw==} hasBin: true dependencies: @@ -18929,25 +20335,25 @@ packages: supports-preserve-symlinks-flag: 1.0.0 dev: true - /response-iterator/0.2.6: + /response-iterator@0.2.6: resolution: {integrity: sha512-pVzEEzrsg23Sh053rmDUvLSkGXluZio0qu8VT6ukrYuvtjVfCbDZH9d6PGXb8HZfzdNZt8feXv/jvUzlhRgLnw==} engines: {node: '>=0.8'} dev: false - /responselike/3.0.0: + /responselike@3.0.0: resolution: {integrity: sha512-40yHxbNcl2+rzXvZuVkrYohathsSJlMTXKryG5y8uciHv1+xDLHQpgjG64JUO9nrEq2jGLH6IZ8BcZyw3wrweg==} engines: {node: '>=14.16'} dependencies: lowercase-keys: 3.0.0 dev: true - /resq/1.11.0: + /resq@1.11.0: resolution: {integrity: sha512-G10EBz+zAAy3zUd/CDoBbXRL6ia9kOo3xRHrMDsHljI0GDkhYlyjwoCx5+3eCC4swi1uCoZQhskuJkj7Gp57Bw==} dependencies: fast-deep-equal: 2.0.1 dev: true - /restore-cursor/3.1.0: + /restore-cursor@3.1.0: resolution: {integrity: sha512-l+sSefzHpj5qimhFSE5a8nufZYAM3sBSVMAPtYkmC+4EH2anSGaEMXSD0izRQbu9nfyQ9y5JrVmp7E8oZrUjvA==} engines: {node: '>=8'} dependencies: @@ -18955,7 +20361,7 @@ packages: signal-exit: 3.0.7 dev: true - /restore-cursor/4.0.0: + /restore-cursor@4.0.0: resolution: {integrity: sha512-I9fPXU9geO9bHOt9pHHOhOkYerIMsmVaWB0rA2AI9ERh/+x/i7MV5HKBNrg+ljO5eoPVgCcnFuRjJ9uH6I/3eg==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dependencies: @@ -18963,29 +20369,29 @@ packages: signal-exit: 3.0.7 dev: true - /ret/0.1.15: + /ret@0.1.15: resolution: {integrity: sha512-TTlYpa+OL+vMMNG24xSlQGEJ3B/RzEfUlLct7b5G/ytav+wPrplCpVMFuwzXbkecJrb6IYo1iFb0S9v37754mg==} engines: {node: '>=0.12'} dev: true - /ret/0.2.2: + /ret@0.2.2: resolution: {integrity: sha512-M0b3YWQs7R3Z917WRQy1HHA7Ba7D8hvZg6UE5mLykJxQVE2ju0IXbGlaHPPlkY+WN7wFP+wUMXmBFA0aV6vYGQ==} engines: {node: '>=4'} dev: true - /reusify/1.0.4: + /reusify@1.0.4: resolution: {integrity: sha512-U9nH88a3fc/ekCF1l0/UP1IosiuIjyTh7hBvXVMHYgVcfGvt897Xguj2UOLDeI5BG2m7/uwyaLVT6fbtCwTyzw==} engines: {iojs: '>=1.0.0', node: '>=0.10.0'} - /rfdc/1.3.0: + /rfdc@1.3.0: resolution: {integrity: sha512-V2hovdzFbOi77/WajaSMXk2OLm+xNIeQdMMuB7icj7bk6zi2F8GGAxigcnDFpJHbNyNcgyJDiP+8nOrY5cZGrA==} dev: true - /rgb2hex/0.2.5: + /rgb2hex@0.2.5: resolution: {integrity: sha512-22MOP1Rh7sAo1BZpDG6R5RFYzR2lYEgwq7HEmyW2qcsOqR2lQKmn+O//xV3YG/0rrhMC6KVX2hU+ZXuaw9a5bw==} dev: true - /rifm/0.12.1_react@18.2.0: + /rifm@0.12.1(react@18.2.0): resolution: {integrity: sha512-OGA1Bitg/dSJtI/c4dh90svzaUPt228kzFsUkJbtA2c964IqEAwWXeL9ZJi86xWv3j5SMqRvGULl7bA6cK0Bvg==} peerDependencies: react: '>=16.8' @@ -18993,20 +20399,20 @@ packages: react: 18.2.0 dev: false - /rimraf/2.7.1: + /rimraf@2.7.1: resolution: {integrity: sha512-uWjbaKIK3T1OSVptzX7Nl6PvQ3qAGtKEtVRjRuazjfL3Bx5eI409VZSqgND+4UNnmzLVdPj9FqFJNPqBZFve4w==} hasBin: true dependencies: glob: 7.2.3 dev: true - /rimraf/3.0.2: + /rimraf@3.0.2: resolution: {integrity: sha512-JZkJMZkAGFFPP2YqXZXPbMlMBgsxzE8ILs4lMIX/2o0L9UBw9O/Y3o6wFw/i9YLapcUJWwqbi3kdxIPdC62TIA==} hasBin: true dependencies: glob: 7.2.3 - /rimraf/5.0.1: + /rimraf@5.0.1: resolution: {integrity: sha512-OfFZdwtd3lZ+XZzYP/6gTACubwFcHdLRqS9UX3UwpU2dnGQYkPFISRwvM3w9IiB2w7bW5qGo/uAwE4SmXXSKvg==} engines: {node: '>=14'} hasBin: true @@ -19014,14 +20420,14 @@ packages: glob: 10.3.3 dev: true - /ripemd160/2.0.2: + /ripemd160@2.0.2: resolution: {integrity: sha512-ii4iagi25WusVoiC4B4lq7pbXfAp3D9v5CwfkY33vffw2+pkDjY1D8GaN7spsxvCSx8dkPqOZCEZyfxcmJG2IA==} dependencies: hash-base: 3.1.0 inherits: 2.0.4 dev: true - /rollup-plugin-dts/5.3.0_btijhbnqj3bkl7p6fnurpsgzhq: + /rollup-plugin-dts@5.3.0(rollup@3.26.2)(typescript@5.1.6): resolution: {integrity: sha512-8FXp0ZkyZj1iU5klkIJYLjIq/YZSwBoERu33QBDxm/1yw5UU4txrEtcmMkrq+ZiKu3Q4qvPCNqc3ovX6rjqzbQ==} engines: {node: '>=v14'} peerDependencies: @@ -19035,15 +20441,15 @@ packages: '@babel/code-frame': 7.22.5 dev: true - /rollup-plugin-esbuild/5.0.0_b5okt2kat7kf37a3hh6exlw3ju: + /rollup-plugin-esbuild@5.0.0(esbuild@0.18.11)(rollup@3.26.2): resolution: {integrity: sha512-1cRIOHAPh8WQgdQQyyvFdeOdxuiyk+zB5zJ5+YOwrZP4cJ0MT3Fs48pQxrZeyZHcn+klFherytILVfE4aYrneg==} engines: {node: '>=14.18.0', npm: '>=8.0.0'} peerDependencies: esbuild: '>=0.10.1' rollup: ^1.20.0 || ^2.0.0 || ^3.0.0 dependencies: - '@rollup/pluginutils': 5.0.2_rollup@3.26.2 - debug: 4.3.4 + '@rollup/pluginutils': 5.0.2(rollup@3.26.2) + debug: 4.3.4(supports-color@8.1.1) es-module-lexer: 1.3.0 esbuild: 0.18.11 joycon: 3.1.1 @@ -19053,7 +20459,7 @@ packages: - supports-color dev: true - /rollup-plugin-license/3.0.1_rollup@3.26.2: + /rollup-plugin-license@3.0.1(rollup@3.26.2): resolution: {integrity: sha512-/lec6Y94Y3wMfTDeYTO/jSXII0GQ/XkDZCiqkMKxyU5D5nGPaxr/2JNYvAgYsoCYuOLGOanKDPjCCQiTT96p7A==} engines: {node: '>=14.0.0'} peerDependencies: @@ -19071,7 +20477,7 @@ packages: spdx-satisfies: 5.0.1 dev: true - /rollup-plugin-terser/7.0.2_rollup@2.79.1: + /rollup-plugin-terser@7.0.2(rollup@2.79.1): resolution: {integrity: sha512-w3iIaU4OxcF52UUXiZNsNeuXIMDvFrr+ZXK6bFZ0Q60qyVfq4uLptoS4bbq3paG3x216eQllFZX7zt6TIImguQ==} deprecated: This package has been deprecated and is no longer maintained. Please use @rollup/plugin-terser peerDependencies: @@ -19084,80 +20490,79 @@ packages: terser: 5.19.0 dev: true - /rollup/2.79.1: + /rollup@2.79.1: resolution: {integrity: sha512-uKxbd0IhMZOhjAiD5oAFp7BqvkA4Dv47qpOCtaNvng4HBwdbWtdOh8f5nZNuk2rp51PMGk3bzfWu5oayNEuYnw==} engines: {node: '>=10.0.0'} hasBin: true optionalDependencies: fsevents: 2.3.2 - dev: true - /rollup/3.26.2: + /rollup@3.26.2: resolution: {integrity: sha512-6umBIGVz93er97pMgQO08LuH3m6PUb3jlDUUGFsNJB6VgTCUaDFpupf5JfU30529m/UKOgmiX+uY6Sx8cOYpLA==} engines: {node: '>=14.18.0', npm: '>=8.0.0'} hasBin: true optionalDependencies: fsevents: 2.3.2 - /rrweb-cssom/0.6.0: + /rrweb-cssom@0.6.0: resolution: {integrity: sha512-APM0Gt1KoXBz0iIkkdB/kfvGOwC4UuJFeG/c+yV7wSc7q96cG/kJ0HiYCnzivD9SB53cLV1MlHFNfOuPaadYSw==} dev: true - /rst-selector-parser/2.2.3: + /rst-selector-parser@2.2.3: resolution: {integrity: sha512-nDG1rZeP6oFTLN6yNDV/uiAvs1+FS/KlrEwh7+y7dpuApDBy6bI2HTBcc0/V8lv9OTqfyD34eF7au2pm8aBbhA==} dependencies: lodash.flattendeep: 4.4.0 nearley: 2.20.1 dev: true - /rsvp/4.8.5: + /rsvp@4.8.5: resolution: {integrity: sha512-nfMOlASu9OnRJo1mbEk2cz0D56a1MBNrJ7orjRZQG10XDyuvwksKbuXNp6qa+kbn839HwjwhBzhFmdsaEAfauA==} engines: {node: 6.* || >= 7.*} dev: true - /run-async/2.4.1: + /run-async@2.4.1: resolution: {integrity: sha512-tvVnVv01b8c1RrA6Ep7JkStj85Guv/YrMcwqYQnwjsAS2cTmmPGBBjAjpCW7RrSodNSoE2/qg9O4bceNvUuDgQ==} engines: {node: '>=0.12.0'} dev: true - /run-async/3.0.0: + /run-async@3.0.0: resolution: {integrity: sha512-540WwVDOMxA6dN6We19EcT9sc3hkXPw5mzRNGM3FkdN/vtE9NFvj5lFAPNwUDmJjXidm3v7TC1cTE7t17Ulm1Q==} engines: {node: '>=0.12.0'} dev: true - /run-parallel/1.2.0: + /run-parallel@1.2.0: resolution: {integrity: sha512-5l4VyZR86LZ/lDxZTR6jqL8AFE2S0IFLMP26AbjsLVADxHdhB/c0GUsH+y39UfCi3dzz8OlQuPmnaJOMoDHQBA==} dependencies: queue-microtask: 1.2.3 - /run-queue/1.0.3: + /run-queue@1.0.3: resolution: {integrity: sha512-ntymy489o0/QQplUDnpYAYUsO50K9SBrIVaKCWDOJzYJts0f9WH9RFJkyagebkw5+y1oi00R7ynNW/d12GBumg==} dependencies: aproba: 1.2.0 dev: true - /rxjs/7.8.1: + /rxjs@7.8.1: resolution: {integrity: sha512-AA3TVj+0A2iuIoQkWEK/tqFjBq2j+6PO6Y0zJcvzLAFhEFIO3HL0vls9hWLncZbAAbK0mar7oZ4V079I/qPMxg==} dependencies: tslib: 2.6.0 dev: true - /sade/1.8.1: + /sade@1.8.1: resolution: {integrity: sha512-xal3CZX1Xlo/k4ApwCFrHVACi9fBqJ7V+mwhBsuf/1IOKbBy098Fex+Wa/5QMubw09pSZ/u8EY8PWgevJsXp1A==} engines: {node: '>=6'} dependencies: mri: 1.2.0 dev: true - /safaridriver/0.0.4: + /safaridriver@0.0.4: resolution: {integrity: sha512-EgK9Vc2Bk4WaECq1E7ti9GyeQ6JKKQNs40vNOE/b5Ul5dDEt429G0Kj5Nzs4FRS5ZIVa7nBck1TyHuinOYdz2Q==} dev: true - /safaridriver/0.0.5: + /safaridriver@0.0.5: resolution: {integrity: sha512-997HUPVHdOk0019Yz2qbX/B47bC0LcUxMrHU2PDY8IOO7hiT1uhBQEeEAF1BeCrZKFgx5cmsbWYmFgFN0TfqNA==} dev: true - /safe-array-concat/1.0.0: + /safe-array-concat@1.0.0: resolution: {integrity: sha512-9dVEFruWIsnie89yym+xWTAYASdpw3CJV7Li/6zBewGf9z2i1j31rP6jnY0pHEO4QZh6N0K11bFjWmdR8UGdPQ==} engines: {node: '>=0.4'} dependencies: @@ -19167,19 +20572,19 @@ packages: isarray: 2.0.5 dev: true - /safe-buffer/5.1.1: + /safe-buffer@5.1.1: resolution: {integrity: sha512-kKvNJn6Mm93gAczWVJg7wH+wGYWNrDHdWvpUmHyEsgCtIwwo3bqPtV4tR5tuPaUhTOo/kvhVwd8XwwOllGYkbg==} dev: true - /safe-buffer/5.1.2: + /safe-buffer@5.1.2: resolution: {integrity: sha512-Gd2UZBJDkXlY7GbJxfsE8/nvKkUEU1G38c1siN6QP6a9PT9MmHB8GnpscSmMJSoF8LOIrt8ud/wPtojys4G6+g==} dev: true - /safe-buffer/5.2.1: + /safe-buffer@5.2.1: resolution: {integrity: sha512-rp3So07KcdmmKbGvgaNxQSJr7bGVSVk5S9Eq1F+ppbRo70+YeaDxkw5Dd8NPN+GD6bjnYm2VuPuCXmpuYvmCXQ==} dev: true - /safe-regex-test/1.0.0: + /safe-regex-test@1.0.0: resolution: {integrity: sha512-JBUUzyOgEwXQY1NuPtvcj/qcBDbDmEvWufhlnXZIm75DEHp+afM1r1ujJpJsV/gSM4t59tpDyPi1sd6ZaPFfsA==} dependencies: call-bind: 1.0.2 @@ -19187,34 +20592,34 @@ packages: is-regex: 1.1.4 dev: true - /safe-regex/1.1.0: + /safe-regex2@2.0.0: + resolution: {integrity: sha512-PaUSFsUaNNuKwkBijoAPHAK6/eM6VirvyPWlZ7BAQy4D+hCvh4B6lIG+nPdhbFfIbP+gTGBcrdsOaUs0F+ZBOQ==} + dependencies: + ret: 0.2.2 + dev: true + + /safe-regex@1.1.0: resolution: {integrity: sha512-aJXcif4xnaNUzvUuC5gcb46oTS7zvg4jpMTnuqtrEPlR3vFr4pxtdTwaF1Qs3Enjn9HK+ZlwQui+a7z0SywIzg==} dependencies: ret: 0.1.15 dev: true - /safe-regex/2.1.1: + /safe-regex@2.1.1: resolution: {integrity: sha512-rx+x8AMzKb5Q5lQ95Zoi6ZbJqwCLkqi3XuJXp5P3rT8OEc6sZCJG5AE5dU3lsgRr/F4Bs31jSlVN+j5KrsGu9A==} dependencies: regexp-tree: 0.1.27 dev: true - /safe-regex2/2.0.0: - resolution: {integrity: sha512-PaUSFsUaNNuKwkBijoAPHAK6/eM6VirvyPWlZ7BAQy4D+hCvh4B6lIG+nPdhbFfIbP+gTGBcrdsOaUs0F+ZBOQ==} - dependencies: - ret: 0.2.2 - dev: true - - /safe-stable-stringify/2.4.3: + /safe-stable-stringify@2.4.3: resolution: {integrity: sha512-e2bDA2WJT0wxseVd4lsDP4+3ONX6HpMXQa1ZhFQ7SU+GjvORCmShbCMltrtIDfkYhVHrOcPtj+KhmDBdPdZD1g==} engines: {node: '>=10'} dev: true - /safer-buffer/2.1.2: + /safer-buffer@2.1.2: resolution: {integrity: sha512-YZo3K82SD7Riyi0E1EQPojLz7kpepnSQI9IyPbHHg1XXXevb5dJI7tpyN2ADxGcQbHG7vcyRHk0cbwqcQriUtg==} dev: true - /sander/0.5.1: + /sander@0.5.1: resolution: {integrity: sha512-3lVqBir7WuKDHGrKRDn/1Ye3kwpXaDOMsiRP1wd6wpZW56gJhsbp5RqQpA6JG/P+pkXizygnr1dKR8vzWaVsfA==} dependencies: es6-promise: 3.3.1 @@ -19223,7 +20628,7 @@ packages: rimraf: 2.7.1 dev: true - /sane/4.1.0: + /sane@4.1.0: resolution: {integrity: sha512-hhbzAgTIX8O7SHfp2c8/kREfEn4qO/9q8C9beyY6+tvZ87EpoZ3i1RIEvp27YBswnNbY9mWd6paKVmKbAgLfZA==} engines: {node: 6.* || 8.* || >= 10.*} deprecated: some dependency vulnerabilities fixed, support for node < 10 dropped, and newer ECMAScript syntax/features added @@ -19242,87 +20647,99 @@ packages: - supports-color dev: true - /saxes/6.0.0: + /saxes@5.0.1: + resolution: {integrity: sha512-5LBh1Tls8c9xgGjw3QrMwETmTMVk0oFgvrFSvWx62llR2hcEInrKNZ2GZCCuuy2lvWrdl5jhbpeqc5hRYKFOcw==} + engines: {node: '>=10'} + dependencies: + xmlchars: 2.2.0 + dev: true + + /saxes@6.0.0: resolution: {integrity: sha512-xAg7SOnEhrm5zI3puOOKyy1OMcMlIJZYNJY7xLBwSze0UjhPLnWfj2GF2EpT0jmzaJKIWKHLsaSSajf35bcYnA==} engines: {node: '>=v12.22.7'} dependencies: xmlchars: 2.2.0 dev: true - /scheduler/0.20.2: + /scheduler@0.20.2: resolution: {integrity: sha512-2eWfGgAqqWFGqtdMmcL5zCMK1U8KlXv8SQFGglL3CEtd0aDVDWgeF/YoCmvln55m5zSk3J/20hTaSBeSObsQDQ==} dependencies: loose-envify: 1.4.0 object-assign: 4.1.1 - /scheduler/0.21.0: + /scheduler@0.21.0: resolution: {integrity: sha512-1r87x5fz9MXqswA2ERLo0EbOAU74DpIUO090gIasYTqlVoJeMcl+Z1Rg7WHz+qtPujhS/hGIt9kxZOYBV3faRQ==} dependencies: loose-envify: 1.4.0 - /scheduler/0.23.0: + /scheduler@0.23.0: resolution: {integrity: sha512-CtuThmgHNg7zIZWAXi3AsyIzA3n4xx7aNyjwC2VJldO2LMVDhFK+63xGqq6CsJH4rTAt6/M+N4GhZiDYPx9eUw==} dependencies: loose-envify: 1.4.0 - /schema-utils/1.0.0: + /schema-utils@1.0.0: resolution: {integrity: sha512-i27Mic4KovM/lnGsy8whRCHhc7VicJajAjTrYg11K9zfZXnYIt4k5F+kZkwjnrhKzLic/HLU4j11mjsz2G/75g==} engines: {node: '>= 4'} dependencies: ajv: 6.12.6 - ajv-errors: 1.0.1_ajv@6.12.6 - ajv-keywords: 3.5.2_ajv@6.12.6 + ajv-errors: 1.0.1(ajv@6.12.6) + ajv-keywords: 3.5.2(ajv@6.12.6) dev: true - /schema-utils/2.7.0: + /schema-utils@2.7.0: resolution: {integrity: sha512-0ilKFI6QQF5nxDZLFn2dMjvc4hjg/Wkg7rHd3jK6/A4a1Hl9VFdQWvgB1UMGoU94pad1P/8N7fMcEnLnSiju8A==} engines: {node: '>= 8.9.0'} dependencies: '@types/json-schema': 7.0.12 ajv: 6.12.6 - ajv-keywords: 3.5.2_ajv@6.12.6 + ajv-keywords: 3.5.2(ajv@6.12.6) dev: true - /schema-utils/2.7.1: + /schema-utils@2.7.1: resolution: {integrity: sha512-SHiNtMOUGWBQJwzISiVYKu82GiV4QYGePp3odlY1tuKO7gPtphAT5R/py0fA6xtbgLL/RvtJZnU9b8s0F1q0Xg==} engines: {node: '>= 8.9.0'} dependencies: '@types/json-schema': 7.0.12 ajv: 6.12.6 - ajv-keywords: 3.5.2_ajv@6.12.6 + ajv-keywords: 3.5.2(ajv@6.12.6) dev: true - /schema-utils/3.3.0: + /schema-utils@3.3.0: resolution: {integrity: sha512-pN/yOAvcC+5rQ5nERGuwrjLlYvLTbCibnZ1I7B1LaiAz9BRBlE9GMgE/eqV30P7aJQUf7Ddimy/RsbYO/GrVGg==} engines: {node: '>= 10.13.0'} dependencies: '@types/json-schema': 7.0.12 ajv: 6.12.6 - ajv-keywords: 3.5.2_ajv@6.12.6 + ajv-keywords: 3.5.2(ajv@6.12.6) dev: true - /scule/1.0.0: + /scule@1.0.0: resolution: {integrity: sha512-4AsO/FrViE/iDNEPaAQlb77tf0csuq27EsVpy6ett584EcRTp6pTDLoGWVxCD77y5iU5FauOvhsI4o1APwPoSQ==} dev: true - /secure-json-parse/2.7.0: + /search-insights@2.7.0: + resolution: {integrity: sha512-GLbVaGgzYEKMvuJbHRhLi1qoBFnjXZGZ6l4LxOYPCp4lI2jDRB3jPU9/XNhMwv6kvnA9slTreq6pvK+b3o3aqg==} + engines: {node: '>=8.16.0'} + dev: true + + /secure-json-parse@2.7.0: resolution: {integrity: sha512-6aU+Rwsezw7VR8/nyvKTx8QpWH9FrcYiXXlqC4z5d5XQBDRqtbfsRjnwGyqbi3gddNtWHuEk9OANUotL26qKUw==} dev: true - /select-hose/2.0.0: + /select-hose@2.0.0: resolution: {integrity: sha512-mEugaLK+YfkijB4fx0e6kImuJdCIt2LxCRcbEYPqRGCs4F2ogyfZU5IAZRdjCP8JPq2AtdNoC/Dux63d9Kiryg==} dev: true - /semver/5.7.2: + /semver@5.7.2: resolution: {integrity: sha512-cBznnQ9KjJqU67B52RMC65CMarK2600WFnbkcaiwWq3xy/5haFJlshgnpjovMVJ+Hff49d8GEn0b87C5pDQ10g==} hasBin: true dev: true - /semver/6.3.1: + /semver@6.3.1: resolution: {integrity: sha512-BR7VvDCVHO+q2xBEWskxS6DJE1qRnb7DxzUrogb71CWoSficBxYsiAGd+Kl0mmq/MprG9yArRkyrQxTO6XjMzA==} hasBin: true - /semver/7.5.4: + /semver@7.5.4: resolution: {integrity: sha512-1bCSESV6Pv+i21Hvpxp3Dx+pSD8lIPt8uVjRrxAUt/nbswYc+tK6Y2btiULjd4+fnq15PX+nqQDC7Oft7WkwcA==} engines: {node: '>=10'} hasBin: true @@ -19330,7 +20747,7 @@ packages: lru-cache: 6.0.0 dev: true - /send/0.18.0: + /send@0.18.0: resolution: {integrity: sha512-qqWzuOjSFOuqPjFe4NOsMLafToQQwBSOEpS+FwEt3A2V3vKubTquT3vmLTQpFgMXp8AlFWFuP1qKaJZOtPpVXg==} engines: {node: '>= 0.8.0'} dependencies: @@ -19351,36 +20768,36 @@ packages: - supports-color dev: true - /serialize-error/8.1.0: + /serialize-error@8.1.0: resolution: {integrity: sha512-3NnuWfM6vBYoy5gZFvHiYsVbafvI9vZv/+jlIigFn4oP4zjNPK3LhcY0xSCgeb1a5L8jO71Mit9LlNoi2UfDDQ==} engines: {node: '>=10'} dependencies: type-fest: 0.20.2 dev: true - /serialize-javascript/4.0.0: + /serialize-javascript@4.0.0: resolution: {integrity: sha512-GaNA54380uFefWghODBWEGisLZFj00nS5ACs6yHa9nLqlLpVLO8ChDGeKRjZnV4Nh4n0Qi7nhYZD/9fCPzEqkw==} dependencies: randombytes: 2.1.0 dev: true - /serialize-javascript/5.0.1: + /serialize-javascript@5.0.1: resolution: {integrity: sha512-SaaNal9imEO737H2c05Og0/8LUXG7EnsZyMa8MzkmuHoELfT6txuj0cMqRj6zfPKnmQ1yasR4PCJc8x+M4JSPA==} dependencies: randombytes: 2.1.0 dev: true - /serialize-javascript/6.0.1: + /serialize-javascript@6.0.1: resolution: {integrity: sha512-owoXEFjWRllis8/M1Q+Cw5k8ZH40e3zhp/ovX+Xr/vi1qj6QesbyXXViFbpNvWvPNAD62SutwEXavefrLJWj7w==} dependencies: randombytes: 2.1.0 dev: true - /seroval/0.5.1: + /seroval@0.5.1: resolution: {integrity: sha512-ZfhQVB59hmIauJG5Ydynupy8KHyr5imGNtdDhbZG68Ufh1Ynkv9KOYOAABf71oVbQxJ8VkWnMHAjEHE7fWkH5g==} engines: {node: '>=10'} - /serve-favicon/2.5.0: + /serve-favicon@2.5.0: resolution: {integrity: sha512-FMW2RvqNr03x+C0WxTyu6sOv21oOjkq5j8tjquWccwa6ScNyGFOGJVpuS1NmTVGBAHS07xnSKotgf2ehQmf9iA==} engines: {node: '>= 0.8.0'} dependencies: @@ -19391,7 +20808,7 @@ packages: safe-buffer: 5.1.1 dev: true - /serve-static/1.15.0: + /serve-static@1.15.0: resolution: {integrity: sha512-XGuRDNjXUijsUL0vl6nSD7cwURuzEgglbOaFuZM9g3kwDXOWVTck0jLzjPzGD+TazWbboZYu52/9/XPdUgne9g==} engines: {node: '>= 0.8.0'} dependencies: @@ -19403,15 +20820,15 @@ packages: - supports-color dev: true - /set-blocking/2.0.0: + /set-blocking@2.0.0: resolution: {integrity: sha512-KiKBS8AnWGEyLzofFfmvKwpdPzqiy16LvQfK3yv/fVH7Bj13/wl3JSR1J+rfgRE9q7xUJK4qvgS8raSOeLUehw==} dev: true - /set-cookie-parser/2.6.0: + /set-cookie-parser@2.6.0: resolution: {integrity: sha512-RVnVQxTXuerk653XfuliOxBP81Sf0+qfQE73LIYKcyMYHG94AuH0kgrQpRDuTZnSmjpysHmzxJXKNfa6PjFhyQ==} dev: true - /set-value/2.0.1: + /set-value@2.0.1: resolution: {integrity: sha512-JxHc1weCN68wRY0fhCoXpyK55m/XPHafOmK4UWD7m2CI14GMcFypt4w/0+NV5f/ZMby2F6S2wwA7fgynh9gWSw==} engines: {node: '>=0.10.0'} dependencies: @@ -19421,15 +20838,15 @@ packages: split-string: 3.1.0 dev: true - /setimmediate/1.0.5: + /setimmediate@1.0.5: resolution: {integrity: sha512-MATJdZp8sLqDl/68LfQmbP8zKPLQNV6BIZoIgrscFDQ+RsvK/BxeDQOgyxKKoh0y/8h3BqVFnCqQ/gd+reiIXA==} dev: true - /setprototypeof/1.2.0: + /setprototypeof@1.2.0: resolution: {integrity: sha512-E5LDX7Wrp85Kil5bhZv46j8jOeboKq5JMmYM3gVGdGH8xFpPWXUMsNrlODCrkoxMEeNi/XZIwuRvY4XNwYMJpw==} dev: true - /sha.js/2.4.11: + /sha.js@2.4.11: resolution: {integrity: sha512-QMEp5B7cftE7APOjk5Y6xgrbWu+WkLVQwk8JNjZ8nKRciZaByEW6MubieAiToS7+dwvrjGhH8jRXz3MVd0AYqQ==} hasBin: true dependencies: @@ -19437,14 +20854,14 @@ packages: safe-buffer: 5.2.1 dev: true - /shallow-clone/3.0.1: + /shallow-clone@3.0.1: resolution: {integrity: sha512-/6KqX+GVUdqPuPPd2LxDDxzX6CAbjJehAAOKlNpqqUpAqPM6HeL8f+o3a+JsyGjn2lv0WY8UsTgUJjU9Ok55NA==} engines: {node: '>=8'} dependencies: kind-of: 6.0.3 dev: true - /sharp-ico/0.1.5: + /sharp-ico@0.1.5: resolution: {integrity: sha512-a3jODQl82NPp1d5OYb0wY+oFaPk7AvyxipIowCHk7pBsZCWgbe0yAkU2OOXdoH0ENyANhyOQbs9xkAiRHcF02Q==} dependencies: decode-ico: 0.4.1 @@ -19452,7 +20869,7 @@ packages: sharp: 0.32.2 dev: true - /sharp/0.32.2: + /sharp@0.32.2: resolution: {integrity: sha512-e4hyWKtU7ks/rLmoPys476zhpQnLqPJopz4+5b6OPeyJfvCTInAp0pe5tGhstjsNdUvDLrUVGEwevewYdZM8Eg==} engines: {node: '>=14.15.0'} requiresBuild: true @@ -19467,35 +20884,35 @@ packages: tunnel-agent: 0.6.0 dev: true - /shebang-command/1.2.0: + /shebang-command@1.2.0: resolution: {integrity: sha512-EV3L1+UQWGor21OmnvojK36mhg+TyIKDh3iFBKBohr5xeXIhNBcx8oWdgkTEEQ+BEFFYdLRuqMfd5L84N1V5Vg==} engines: {node: '>=0.10.0'} dependencies: shebang-regex: 1.0.0 dev: true - /shebang-command/2.0.0: + /shebang-command@2.0.0: resolution: {integrity: sha512-kHxr2zZpYtdmrN1qDjrrX/Z1rR1kG8Dx+gkpK1G4eXmvXswmcE1hTWBWYUzlraYw1/yZp6YuDY77YtvbN0dmDA==} engines: {node: '>=8'} dependencies: shebang-regex: 3.0.0 dev: true - /shebang-regex/1.0.0: + /shebang-regex@1.0.0: resolution: {integrity: sha512-wpoSFAxys6b2a2wHZ1XpDSgD7N9iVjg29Ph9uV/uaP9Ex/KXlkTZTeddxDPSYQpgvzKLGJke2UU0AzoGCjNIvQ==} engines: {node: '>=0.10.0'} dev: true - /shebang-regex/3.0.0: + /shebang-regex@3.0.0: resolution: {integrity: sha512-7++dFhtcx3353uBaq8DDR4NuxBetBzC7ZQOhmTQInHEd6bSrXdiEyzCvG07Z44UYdLShWUyXt5M/yhz8ekcb1A==} engines: {node: '>=8'} dev: true - /shell-quote/1.8.1: + /shell-quote@1.8.1: resolution: {integrity: sha512-6j1W9l1iAs/4xYBI1SYOVZyFcCis9b4KCLQ8fgAGG07QvzaRLVVRQvAy85yNmmZSjYjg4MWh4gNvlPujU/5LpA==} dev: true - /shiki/0.14.3: + /shiki@0.14.3: resolution: {integrity: sha512-U3S/a+b0KS+UkTyMjoNojvTgrBHjgp7L6ovhFVZsXmBGnVdQ4K4U9oK0z63w538S91ATngv1vXigHCSWOwnr+g==} dependencies: ansi-sequence-parser: 1.1.0 @@ -19504,7 +20921,7 @@ packages: vscode-textmate: 8.0.0 dev: true - /side-channel/1.0.4: + /side-channel@1.0.4: resolution: {integrity: sha512-q5XPytqFEIKHkGdiMIrY10mvLRvnQh42/+GoBlFW3b2LXLE2xxJpZFdm94we0BaoV3RwJyGqg5wS7epxTv0Zvw==} dependencies: call-bind: 1.0.2 @@ -19512,28 +20929,28 @@ packages: object-inspect: 1.12.3 dev: true - /siginfo/2.0.0: + /siginfo@2.0.0: resolution: {integrity: sha512-ybx0WO1/8bSBLEWXZvEd7gMW3Sn3JFlW3TvX1nREbDLRNQNaeNN8WK0meBwPdAaOI7TtRRRJn/Es1zhrrCHu7g==} dev: false - /sigmund/1.0.1: + /sigmund@1.0.1: resolution: {integrity: sha512-fCvEXfh6NWpm+YSuY2bpXb/VIihqWA6hLsgboC+0nl71Q7N7o2eaCW8mJa/NLvQhs6jpd3VZV4UiUQlV6+lc8g==} dev: true - /signal-exit/3.0.7: + /signal-exit@3.0.7: resolution: {integrity: sha512-wnD2ZE+l+SPC/uoS0vXeE9L1+0wuaMqKlfz9AMUo38JsyLSBWSFcHR1Rri62LZc12vLr1gb3jl7iwQhgwpAbGQ==} dev: true - /signal-exit/4.0.2: + /signal-exit@4.0.2: resolution: {integrity: sha512-MY2/qGx4enyjprQnFaZsHib3Yadh3IXyV2C321GY0pjGfVBu4un0uDJkwgdxqO+Rdx8JMT8IfJIRwbYVz3Ob3Q==} engines: {node: '>=14'} dev: true - /simple-concat/1.0.1: + /simple-concat@1.0.1: resolution: {integrity: sha512-cSFtAPtRhljv69IK0hTVZQ+OfE9nePi/rtJmw5UjHeVyVroEqJXP1sFztKUy1qU+xvz3u/sfYJLa947b7nAN2Q==} dev: true - /simple-get/4.0.1: + /simple-get@4.0.1: resolution: {integrity: sha512-brv7p5WgH0jmQJr1ZDDfKDOSeWWg+OVypG99A/5vYGPqJ6pxiaHLy8nxtFjBA7oMa01ebA9gfh1uMCFqOuXxvA==} dependencies: decompress-response: 6.0.0 @@ -19541,19 +20958,19 @@ packages: simple-concat: 1.0.1 dev: true - /simple-git-hooks/2.8.1: + /simple-git-hooks@2.8.1: resolution: {integrity: sha512-DYpcVR1AGtSfFUNzlBdHrQGPsOhuuEJ/FkmPOOlFysP60AHd3nsEpkGq/QEOdtUyT1Qhk7w9oLmFoMG+75BDog==} hasBin: true requiresBuild: true dev: true - /simple-swizzle/0.2.2: + /simple-swizzle@0.2.2: resolution: {integrity: sha512-JA//kQgZtbuY83m+xT+tXJkmJncGMTFT+C+g2h2R9uxkYIrE2yy9sgmcLhCnw57/WSD+Eh3J97FPEDFnbXnDUg==} dependencies: is-arrayish: 0.3.2 dev: true - /sirv/2.0.3: + /sirv@2.0.3: resolution: {integrity: sha512-O9jm9BsID1P+0HOi81VpXPoDxYP374pkOLzACAoyUQ/3OUVndNpsz6wMnY2z+yOxzbllCKZrM+9QrWsv4THnyA==} engines: {node: '>= 10'} dependencies: @@ -19561,26 +20978,26 @@ packages: mrmime: 1.0.1 totalist: 3.0.1 - /sisteransi/1.0.5: + /sisteransi@1.0.5: resolution: {integrity: sha512-bLGGlR1QxBcynn2d5YmDX4MGjlZvy2MRBDRNHLJ8VI6l6+9FUiyTFNJ0IveOSP0bcXgVDPRcfGqA0pjaqUpfVg==} dev: true - /slash/2.0.0: + /slash@2.0.0: resolution: {integrity: sha512-ZYKh3Wh2z1PpEXWr0MpSBZ0V6mZHAQfYevttO11c51CaWjGTaadiKZ+wVt1PbMlDV5qhMFslpZCemhwOK7C89A==} engines: {node: '>=6'} dev: true - /slash/3.0.0: + /slash@3.0.0: resolution: {integrity: sha512-g9Q1haeby36OSStwb4ntCGGGaKsaVSjQ68fBxoQcutl5fS1vuY18H3wSt3jFyFtrkx+Kz0V1G85A4MyAdDMi2Q==} engines: {node: '>=8'} dev: true - /slash/4.0.0: + /slash@4.0.0: resolution: {integrity: sha512-3dOsAHXXUkQTpOYcoAxLIorMTp4gIQr5IW3iVb7A7lFIp0VHhnynm9izx6TssdrIcVIESAlVjtnO2K8bg+Coew==} engines: {node: '>=12'} dev: true - /slice-ansi/3.0.0: + /slice-ansi@3.0.0: resolution: {integrity: sha512-pSyv7bSTC7ig9Dcgbw9AuRNUb5k5V6oDudjZoMBSr13qpLBG7tB+zgCkARjq7xIUgdz5P1Qe8u+rSGdouOOIyQ==} engines: {node: '>=8'} dependencies: @@ -19589,7 +21006,7 @@ packages: is-fullwidth-code-point: 3.0.0 dev: true - /slice-ansi/4.0.0: + /slice-ansi@4.0.0: resolution: {integrity: sha512-qMCMfhY040cVHT43K9BFygqYbUPFZKHOg7K73mtTWJRb8pyP3fzf4Ixd5SzdEJQ6MRUg/WBnOLxghZtKKurENQ==} engines: {node: '>=10'} dependencies: @@ -19598,7 +21015,7 @@ packages: is-fullwidth-code-point: 3.0.0 dev: true - /slice-ansi/5.0.0: + /slice-ansi@5.0.0: resolution: {integrity: sha512-FC+lgizVPfie0kkhqUScwRu1O/lF6NOgJmlCgK+/LYxDCTk8sGelYaHDhFcDN+Sn3Cv+3VSa4Byeo+IMCzpMgQ==} engines: {node: '>=12'} dependencies: @@ -19606,7 +21023,7 @@ packages: is-fullwidth-code-point: 4.0.0 dev: true - /snapdragon-node/2.1.1: + /snapdragon-node@2.1.1: resolution: {integrity: sha512-O27l4xaMYt/RSQ5TR3vpWCAB5Kb/czIcqUFOM/C4fYcLnbZUc1PkjTAMjof2pBWaSTwOUd6qUHcFGVGj7aIwnw==} engines: {node: '>=0.10.0'} dependencies: @@ -19615,14 +21032,14 @@ packages: snapdragon-util: 3.0.1 dev: true - /snapdragon-util/3.0.1: + /snapdragon-util@3.0.1: resolution: {integrity: sha512-mbKkMdQKsjX4BAL4bRYTj21edOf8cN7XHdYUJEe+Zn99hVEYcMvKPct1IqNe7+AZPirn8BCDOQBHQZknqmKlZQ==} engines: {node: '>=0.10.0'} dependencies: kind-of: 3.2.2 dev: true - /snapdragon/0.8.2: + /snapdragon@0.8.2: resolution: {integrity: sha512-FtyOnWN/wCHTVXOMwvSv26d+ko5vWlIDD6zoUJ7LW8vh+ZBC8QdljveRP+crNrtBwioEUWy/4dMtbBjA4ioNlg==} engines: {node: '>=0.10.0'} dependencies: @@ -19638,13 +21055,13 @@ packages: - supports-color dev: true - /solid-js/1.7.8: + /solid-js@1.7.8: resolution: {integrity: sha512-XHBWk1FvFd0JMKljko7FfhefJMTSgYEuVKcQ2a8hzRXfiuSJAGsrPPafqEo+f6l+e8Oe3cROSpIL6kbzjC1fjQ==} dependencies: csstype: 3.1.2 seroval: 0.5.1 - /solid-refresh/0.5.3_solid-js@1.7.8: + /solid-refresh@0.5.3(solid-js@1.7.8): resolution: {integrity: sha512-Otg5it5sjOdZbQZJnvo99TEBAr6J7PQ5AubZLNU6szZzg3RQQ5MX04oteBIIGDs0y2Qv8aXKm9e44V8z+UnFdw==} peerDependencies: solid-js: ^1.3 @@ -19655,7 +21072,7 @@ packages: solid-js: 1.7.8 dev: true - /solid-testing-library/0.5.1_solid-js@1.7.8: + /solid-testing-library@0.5.1(solid-js@1.7.8): resolution: {integrity: sha512-CfcCWsI5zIJz2zcyZQz2weq+6cCS5QrcmWeEmUEy03fElJ/BV5Ly4MMTsmwdOK803zY3wJP5pPf026C40VrE1Q==} engines: {node: '>= 14'} deprecated: This package is now available at @solidjs/testing-library @@ -19666,13 +21083,13 @@ packages: solid-js: 1.7.8 dev: true - /sonic-boom/3.3.0: + /sonic-boom@3.3.0: resolution: {integrity: sha512-LYxp34KlZ1a2Jb8ZQgFCK3niIHzibdwtwNUWKg0qQRzsDoJ3Gfgkf8KdBTFU3SkejDEIlWwnSnpVdOZIhFMl/g==} dependencies: atomic-sleep: 1.0.0 dev: true - /sorcery/0.11.0: + /sorcery@0.11.0: resolution: {integrity: sha512-J69LQ22xrQB1cIFJhPfgtLuI6BpWRiWu1Y3vSsIwK/eAScqJxd/+CJlUuHQRdX2C9NGFamq+KqNywGgaThwfHw==} hasBin: true dependencies: @@ -19682,15 +21099,15 @@ packages: sander: 0.5.1 dev: true - /source-list-map/2.0.1: + /source-list-map@2.0.1: resolution: {integrity: sha512-qnQ7gVMxGNxsiL4lEuJwe/To8UnK7fAnmbGEEH8RpLouuKbeEm0lhbQVFIrNSuB+G7tVrAlVsZgETT5nljf+Iw==} dev: true - /source-map-js/1.0.2: + /source-map-js@1.0.2: resolution: {integrity: sha512-R0XvVJ9WusLiqTCEiGCmICCMplcCkIwwR11mOSD9CR5u+IXYdiseeEuXCVAjS54zqwkLcPNnmU4OeJ6tUrWhDw==} engines: {node: '>=0.10.0'} - /source-map-resolve/0.5.3: + /source-map-resolve@0.5.3: resolution: {integrity: sha512-Htz+RnsXWk5+P2slx5Jh3Q66vhQj1Cllm0zvnaY98+NFx+Dv2CF/f5O/t8x+KaNdrdIAsruNzoh/KpialbqAnw==} deprecated: See https://github.com/lydell/source-map-resolve#deprecated dependencies: @@ -19701,48 +21118,48 @@ packages: urix: 0.1.0 dev: true - /source-map-support/0.5.21: + /source-map-support@0.5.21: resolution: {integrity: sha512-uBHU3L3czsIyYXKX88fdrGovxdSCoTGDRZ6SYXtSRxLZUzHg5P/66Ht6uoUlHu9EZod+inXhKo3qQgwXUT/y1w==} dependencies: buffer-from: 1.1.2 source-map: 0.6.1 dev: true - /source-map-url/0.4.1: + /source-map-url@0.4.1: resolution: {integrity: sha512-cPiFOTLUKvJFIg4SKVScy4ilPPW6rFgMgfuZJPNoDuMs3nC1HbMUycBoJw77xFIp6z1UJQJOfx6C9GMH80DiTw==} deprecated: See https://github.com/lydell/source-map-url#deprecated dev: true - /source-map/0.5.7: + /source-map@0.5.7: resolution: {integrity: sha512-LbrmJOMUSdEVxIKvdcJzQC+nQhe8FUZQTXQy6+I75skNgn3OoQ0DZA8YnFa7gp8tqtL3KPf1kmo0R5DoApeSGQ==} engines: {node: '>=0.10.0'} - /source-map/0.6.1: + /source-map@0.6.1: resolution: {integrity: sha512-UjgapumWlbMhkBgzT7Ykc5YXUT46F0iKu8SGXq0bcwP5dz/h0Plj6enJqjz1Zbq2l5WaqYnrVbwWOWMyF3F47g==} engines: {node: '>=0.10.0'} - /source-map/0.7.4: + /source-map@0.7.4: resolution: {integrity: sha512-l3BikUxvPOcn5E74dZiq5BGsTb5yEwhaTSzccU6t4sDOH8NWJCstKO5QT2CvtFoK6F0saL7p9xHAqHOlCPJygA==} engines: {node: '>= 8'} dev: true - /source-map/0.8.0-beta.0: + /source-map@0.8.0-beta.0: resolution: {integrity: sha512-2ymg6oRBpebeZi9UUNsgQ89bhx01TcTkmNTGnNO88imTmbSgy4nfujrgVEFKWpMTEGA11EDkTt7mqObTPdigIA==} engines: {node: '>= 8'} dependencies: whatwg-url: 7.1.0 dev: true - /sourcemap-codec/1.4.8: + /sourcemap-codec@1.4.8: resolution: {integrity: sha512-9NykojV5Uih4lgo5So5dtw+f0JgJX30KCNI8gwhz2J9A15wD0Ml6tjHKwf6fTSa6fAdVBdZeNOs9eJ71qCk8vA==} deprecated: Please use @jridgewell/sourcemap-codec instead dev: true - /space-separated-tokens/1.1.5: + /space-separated-tokens@1.1.5: resolution: {integrity: sha512-q/JSVd1Lptzhf5bkYm4ob4iWPjx0KiRe3sRFBNrVqbJkFaBm5vbbowy1mymoPNLRa52+oadOhJ+K49wsSeSjTA==} dev: true - /spdx-compare/1.0.0: + /spdx-compare@1.0.0: resolution: {integrity: sha512-C1mDZOX0hnu0ep9dfmuoi03+eOdDoz2yvK79RxbcrVEG1NO1Ph35yW102DHWKN4pk80nwCgeMmSY5L25VE4D9A==} dependencies: array-find-index: 1.0.2 @@ -19750,39 +21167,39 @@ packages: spdx-ranges: 2.1.1 dev: true - /spdx-correct/3.2.0: + /spdx-correct@3.2.0: resolution: {integrity: sha512-kN9dJbvnySHULIluDHy32WHRUu3Og7B9sbY7tsFLctQkIqnMh3hErYgdMjTYuqmcXX+lK5T1lnUt3G7zNswmZA==} dependencies: spdx-expression-parse: 3.0.1 spdx-license-ids: 3.0.13 dev: true - /spdx-exceptions/2.3.0: + /spdx-exceptions@2.3.0: resolution: {integrity: sha512-/tTrYOC7PPI1nUAgx34hUpqXuyJG+DTHJTnIULG4rDygi4xu/tfgmq1e1cIRwRzwZgo4NLySi+ricLkZkw4i5A==} dev: true - /spdx-expression-parse/3.0.1: + /spdx-expression-parse@3.0.1: resolution: {integrity: sha512-cbqHunsQWnJNE6KhVSMsMeH5H/L9EpymbzqTQ3uLwNCLZ1Q481oWaofqH7nO6V07xlXwY6PhQdQ2IedWx/ZK4Q==} dependencies: spdx-exceptions: 2.3.0 spdx-license-ids: 3.0.13 dev: true - /spdx-expression-validate/2.0.0: + /spdx-expression-validate@2.0.0: resolution: {integrity: sha512-b3wydZLM+Tc6CFvaRDBOF9d76oGIHNCLYFeHbftFXUWjnfZWganmDmvtM5sm1cRwJc/VDBMLyGGrsLFd1vOxbg==} dependencies: spdx-expression-parse: 3.0.1 dev: true - /spdx-license-ids/3.0.13: + /spdx-license-ids@3.0.13: resolution: {integrity: sha512-XkD+zwiqXHikFZm4AX/7JSCXA98U5Db4AFd5XUg/+9UNtnH75+Z9KxtpYiJZx36mUDVOwH83pl7yvCer6ewM3w==} dev: true - /spdx-ranges/2.1.1: + /spdx-ranges@2.1.1: resolution: {integrity: sha512-mcdpQFV7UDAgLpXEE/jOMqvK4LBoO0uTQg0uvXUewmEFhpiZx5yJSZITHB8w1ZahKdhfZqP5GPEOKLyEq5p8XA==} dev: true - /spdx-satisfies/5.0.1: + /spdx-satisfies@5.0.1: resolution: {integrity: sha512-Nwor6W6gzFp8XX4neaKQ7ChV4wmpSh2sSDemMFSzHxpTw460jxFYeOn+jq4ybnSSw/5sc3pjka9MQPouksQNpw==} dependencies: spdx-compare: 1.0.0 @@ -19790,10 +21207,10 @@ packages: spdx-ranges: 2.1.1 dev: true - /spdy-transport/3.0.0: + /spdy-transport@3.0.0: resolution: {integrity: sha512-hsLVFE5SjA6TCisWeJXFKniGGOpBgMLmerfO2aCyCU5s7nJ/rpAepqmFifv/GCbSbueEeAJJnmSQ2rKC/g8Fcw==} dependencies: - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) detect-node: 2.1.0 hpack.js: 2.1.6 obuf: 1.1.2 @@ -19803,11 +21220,11 @@ packages: - supports-color dev: true - /spdy/4.0.2: + /spdy@4.0.2: resolution: {integrity: sha512-r46gZQZQV+Kl9oItvl1JZZqJKGr+oEkB08A6BzkiR7593/7IbtuncXHd2YoYeTsG4157ZssMu9KYvUHLcjcDoA==} engines: {node: '>=6.0.0'} dependencies: - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) handle-thing: 2.0.1 http-deceiver: 1.2.7 select-hose: 2.0.0 @@ -19816,27 +21233,27 @@ packages: - supports-color dev: true - /split-string/3.1.0: + /split-string@3.1.0: resolution: {integrity: sha512-NzNVhJDYpwceVVii8/Hu6DKfD2G+NrQHlS/V/qgv763EYudVwEcMQNxd2lh+0VrUByXN/oJkl5grOhYWvQUYiw==} engines: {node: '>=0.10.0'} dependencies: extend-shallow: 3.0.2 dev: true - /split2/4.2.0: + /split2@4.2.0: resolution: {integrity: sha512-UcjcJOWknrNkF6PLX83qcHM6KHgVKNkV62Y8a5uYDVv9ydGQVwAHMKqHdJje1VTWpljG0WYpCDhrCdAOYH4TWg==} engines: {node: '>= 10.x'} dev: true - /splitpanes/3.1.5: + /splitpanes@3.1.5: resolution: {integrity: sha512-r3Mq2ITFQ5a2VXLOy4/Sb2Ptp7OfEO8YIbhVJqJXoFc9hc5nTXXkCvtVDjIGbvC0vdE7tse+xTM9BMjsszP6bw==} dev: true - /sprintf-js/1.0.3: + /sprintf-js@1.0.3: resolution: {integrity: sha512-D9cPgkvLlV3t3IzL0D0YLvGA9Ahk4PcvVwUbN0dSGr1aP0Nrt4AEnTUbuGvquEC0mA64Gqt1fzirlRs5ibXx8g==} dev: true - /sshpk/1.17.0: + /sshpk@1.17.0: resolution: {integrity: sha512-/9HIEs1ZXGhSPE8X6Ccm7Nam1z8KcoCqPdI7ecm1N33EzAetWahvQWVqLZtaZQ+IDKX4IyA2o0gBzqIMkAagHQ==} engines: {node: '>=0.10.0'} hasBin: true @@ -19852,48 +21269,48 @@ packages: tweetnacl: 0.14.5 dev: true - /ssim.js/3.5.0: + /ssim.js@3.5.0: resolution: {integrity: sha512-Aj6Jl2z6oDmgYFFbQqK7fght19bXdOxY7Tj03nF+03M9gCBAjeIiO8/PlEGMfKDwYpw4q6iBqVq2YuREorGg/g==} dev: true - /ssri/6.0.2: + /ssri@6.0.2: resolution: {integrity: sha512-cepbSq/neFK7xB6A50KHN0xHDotYzq58wWCa5LeWqnPrHG8GzfEjO/4O8kpmcGW+oaxkvhEJCWgbgNk4/ZV93Q==} dependencies: figgy-pudding: 3.5.2 dev: true - /ssri/8.0.1: + /ssri@8.0.1: resolution: {integrity: sha512-97qShzy1AiyxvPNIkLWoGua7xoQzzPjQ0HAH4B0rWKo7SZ6USuPcrUiAFrws0UH8RrbWmgq3LMTObhPIHbbBeQ==} engines: {node: '>= 8'} dependencies: minipass: 3.3.6 dev: true - /stable/0.1.8: + /stable@0.1.8: resolution: {integrity: sha512-ji9qxRnOVfcuLDySj9qzhGSEFVobyt1kIOSkj1qZzYLzq7Tos/oUUWvotUPQLlrsidqsK6tBH89Bc9kL5zHA6w==} deprecated: 'Modern JS already guarantees Array#sort() is a stable sort, so this library is deprecated. See the compatibility table on MDN: https://developer.mozilla.org/en-US/docs/Web/JavaScript/Reference/Global_Objects/Array/sort#browser_compatibility' dev: true - /stack-utils/2.0.6: + /stack-utils@2.0.6: resolution: {integrity: sha512-XlkWvfIm6RmsWtNJx+uqtKLS8eqFbxUg0ZzLXqY0caEy9l7hruX8IpiDnjsLavoBgqCCR71TqWO8MaXYheJ3RQ==} engines: {node: '>=10'} dependencies: escape-string-regexp: 2.0.0 dev: true - /stackback/0.0.2: + /stackback@0.0.2: resolution: {integrity: sha512-1XMJE5fQo1jGH6Y/7ebnwPOBEkIEnT4QF32d5R1+VXdXveM0IBMJt8zfaxX1P3QhVwrYe+576+jkANtSS2mBbw==} dev: false - /stackframe/1.3.4: + /stackframe@1.3.4: resolution: {integrity: sha512-oeVtt7eWQS+Na6F//S4kJ2K2VbRlS9D43mAlMyVpVWovy9o+jfgH8O9agzANzaiLjclA0oYzUXEM4PurhSUChw==} dev: true - /state-toggle/1.0.3: + /state-toggle@1.0.3: resolution: {integrity: sha512-d/5Z4/2iiCnHw6Xzghyhb+GcmF89bxwgXG60wjIiZaxnymbyOmI8Hk4VqHXiVVp6u2ysaskFfXg3ekCj4WNftQ==} dev: true - /static-extend/0.1.2: + /static-extend@0.1.2: resolution: {integrity: sha512-72E9+uLc27Mt718pMHt9VMNiAL4LMsmDbBva8mxWUCkT07fSzEGMYUCk0XWY6lp0j6RBAG4cJ3mWuZv2OE3s0g==} engines: {node: '>=0.10.0'} dependencies: @@ -19901,41 +21318,41 @@ packages: object-copy: 0.1.0 dev: true - /statuses/2.0.1: + /statuses@2.0.1: resolution: {integrity: sha512-RwNA9Z/7PrK06rYLIzFMlaF+l73iwpzsqRIFgbMLbTcLD6cOao82TaWefPXQvB2fOC4AjuYSEndS7N/mTCbkdQ==} engines: {node: '>= 0.8'} dev: true - /std-env/3.3.3: + /std-env@3.3.3: resolution: {integrity: sha512-Rz6yejtVyWnVjC1RFvNmYL10kgjC49EOghxWn0RFqlCHGFpQx+Xe7yW3I4ceK1SGrWIGMjD5Kbue8W/udkbMJg==} dev: false - /stop-iteration-iterator/1.0.0: + /stop-iteration-iterator@1.0.0: resolution: {integrity: sha512-iCGQj+0l0HOdZ2AEeBADlsRC+vsnDsZsbdSiH1yNSjcfKM7fdpCMfqAL/dwF5BLiw/XhRft/Wax6zQbhq2BcjQ==} engines: {node: '>= 0.4'} dependencies: internal-slot: 1.0.5 dev: true - /store2/2.14.2: + /store2@2.14.2: resolution: {integrity: sha512-siT1RiqlfQnGqgT/YzXVUNsom9S0H1OX+dpdGN1xkyYATo4I6sep5NmsRD/40s3IIOvlCq6akxkqG82urIZW1w==} dev: true - /stream-browserify/2.0.2: + /stream-browserify@2.0.2: resolution: {integrity: sha512-nX6hmklHs/gr2FuxYDltq8fJA1GDlxKQCz8O/IM4atRqBH8OORmBNgfvW5gG10GT/qQ9u0CzIvr2X5Pkt6ntqg==} dependencies: inherits: 2.0.4 readable-stream: 2.3.8 dev: true - /stream-each/1.2.3: + /stream-each@1.2.3: resolution: {integrity: sha512-vlMC2f8I2u/bZGqkdfLQW/13Zihpej/7PmSiMQsbYddxuTsJp8vRe2x2FvVExZg7FaOds43ROAuFJwPR4MTZLw==} dependencies: end-of-stream: 1.4.4 stream-shift: 1.0.1 dev: true - /stream-http/2.8.3: + /stream-http@2.8.3: resolution: {integrity: sha512-+TSkfINHDo4J+ZobQLWiMouQYB+UVYFttRA94FpEzzJ7ZdqcL4uUUQ7WkdkI4DSozGmgBUE/a47L+38PenXhUw==} dependencies: builtin-status-codes: 3.0.0 @@ -19945,38 +21362,46 @@ packages: xtend: 4.0.2 dev: true - /stream-shift/1.0.1: + /stream-shift@1.0.1: resolution: {integrity: sha512-AiisoFqQ0vbGcZgQPY1cdP2I76glaVA/RauYR4G4thNFgkTqr90yXTo4LYX60Jl+sIlPNHHdGSwo01AvbKUSVQ==} dev: true - /streamsearch/1.1.0: + /streamsearch@1.1.0: resolution: {integrity: sha512-Mcc5wHehp9aXz1ax6bZUyY5afg9u2rv5cqQI3mRrYkGC8rW2hM02jWuwjtL++LS5qinSyhj2QfLyNsuc+VsExg==} engines: {node: '>=10.0.0'} dev: true - /streamx/2.15.0: + /streamx@2.15.0: resolution: {integrity: sha512-HcxY6ncGjjklGs1xsP1aR71INYcsXFJet5CU1CHqihQ2J5nOsbd4OjgjHO42w/4QNv9gZb3BueV+Vxok5pLEXg==} dependencies: fast-fifo: 1.3.0 queue-tick: 1.0.1 dev: true - /strict-event-emitter/0.2.8: + /strict-event-emitter@0.2.8: resolution: {integrity: sha512-KDf/ujU8Zud3YaLtMCcTI4xkZlZVIYxTLr+XIULexP+77EEVWixeXroLUXQXiVtH4XH2W7jr/3PT1v3zBuvc3A==} dependencies: events: 3.3.0 dev: true - /strict-event-emitter/0.4.6: + /strict-event-emitter@0.4.6: resolution: {integrity: sha512-12KWeb+wixJohmnwNFerbyiBrAlq5qJLwIt38etRtKtmmHyDSoGlIqFE9wx+4IwG0aDjI7GV8tc8ZccjWZZtTg==} dev: true - /string-argv/0.3.2: + /string-argv@0.3.2: resolution: {integrity: sha512-aqD2Q0144Z+/RqG52NeHEkZauTAUWJO8c6yTftGJKO3Tja5tUgIfmIl6kExvhtxSDP7fXB6DvzkfMpCd/F3G+Q==} engines: {node: '>=0.6.19'} dev: true - /string-width/4.2.3: + /string-length@4.0.2: + resolution: {integrity: sha512-+l6rNN5fYHNhZZy41RXsYptCjA2Igmq4EG7kZAYFQI1E1VTXarr6ZPXBg6eq7Y6eK4FEhY6AJlyuFIb/v/S0VQ==} + engines: {node: '>=10'} + dependencies: + char-regex: 1.0.2 + strip-ansi: 6.0.1 + dev: true + + /string-width@4.2.3: resolution: {integrity: sha512-wKyQRQpjJ0sIp62ErSZdGsjMJWsap5oRNihHhu6G7JVO/9jIB6UyevL+tXuOqrng8j/cxKTWyWUwvSTriiZz/g==} engines: {node: '>=8'} dependencies: @@ -19985,7 +21410,7 @@ packages: strip-ansi: 6.0.1 dev: true - /string-width/5.1.2: + /string-width@5.1.2: resolution: {integrity: sha512-HnLOCR3vjcY8beoNLtcjZ5/nxn2afmME6lhrDrebokqMap+XbeW8n9TXpPDOqdGK5qcI3oT0GKTW6wC7EMiVqA==} engines: {node: '>=12'} dependencies: @@ -19994,7 +21419,7 @@ packages: strip-ansi: 7.1.0 dev: true - /string.prototype.matchall/4.0.8: + /string.prototype.matchall@4.0.8: resolution: {integrity: sha512-6zOCOcJ+RJAQshcTvXPHoxoQGONa3e/Lqx90wUA+wEzX78sg5Bo+1tQo4N0pohS0erG9qtCqJDjNCQBjeWVxyg==} dependencies: call-bind: 1.0.2 @@ -20007,7 +21432,7 @@ packages: side-channel: 1.0.4 dev: true - /string.prototype.padend/3.1.4: + /string.prototype.padend@3.1.4: resolution: {integrity: sha512-67otBXoksdjsnXXRUq+KMVTdlVRZ2af422Y0aTyTjVaoQkGr3mxl2Bc5emi7dOQ3OGVVQQskmLEWwFXwommpNw==} engines: {node: '>= 0.4'} dependencies: @@ -20016,7 +21441,7 @@ packages: es-abstract: 1.21.2 dev: true - /string.prototype.padstart/3.1.4: + /string.prototype.padstart@3.1.4: resolution: {integrity: sha512-XqOHj8horGsF+zwxraBvMTkBFM28sS/jHBJajh17JtJKA92qazidiQbLosV4UA18azvLOVKYo/E3g3T9Y5826w==} engines: {node: '>= 0.4'} dependencies: @@ -20025,7 +21450,7 @@ packages: es-abstract: 1.21.2 dev: true - /string.prototype.trim/1.2.7: + /string.prototype.trim@1.2.7: resolution: {integrity: sha512-p6TmeT1T3411M8Cgg9wBTMRtY2q9+PNy9EV1i2lIXUN/btt763oIfxwN3RR8VU6wHX8j/1CFy0L+YuThm6bgOg==} engines: {node: '>= 0.4'} dependencies: @@ -20034,7 +21459,7 @@ packages: es-abstract: 1.21.2 dev: true - /string.prototype.trimend/1.0.6: + /string.prototype.trimend@1.0.6: resolution: {integrity: sha512-JySq+4mrPf9EsDBEDYMOb/lM7XQLulwg5R/m1r0PXEFqrV0qHvl58sdTilSXtKOflCsK2E8jxf+GKC0T07RWwQ==} dependencies: call-bind: 1.0.2 @@ -20042,7 +21467,7 @@ packages: es-abstract: 1.21.2 dev: true - /string.prototype.trimstart/1.0.6: + /string.prototype.trimstart@1.0.6: resolution: {integrity: sha512-omqjMDaY92pbn5HOX7f9IccLA+U1tA9GvtU4JrodiXFfYB7jPzzHpRzpglLAjtUV6bB557zwClJezTqnAiYnQA==} dependencies: call-bind: 1.0.2 @@ -20050,19 +21475,19 @@ packages: es-abstract: 1.21.2 dev: true - /string_decoder/1.1.1: + /string_decoder@1.1.1: resolution: {integrity: sha512-n/ShnvDi6FHbbVfviro+WojiFzv+s8MPMHBczVePfUpDJLwoLT0ht1l4YwBCbi8pJAveEEdnkHyPyTP/mzRfwg==} dependencies: safe-buffer: 5.1.2 dev: true - /string_decoder/1.3.0: + /string_decoder@1.3.0: resolution: {integrity: sha512-hkRX8U1WjJFd8LsDJ2yQ/wWWxaopEsABU1XfkM8A+j0+85JAGppt16cr1Whg6KIbb4okU6Mql6BOj+uup/wKeA==} dependencies: safe-buffer: 5.2.1 dev: true - /stringify-object/3.3.0: + /stringify-object@3.3.0: resolution: {integrity: sha512-rHqiFh1elqCQ9WPLIC8I0Q/g/wj5J1eMkyoiD6eoQApWHP0FtlK7rqnhmabL5VUY9JQCcqwwvlOaSuutekgyrw==} engines: {node: '>=4'} dependencies: @@ -20071,28 +21496,28 @@ packages: is-regexp: 1.0.0 dev: true - /strip-ansi/3.0.1: + /strip-ansi@3.0.1: resolution: {integrity: sha512-VhumSSbBqDTP8p2ZLKj40UjBCV4+v8bUSEpUb4KjRgWk9pbqGF4REFj6KEagidb2f/M6AzC0EmFyDNGaw9OCzg==} engines: {node: '>=0.10.0'} dependencies: ansi-regex: 2.1.1 dev: true - /strip-ansi/6.0.1: + /strip-ansi@6.0.1: resolution: {integrity: sha512-Y38VPSHcqkFrCpFnQ9vuSXmquuv5oXOKpGeT6aGrr3o3Gc9AlVa6JBfUSOCnbxGGZF+/0ooI7KrPuUSztUdU5A==} engines: {node: '>=8'} dependencies: ansi-regex: 5.0.1 dev: true - /strip-ansi/7.1.0: + /strip-ansi@7.1.0: resolution: {integrity: sha512-iq6eVVI64nQQTRYq2KtEg2d2uU7LElhTJwsH4YzIHZshxlgZms/wIc4VoDQTlG/IvVIrBKG06CrZnp0qv7hkcQ==} engines: {node: '>=12'} dependencies: ansi-regex: 6.0.1 dev: true - /strip-bom/2.0.0: + /strip-bom@2.0.0: resolution: {integrity: sha512-kwrX1y7czp1E69n2ajbG65mIo9dqvJ+8aBQXOGVxqwvNbsXdFM6Lq37dLAY3mknUwru8CfcCbfOLL/gMo+fi3g==} engines: {node: '>=0.10.0'} dependencies: @@ -20100,32 +21525,37 @@ packages: dev: true optional: true - /strip-bom/3.0.0: + /strip-bom@3.0.0: resolution: {integrity: sha512-vavAMRXOgBVNF6nyEEmL3DBK19iRpDcoIwW+swQ+CbGiu7lju6t+JklA1MHweoWtadgt4ISVUsXLyDq34ddcwA==} engines: {node: '>=4'} dev: true - /strip-comments/2.0.1: + /strip-bom@4.0.0: + resolution: {integrity: sha512-3xurFv5tEgii33Zi8Jtp55wEIILR9eh34FAW00PZf+JnSsTmV/ioewSgQl97JHvgjoRGwPShsWm+IdrxB35d0w==} + engines: {node: '>=8'} + dev: true + + /strip-comments@2.0.1: resolution: {integrity: sha512-ZprKx+bBLXv067WTCALv8SSz5l2+XhpYCsVtSqlMnkAXMWDq+/ekVbl1ghqP9rUHTzv6sm/DwCOiYutU/yp1fw==} engines: {node: '>=10'} dev: true - /strip-eof/1.0.0: + /strip-eof@1.0.0: resolution: {integrity: sha512-7FCwGGmx8mD5xQd3RPUvnSpUXHM3BWuzjtpD4TXsfcZ9EL4azvVVUscFYwD9nx8Kh+uCBC00XBtAykoMHwTh8Q==} engines: {node: '>=0.10.0'} dev: true - /strip-final-newline/2.0.0: + /strip-final-newline@2.0.0: resolution: {integrity: sha512-BrpvfNAE3dcvq7ll3xVumzjKjZQ5tI1sEUIKr3Uoks0XUl45St3FlatVqef9prk4jRDzhW6WZg+3bk93y6pLjA==} engines: {node: '>=6'} dev: true - /strip-final-newline/3.0.0: + /strip-final-newline@3.0.0: resolution: {integrity: sha512-dOESqjYr96iWYylGObzd39EuNTa5VJxyvVAEm5Jnh7KGo75V43Hk1odPQkNDyXNmUR6k+gEiDVXnjB8HJ3crXw==} engines: {node: '>=12'} dev: true - /strip-indent/1.0.1: + /strip-indent@1.0.1: resolution: {integrity: sha512-I5iQq6aFMM62fBEAIB/hXzwJD6EEZ0xEGCX2t7oXqaKPIRgt4WruAQ285BISgdkP+HLGWyeGmNJcpIwFeRYRUA==} engines: {node: '>=0.10.0'} hasBin: true @@ -20134,36 +21564,36 @@ packages: dev: true optional: true - /strip-indent/3.0.0: + /strip-indent@3.0.0: resolution: {integrity: sha512-laJTa3Jb+VQpaC6DseHhF7dXVqHTfJPCRDaEbid/drOhgitgYku/letMUqOXFoWV0zIIUbjpdH2t+tYj4bQMRQ==} engines: {node: '>=8'} dependencies: min-indent: 1.0.1 dev: true - /strip-indent/4.0.0: + /strip-indent@4.0.0: resolution: {integrity: sha512-mnVSV2l+Zv6BLpSD/8V87CW/y9EmmbYzGCIavsnsI6/nwn26DwffM/yztm30Z/I2DY9wdS3vXVCMnHDgZaVNoA==} engines: {node: '>=12'} dependencies: min-indent: 1.0.1 dev: true - /strip-json-comments/2.0.1: + /strip-json-comments@2.0.1: resolution: {integrity: sha512-4gB8na07fecVVkOI6Rs4e7T6NOTki5EmL7TUduTs6bu3EdnSycntVJ4re8kgZA+wx9IueI2Y11bfbgwtzuE0KQ==} engines: {node: '>=0.10.0'} dev: true - /strip-json-comments/3.1.1: + /strip-json-comments@3.1.1: resolution: {integrity: sha512-6fPc+R4ihwqP6N/aIv2f1gMH8lOVtWQHoqC4yK6oSDVVocumAsfCqjkXnqiYMhmMwS/mEHLp7Vehlt3ql6lEig==} engines: {node: '>=8'} dev: true - /strip-literal/1.0.1: + /strip-literal@1.0.1: resolution: {integrity: sha512-QZTsipNpa2Ppr6v1AmJHESqJ3Uz247MUS0OjrnnZjFAvEoWqxuyFuXn2xLgMtRnijJShAa1HL0gtJyUs7u7n3Q==} dependencies: acorn: 8.10.0 - /style-loader/1.3.0_webpack@4.46.0: + /style-loader@1.3.0(webpack@4.46.0): resolution: {integrity: sha512-V7TCORko8rs9rIqkSrlMfkqA63DfoGBBJmK1kKGCcSi+BWb4cqz0SRsnp4l6rU5iwOEd0/2ePv68SV22VXon4Q==} engines: {node: '>= 8.9.0'} peerDependencies: @@ -20174,13 +21604,13 @@ packages: webpack: 4.46.0 dev: true - /style-to-object/0.3.0: + /style-to-object@0.3.0: resolution: {integrity: sha512-CzFnRRXhzWIdItT3OmF8SQfWyahHhjq3HwcMNCNLn+N7klOOqPjMeG/4JSu77D7ypZdGvSzvkrbyeTMizz2VrA==} dependencies: inline-style-parser: 0.1.1 dev: true - /styled-jsx/5.0.1_react@18.0.0: + /styled-jsx@5.0.1(@babel/core@7.22.8)(react@18.0.0): resolution: {integrity: sha512-+PIZ/6Uk40mphiQJJI1202b+/dYeTVd9ZnMPR80pgiWbjIwvN2zIp4r9et0BgqBuShh48I0gttPlAXA7WVvBxw==} engines: {node: '>= 12.0.0'} peerDependencies: @@ -20193,14 +21623,15 @@ packages: babel-plugin-macros: optional: true dependencies: + '@babel/core': 7.22.8 react: 18.0.0 dev: false - /stylis/4.2.0: + /stylis@4.2.0: resolution: {integrity: sha512-Orov6g6BB1sDfYgzWfTHDOxamtX1bE/zo104Dh9e6fqJ3PooipYyfJ0pUmrZO2wAvO8YbEyeFrkV91XTsGMSrw==} dev: false - /sucrase/3.32.0: + /sucrase@3.32.0: resolution: {integrity: sha512-ydQOU34rpSyj2TGyz4D2p8rbktIOZ8QY9s+DGLvFU1i5pWJE8vkpruCjGCMHsdXwnD7JDcS+noSwM/a7zyNFDQ==} engines: {node: '>=8'} hasBin: true @@ -20214,13 +21645,13 @@ packages: ts-interface-checker: 0.1.13 dev: true - /superagent/8.0.9: + /superagent@8.0.9: resolution: {integrity: sha512-4C7Bh5pyHTvU33KpZgwrNKh/VQnvgtCSqPRfJAUdmrtSYePVzVg4E4OzsrbkhJj9O7SO6Bnv75K/F8XVZT8YHA==} engines: {node: '>=6.4.0 <13 || >=14'} dependencies: component-emitter: 1.3.0 cookiejar: 2.1.4 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) fast-safe-stringify: 2.1.1 form-data: 4.0.0 formidable: 2.1.2 @@ -20232,7 +21663,7 @@ packages: - supports-color dev: true - /supertest/6.2.4: + /supertest@6.2.4: resolution: {integrity: sha512-M8xVnCNv+q2T2WXVzxDECvL2695Uv2uUj2O0utxsld/HRyJvOU8W9f1gvsYxSNU4wmIe0/L/ItnpU4iKq0emDA==} engines: {node: '>=6.4.0'} dependencies: @@ -20242,35 +21673,42 @@ packages: - supports-color dev: true - /supports-color/2.0.0: + /supports-color@2.0.0: resolution: {integrity: sha512-KKNVtd6pCYgPIKU4cp2733HWYCpplQhddZLBUryaAHou723x+FRzQ5Df824Fj+IyyuiQTRoub4SnIFfIcrp70g==} engines: {node: '>=0.8.0'} dev: true - /supports-color/5.5.0: + /supports-color@5.5.0: resolution: {integrity: sha512-QjVjwdXIt408MIiAqCX4oUKsgU2EqAGzs2Ppkm4aQYbjm+ZEWEcW4SfFNTr4uMNZma0ey4f5lgLrkB0aX0QMow==} engines: {node: '>=4'} dependencies: has-flag: 3.0.0 - /supports-color/7.2.0: + /supports-color@7.2.0: resolution: {integrity: sha512-qpCAvRl9stuOHveKsn7HncJRvv501qIacKzQlO/+Lwxc9+0q2wLyv4Dfvt80/DPn2pqOBsJdDiogXGR9+OvwRw==} engines: {node: '>=8'} dependencies: has-flag: 4.0.0 - /supports-color/8.1.1: + /supports-color@8.1.1: resolution: {integrity: sha512-MpUEN2OodtUzxvKQl72cUF7RQ5EiHsGvSsVG0ia9c5RbWGL2CI4C7EpPS8UTBIplnlzZiNuV56w+FuNxy3ty2Q==} engines: {node: '>=10'} dependencies: has-flag: 4.0.0 + + /supports-hyperlinks@2.3.0: + resolution: {integrity: sha512-RpsAZlpWcDwOPQA22aCH4J0t7L8JmAvsCxfOSEwm7cQs3LshN36QaTkwd70DnBOXDWGssw2eUoc8CaRWT0XunA==} + engines: {node: '>=8'} + dependencies: + has-flag: 4.0.0 + supports-color: 7.2.0 dev: true - /supports-preserve-symlinks-flag/1.0.0: + /supports-preserve-symlinks-flag@1.0.0: resolution: {integrity: sha512-ot0WnXS9fgdkgIcePe6RHNk1WA8+muPa6cSjeR3V8K27q9BB1rTE3R1p7Hv0z1ZyAc8s6Vvv8DIyWf681MAt0w==} engines: {node: '>= 0.4'} - /svelte-check/3.4.6_svelte@3.59.2: + /svelte-check@3.4.6(svelte@3.59.2): resolution: {integrity: sha512-OBlY8866Zh1zHQTkBMPS6psPi7o2umTUyj6JWm4SacnIHXpWFm658pG32m3dKvKFL49V4ntAkfFHKo4ztH07og==} hasBin: true peerDependencies: @@ -20283,7 +21721,7 @@ packages: picocolors: 1.0.0 sade: 1.8.1 svelte: 3.59.2 - svelte-preprocess: 5.0.4_vskbpfd7qchoojf5wqdzq623ya + svelte-preprocess: 5.0.4(svelte@3.59.2)(typescript@5.1.6) typescript: 5.1.6 transitivePeerDependencies: - '@babel/core' @@ -20297,7 +21735,7 @@ packages: - sugarss dev: true - /svelte-hmr/0.15.2_svelte@3.59.2: + /svelte-hmr@0.15.2(svelte@3.59.2): resolution: {integrity: sha512-q/bAruCvFLwvNbeE1x3n37TYFb3mTBJ6TrCq6p2CoFbSTNhDE9oAtEfpy+wmc9So8AG0Tja+X0/mJzX9tSfvIg==} engines: {node: ^12.20 || ^14.13.1 || >= 16} peerDependencies: @@ -20306,7 +21744,7 @@ packages: svelte: 3.59.2 dev: true - /svelte-hmr/0.15.2_svelte@4.0.5: + /svelte-hmr@0.15.2(svelte@4.0.5): resolution: {integrity: sha512-q/bAruCvFLwvNbeE1x3n37TYFb3mTBJ6TrCq6p2CoFbSTNhDE9oAtEfpy+wmc9So8AG0Tja+X0/mJzX9tSfvIg==} engines: {node: ^12.20 || ^14.13.1 || >= 16} peerDependencies: @@ -20315,7 +21753,7 @@ packages: svelte: 4.0.5 dev: true - /svelte-preprocess/5.0.4_vskbpfd7qchoojf5wqdzq623ya: + /svelte-preprocess@5.0.4(svelte@3.59.2)(typescript@5.1.6): resolution: {integrity: sha512-ABia2QegosxOGsVlsSBJvoWeXy1wUKSfF7SWJdTjLAbx/Y3SrVevvvbFNQqrSJw89+lNSsM58SipmZJ5SRi5iw==} engines: {node: '>= 14.10.0'} requiresBuild: true @@ -20362,12 +21800,12 @@ packages: typescript: 5.1.6 dev: true - /svelte/3.59.2: + /svelte@3.59.2: resolution: {integrity: sha512-vzSyuGr3eEoAtT/A6bmajosJZIUWySzY2CzB3w2pgPvnkUjGqlDnsNnA0PMO+mMAhuyMul6C2uuZzY6ELSkzyA==} engines: {node: '>= 8'} dev: true - /svelte/4.0.5: + /svelte@4.0.5: resolution: {integrity: sha512-PHKPWP1wiWHBtsE57nCb8xiWB3Ht7/3Kvi3jac0XIxUM2rep8alO7YoAtgWeGD7++tFy46krilOrPW0mG3Dx+A==} engines: {node: '>=16'} dependencies: @@ -20386,7 +21824,7 @@ packages: periscopic: 3.1.0 dev: true - /sveltedoc-parser/4.2.1: + /sveltedoc-parser@4.2.1: resolution: {integrity: sha512-sWJRa4qOfRdSORSVw9GhfDEwsbsYsegnDzBevUCF6k/Eis/QqCu9lJ6I0+d/E2wOWCjOhlcJ3+jl/Iur+5mmCw==} engines: {node: '>=10.0.0'} dependencies: @@ -20397,15 +21835,15 @@ packages: - supports-color dev: true - /svg-tags/1.0.0: + /svg-tags@1.0.0: resolution: {integrity: sha512-ovssysQTa+luh7A5Weu3Rta6FJlFBBbInjOh722LIt6klpU2/HtdUbszju/G4devcvk8PGt7FCLv5wftu3THUA==} dev: true - /sweetalert2/11.7.16: + /sweetalert2@11.7.16: resolution: {integrity: sha512-vxqVcA358RWdK/XOG1gFtOzT7qBH186Ry4gnW0Xtrx7vIo1mpnR8hG8MxQms4gz3JPbYQ6UIgZn0+hTK7in3Jw==} dev: true - /swr/1.3.0_react@18.2.0: + /swr@1.3.0(react@18.2.0): resolution: {integrity: sha512-dkghQrOl2ORX9HYrMDtPa7LTVHJjCTeZoB1dqTbnnEDlSvN8JEKpYIYurDfvbQFUUS8Cg8PceFVZNkW0KNNYPw==} peerDependencies: react: ^16.11.0 || ^17.0.0 || ^18.0.0 @@ -20413,16 +21851,16 @@ packages: react: 18.2.0 dev: false - /symbol-observable/4.0.0: + /symbol-observable@4.0.0: resolution: {integrity: sha512-b19dMThMV4HVFynSAM1++gBHAbk2Tc/osgLIBZMKsyqh34jb2e8Os7T6ZW/Bt3pJFdBTd2JwAnAAEQV7rSNvcQ==} engines: {node: '>=0.10'} dev: false - /symbol-tree/3.2.4: + /symbol-tree@3.2.4: resolution: {integrity: sha512-9QNk5KwDF+Bvz+PyObkmSYjI5ksVUYtjW7AU22r2NKcfLJcXp96hkDWU3+XndOsUb+AQ9QhfzfCT2O+CNWT5Tw==} dev: true - /symbol.prototype.description/1.0.5: + /symbol.prototype.description@1.0.5: resolution: {integrity: sha512-x738iXRYsrAt9WBhRCVG5BtIC3B7CUkFwbHW2zOvGtwM33s7JjrCDyq8V0zgMYVb5ymsL8+qkzzpANH63CPQaQ==} engines: {node: '>= 0.11.15'} dependencies: @@ -20432,25 +21870,25 @@ packages: object.getownpropertydescriptors: 2.1.6 dev: true - /synchronous-promise/2.0.17: + /synchronous-promise@2.0.17: resolution: {integrity: sha512-AsS729u2RHUfEra9xJrE39peJcc2stq2+poBXX8bcM08Y6g9j/i/PUzwNQqkaJde7Ntg1TO7bSREbR5sdosQ+g==} dev: true - /tabbable/6.2.0: + /tabbable@6.2.0: resolution: {integrity: sha512-Cat63mxsVJlzYvN51JmVXIgNoUokrIaT2zLclCXjRd8boZ0004U4KCs/sToJ75C6sdlByWxpYnb5Boif1VSFew==} dev: true - /tapable/1.1.3: + /tapable@1.1.3: resolution: {integrity: sha512-4WK/bYZmj8xLr+HUCODHGF1ZFzsYffasLUgEiMBY4fgtltdO6B4WJtlSbPaDTLpYTcGVwM2qLnFTICEcNxs3kA==} engines: {node: '>=6'} dev: true - /tapable/2.2.1: + /tapable@2.2.1: resolution: {integrity: sha512-GNzQvQTOIP6RyTfE2Qxb8ZVlNmw0n88vp1szwWRimP02mnTsx3Wtn5qRdqY9w2XduFNUgvOwhNnQsjwCp+kqaQ==} engines: {node: '>=6'} dev: true - /tar-fs/2.1.1: + /tar-fs@2.1.1: resolution: {integrity: sha512-V0r2Y9scmbDRLCNex/+hYzvp/zyYjvFbHPNgVTKfQvVrb6guiE/fxP+XblDNR011utopbkex2nM4dHNV6GDsng==} dependencies: chownr: 1.1.4 @@ -20459,7 +21897,7 @@ packages: tar-stream: 2.2.0 dev: true - /tar-fs/3.0.4: + /tar-fs@3.0.4: resolution: {integrity: sha512-5AFQU8b9qLfZCX9zp2duONhPmZv0hGYiBPJsyUdqMjzq/mqVpy/rEUSeHk1+YitmxugaptgBh5oDGU3VsAJq4w==} dependencies: mkdirp-classic: 0.5.3 @@ -20467,7 +21905,7 @@ packages: tar-stream: 3.1.6 dev: true - /tar-stream/2.2.0: + /tar-stream@2.2.0: resolution: {integrity: sha512-ujeqbceABgwMZxEJnk2HDY2DlnUZ+9oEcb1KzTVfYHio0UE6dG71n60d8D2I4qNvleWrrXpmjpt7vZeF1LnMZQ==} engines: {node: '>=6'} dependencies: @@ -20478,7 +21916,7 @@ packages: readable-stream: 3.6.2 dev: true - /tar-stream/3.1.6: + /tar-stream@3.1.6: resolution: {integrity: sha512-B/UyjYwPpMBv+PaFSWAmtYjwdrlEaZQEhMIBFNC5oEG8lpiW8XjcSdmEaClj28ArfKScKHs2nshz3k2le6crsg==} dependencies: b4a: 1.6.4 @@ -20486,7 +21924,7 @@ packages: streamx: 2.15.0 dev: true - /tar/6.1.15: + /tar@6.1.15: resolution: {integrity: sha512-/zKt9UyngnxIT/EAGYuxaMYgOIJiP81ab9ZfkILq4oNLPFX50qyYmu7jRj9qeXoxmJHjGlbH0+cm2uy1WCs10A==} engines: {node: '>=10'} dependencies: @@ -20498,7 +21936,7 @@ packages: yallist: 4.0.0 dev: true - /telejson/6.0.8: + /telejson@6.0.8: resolution: {integrity: sha512-nerNXi+j8NK1QEfBHtZUN/aLdDcyupA//9kAboYLrtzZlPLpUfqbVGWb9zz91f/mIjRbAYhbgtnJHY8I1b5MBg==} dependencies: '@types/is-function': 1.0.1 @@ -20511,18 +21949,18 @@ packages: memoizerific: 1.11.3 dev: true - /telejson/7.1.0: + /telejson@7.1.0: resolution: {integrity: sha512-jFJO4P5gPebZAERPkJsqMAQ0IMA1Hi0AoSfxpnUaV6j6R2SZqlpkbS20U6dEUtA3RUYt2Ak/mTlkQzHH9Rv/hA==} dependencies: memoizerific: 1.11.3 dev: true - /temp-dir/2.0.0: + /temp-dir@2.0.0: resolution: {integrity: sha512-aoBAniQmmwtcKp/7BzsH8Cxzv8OL736p7v1ihGb5e9DJ9kTwGWHrQrVB5+lfVDzfGrdRzXch+ig7LHaY1JTOrg==} engines: {node: '>=8'} dev: true - /tempy/0.6.0: + /tempy@0.6.0: resolution: {integrity: sha512-G13vtMYPT/J8A4X2SjdtBTphZlrp1gKv6hZiOjw14RCWg6GbHuQBGtjlx75xLbYV/wEc0D7G5K4rxKP/cXk8Bw==} engines: {node: '>=10'} dependencies: @@ -20532,7 +21970,15 @@ packages: unique-string: 2.0.0 dev: true - /terser-webpack-plugin/1.4.5_webpack@4.46.0: + /terminal-link@2.1.1: + resolution: {integrity: sha512-un0FmiRUQNr5PJqy9kP7c40F5BOfpGlYTrxonDChEZB7pzZxRNp/bt+ymiy9/npwXya9KH99nJ/GXFIiUkYGFQ==} + engines: {node: '>=8'} + dependencies: + ansi-escapes: 4.3.2 + supports-hyperlinks: 2.3.0 + dev: true + + /terser-webpack-plugin@1.4.5(webpack@4.46.0): resolution: {integrity: sha512-04Rfe496lN8EYruwi6oPQkG0vo8C+HT49X687FZnpPF0qMAIHONI6HEXYPKDOE8e5HjXTyKfqRd/agHtH0kOtw==} engines: {node: '>= 6.9.0'} peerDependencies: @@ -20550,7 +21996,7 @@ packages: worker-farm: 1.7.0 dev: true - /terser-webpack-plugin/4.2.3_webpack@4.46.0: + /terser-webpack-plugin@4.2.3(webpack@4.46.0): resolution: {integrity: sha512-jTgXh40RnvOrLQNgIkwEKnQ8rmHjHK4u+6UBEi+W+FPmvb+uo+chJXntKe7/3lW5mNysgSWD60KyesnhW8D6MQ==} engines: {node: '>= 10.13.0'} peerDependencies: @@ -20570,7 +22016,7 @@ packages: - bluebird dev: true - /terser-webpack-plugin/5.3.9_webpack@5.88.1: + /terser-webpack-plugin@5.3.9(esbuild@0.18.11)(webpack@5.88.1): resolution: {integrity: sha512-ZuXsqE07EcggTWQjXUj+Aot/OMcD0bMKGgF63f7UxYcu5/AJF53aIpK1YoP5xR9l6s/Hy2b+t1AM0bLNPRuhwA==} engines: {node: '>= 10.13.0'} peerDependencies: @@ -20587,14 +22033,15 @@ packages: optional: true dependencies: '@jridgewell/trace-mapping': 0.3.18 + esbuild: 0.18.11 jest-worker: 27.5.1 schema-utils: 3.3.0 serialize-javascript: 6.0.1 terser: 5.19.0 - webpack: 5.88.1 + webpack: 5.88.1(esbuild@0.18.11) dev: true - /terser/4.8.1: + /terser@4.8.1: resolution: {integrity: sha512-4GnLC0x667eJG0ewJTa6z/yXrbLGv80D9Ru6HIpCQmO+Q4PfEtBFi0ObSckqwL6VyQv/7ENJieXHo2ANmdQwgw==} engines: {node: '>=6.0.0'} hasBin: true @@ -20605,7 +22052,7 @@ packages: source-map-support: 0.5.21 dev: true - /terser/5.19.0: + /terser@5.19.0: resolution: {integrity: sha512-JpcpGOQLOXm2jsomozdMDpd5f8ZHh1rR48OFgWUH3QsyZcfPgv2qDCYbcDEAYNd4OZRj2bWYKpwdll/udZCk/Q==} engines: {node: '>=10'} hasBin: true @@ -20616,7 +22063,7 @@ packages: source-map-support: 0.5.21 dev: true - /test-exclude/6.0.0: + /test-exclude@6.0.0: resolution: {integrity: sha512-cAGWPIyOHU6zlmg88jwm7VRyXnMN7iV68OGAbYDk/Mh/xC/pzVPlQtY6ngoIH/5/tciuhGfvESU8GrHrcxD56w==} engines: {node: '>=8'} dependencies: @@ -20624,118 +22071,122 @@ packages: glob: 7.2.3 minimatch: 3.1.2 - /text-table/0.2.0: + /text-table@0.2.0: resolution: {integrity: sha512-N+8UisAXDGk8PFXP4HAzVR9nbfmVJ3zYLAWiTIoqC5v5isinhr+r5uaO8+7r3BMfuNIufIsA7RdpVgacC2cSpw==} dev: true - /thenify-all/1.6.0: + /thenify-all@1.6.0: resolution: {integrity: sha512-RNxQH/qI8/t3thXJDwcstUO4zeqo64+Uy/+sNVRBx4Xn2OX+OZ9oP+iJnNFqplFra2ZUVeKCSa2oVWi3T4uVmA==} engines: {node: '>=0.8'} dependencies: thenify: 3.3.1 dev: true - /thenify/3.3.1: + /thenify@3.3.1: resolution: {integrity: sha512-RVZSIV5IG10Hk3enotrhvz0T9em6cyHBLkH/YAZuKqd8hRkKhSfCGIcP2KUY0EPxndzANBmNllzWPwak+bheSw==} dependencies: any-promise: 1.3.0 dev: true - /thread-stream/2.3.0: + /thread-stream@2.3.0: resolution: {integrity: sha512-kaDqm1DET9pp3NXwR8382WHbnpXnRkN9xGN9dQt3B2+dmXiW8X1SOwmFOxAErEQ47ObhZ96J6yhZNXuyCOL7KA==} dependencies: real-require: 0.2.0 dev: true - /throttleit/1.0.0: - resolution: {integrity: sha512-rkTVqu6IjfQ/6+uNuuc3sZek4CEYxTJom3IktzgdSxcZqdARuebbA/f4QmAxMQIxqq9ZLEUkSYqvuk1I6VKq4g==} + /throat@6.0.2: + resolution: {integrity: sha512-WKexMoJj3vEuK0yFEapj8y64V0A6xcuPuK9Gt1d0R+dzCSJc0lHqQytAbSB4cDAK0dWh4T0E2ETkoLE2WZ41OQ==} dev: true - /through/2.3.8: - resolution: {integrity: sha512-w89qg7PI8wAdvX60bMDP+bFoD5Dvhm9oLheFp5O4a2QF0cSBGsBX4qZmadPMvVqlLJBBci+WqGGOAPvcDeNSVg==} + /throttleit@1.0.0: + resolution: {integrity: sha512-rkTVqu6IjfQ/6+uNuuc3sZek4CEYxTJom3IktzgdSxcZqdARuebbA/f4QmAxMQIxqq9ZLEUkSYqvuk1I6VKq4g==} dev: true - /through2/2.0.5: + /through2@2.0.5: resolution: {integrity: sha512-/mrRod8xqpA+IHSLyGCQ2s8SPHiCDEeQJSep1jqLYeEUClOFG2Qsh+4FU6G9VeqpZnGW/Su8LQGc4YKni5rYSQ==} dependencies: readable-stream: 2.3.8 xtend: 4.0.2 dev: true - /timers-browserify/2.0.12: + /through@2.3.8: + resolution: {integrity: sha512-w89qg7PI8wAdvX60bMDP+bFoD5Dvhm9oLheFp5O4a2QF0cSBGsBX4qZmadPMvVqlLJBBci+WqGGOAPvcDeNSVg==} + dev: true + + /timers-browserify@2.0.12: resolution: {integrity: sha512-9phl76Cqm6FhSX9Xe1ZUAMLtm1BLkKj2Qd5ApyWkXzsMRaA7dgr81kf4wJmQf/hAvg8EEyJxDo3du/0KlhPiKQ==} engines: {node: '>=0.6.0'} dependencies: setimmediate: 1.0.5 dev: true - /tiny-lru/8.0.2: + /tiny-lru@8.0.2: resolution: {integrity: sha512-ApGvZ6vVvTNdsmt676grvCkUCGwzG9IqXma5Z07xJgiC5L7akUMof5U8G2JTI9Rz/ovtVhJBlY6mNhEvtjzOIg==} engines: {node: '>=6'} dev: true - /tinybench/2.5.0: + /tinybench@2.5.0: resolution: {integrity: sha512-kRwSG8Zx4tjF9ZiyH4bhaebu+EDz1BOx9hOigYHlUW4xxI/wKIUQUqo018UlU4ar6ATPBsaMrdbKZ+tmPdohFA==} dev: false - /tinypool/0.7.0: + /tinypool@0.7.0: resolution: {integrity: sha512-zSYNUlYSMhJ6Zdou4cJwo/p7w5nmAH17GRfU/ui3ctvjXFErXXkruT4MWW6poDeXgCaIBlGLrfU6TbTXxyGMww==} engines: {node: '>=14.0.0'} dev: false - /tinyspy/0.3.3: + /tinyspy@0.3.3: resolution: {integrity: sha512-gRiUR8fuhUf0W9lzojPf1N1euJYA30ISebSfgca8z76FOvXtVXqd5ojEIaKLWbDQhAaC3ibxZIjqbyi4ybjcTw==} engines: {node: '>=14.0.0'} dev: false - /tinyspy/1.1.1: + /tinyspy@1.1.1: resolution: {integrity: sha512-UVq5AXt/gQlti7oxoIg5oi/9r0WpF7DGEVwXgqWSMmyN16+e3tl5lIvTaOpJ3TAtu5xFzWccFRM4R5NaWHF+4g==} engines: {node: '>=14.0.0'} dev: true - /tinyspy/2.1.1: + /tinyspy@2.1.1: resolution: {integrity: sha512-XPJL2uSzcOyBMky6OFrusqWlzfFrXtE0hPuMgW8A2HmaqrPo4ZQHRN/V0QXN3FSjKxpsbRrFc5LI7KOwBsT1/w==} engines: {node: '>=14.0.0'} dev: false - /tmp/0.0.33: + /tmp@0.0.33: resolution: {integrity: sha512-jRCJlojKnZ3addtTOjdIqoRuPEKBvNXcGYqzO6zWZX8KfKEpnGY5jfggJQ3EjKuu8D4bJRr0y+cYJFmYbImXGw==} engines: {node: '>=0.6.0'} dependencies: os-tmpdir: 1.0.2 dev: true - /tmp/0.2.1: + /tmp@0.2.1: resolution: {integrity: sha512-76SUhtfqR2Ijn+xllcI5P1oyannHNHByD80W1q447gU3mp9G9PSpGdWmjUOHRDPiHYacIk66W7ubDTuPF3BEtQ==} engines: {node: '>=8.17.0'} dependencies: rimraf: 3.0.2 dev: true - /tmpl/1.0.5: + /tmpl@1.0.5: resolution: {integrity: sha512-3f0uOEAQwIqGuWW2MVzYg8fV/QNnc/IpuJNG837rLuczAaLVHslWHZQj4IGiEl5Hs3kkbhwL9Ab7Hrsmuj+Smw==} dev: true - /to-arraybuffer/1.0.1: + /to-arraybuffer@1.0.1: resolution: {integrity: sha512-okFlQcoGTi4LQBG/PgSYblw9VOyptsz2KJZqc6qtgGdes8VktzUQkj4BI2blit072iS8VODNcMA+tvnS9dnuMA==} dev: true - /to-data-view/1.1.0: + /to-data-view@1.1.0: resolution: {integrity: sha512-1eAdufMg6mwgmlojAx3QeMnzB/BTVp7Tbndi3U7ftcT2zCZadjxkkmLmd97zmaxWi+sgGcgWrokmpEoy0Dn0vQ==} dev: true - /to-fast-properties/2.0.0: + /to-fast-properties@2.0.0: resolution: {integrity: sha512-/OaKK0xYrs3DmxRYqL/yDc+FxFUVYhDlXMhRmv3z915w2HF1tnN1omB354j8VUGO/hbRzyD6Y3sA7v7GS/ceog==} engines: {node: '>=4'} - /to-object-path/0.3.0: + /to-object-path@0.3.0: resolution: {integrity: sha512-9mWHdnGRuh3onocaHzukyvCZhzvr6tiflAy/JRFXcJX0TjgfWA9pk9t8CMbzmBE4Jfw58pXbkngtBtqYxzNEyg==} engines: {node: '>=0.10.0'} dependencies: kind-of: 3.2.2 dev: true - /to-regex-range/2.1.1: + /to-regex-range@2.1.1: resolution: {integrity: sha512-ZZWNfCjUokXXDGXFpZehJIkZqq91BcULFq/Pi7M5i4JnxXdhMKAK682z8bCW3o8Hj1wuuzoKcW3DfVzaP6VuNg==} engines: {node: '>=0.10.0'} dependencies: @@ -20743,13 +22194,13 @@ packages: repeat-string: 1.6.1 dev: true - /to-regex-range/5.0.1: + /to-regex-range@5.0.1: resolution: {integrity: sha512-65P7iz6X5yEr1cwcgvQxbbIw7Uk3gOy5dIdtZ4rDveLqhrdJP+Li/Hx6tyK0NEb+2GCyneCMJiGqrADCSNk8sQ==} engines: {node: '>=8.0'} dependencies: is-number: 7.0.0 - /to-regex/3.0.2: + /to-regex@3.0.2: resolution: {integrity: sha512-FWtleNAtZ/Ki2qtqej2CXTOayOH9bHDQF+Q48VpWyDXjbYxA4Yz8iDB31zXOBUlOHHKidDbqGVrTUvQMPmBGBw==} engines: {node: '>=0.10.0'} dependencies: @@ -20759,16 +22210,16 @@ packages: safe-regex: 1.1.0 dev: true - /toidentifier/1.0.1: + /toidentifier@1.0.1: resolution: {integrity: sha512-o5sSPKEkg/DIQNmH43V0/uerLrpzVedkUh8tGNvaeXpfpuwjKenlSox/2O/BTlZUtEe+JG7s5YhEz608PlAHRA==} engines: {node: '>=0.6'} dev: true - /totalist/3.0.1: + /totalist@3.0.1: resolution: {integrity: sha512-sf4i37nQ2LBx4m3wB74y+ubopq6W/dIzXg0FDGjsYnZHVa1Da8FH853wlL2gtUhg+xJXjfk3kUZS3BRoQeoQBQ==} engines: {node: '>=6'} - /tough-cookie/2.5.0: + /tough-cookie@2.5.0: resolution: {integrity: sha512-nlLsUzgm1kfLXSXfRZMc1KLAugd4hqJHDTvc2hDIwS3mZAfMEuMbc03SujMF+GEcpaX/qboeycw6iO8JwVv2+g==} engines: {node: '>=0.8'} dependencies: @@ -20776,7 +22227,7 @@ packages: punycode: 2.3.0 dev: true - /tough-cookie/4.1.3: + /tough-cookie@4.1.3: resolution: {integrity: sha512-aX/y5pVRkfRnfmuX+OdbSdXvPe6ieKX/G2s7e98f4poJHnqH3281gDPm/metm6E/WRamfx7WC4HUqkWHfQHprw==} engines: {node: '>=6'} dependencies: @@ -20786,70 +22237,77 @@ packages: url-parse: 1.5.10 dev: true - /tr46/0.0.3: + /tr46@0.0.3: resolution: {integrity: sha512-N3WMsuqV66lT30CrXNbEjx4GEwlow3v6rr4mCcv6prnfwhS01rkgyFdjPNBYd9br7LpXV1+Emh01fHnq2Gdgrw==} - /tr46/1.0.1: + /tr46@1.0.1: resolution: {integrity: sha512-dTpowEjclQ7Kgx5SdBkqRzVhERQXov8/l9Ft9dVM9fmg0W0KQSVaXX9T4i6twCPNtYiZM53lpSSUAwJbFPOHxA==} dependencies: punycode: 2.3.0 dev: true - /tr46/3.0.0: + /tr46@2.1.0: + resolution: {integrity: sha512-15Ih7phfcdP5YxqiB+iDtLoaTz4Nd35+IiAv0kQ5FNKHzXgdWqPoTIqEDDJmXceQt4JZk6lVPT8lnDlPpGDppw==} + engines: {node: '>=8'} + dependencies: + punycode: 2.3.0 + dev: true + + /tr46@3.0.0: resolution: {integrity: sha512-l7FvfAHlcmulp8kr+flpQZmVwtu7nfRV7NZujtN0OqES8EL4O4e0qqzL0DC5gAvx/ZC/9lk6rhcUwYvkBnBnYA==} engines: {node: '>=12'} dependencies: punycode: 2.3.0 dev: true - /tr46/4.1.1: + /tr46@4.1.1: resolution: {integrity: sha512-2lv/66T7e5yNyhAAC4NaKe5nVavzuGJQVVtRYLyQ2OI8tsJ61PMLlelehb0wi2Hx6+hT/OJUWZcw8MjlSRnxvw==} engines: {node: '>=14'} dependencies: punycode: 2.3.0 dev: true - /tree-kill/1.2.2: + /tree-kill@1.2.2: resolution: {integrity: sha512-L0Orpi8qGpRG//Nd+H90vFB+3iHnue1zSSGmNOOCh1GLJ7rUKVwV2HvijphGQS2UmhUZewS9VgvxYIdgr+fG1A==} hasBin: true dev: true - /trim-newlines/1.0.0: + /trim-newlines@1.0.0: resolution: {integrity: sha512-Nm4cF79FhSTzrLKGDMi3I4utBtFv8qKy4sq1enftf2gMdpqI8oVQTAfySkTz5r49giVzDj88SVZXP4CeYQwjaw==} engines: {node: '>=0.10.0'} dev: true optional: true - /trim-trailing-lines/1.1.4: + /trim-trailing-lines@1.1.4: resolution: {integrity: sha512-rjUWSqnfTNrjbB9NQWfPMH/xRK1deHeGsHoVfpxJ++XeYXE0d6B1En37AHfw3jtfTU7dzMzZL2jjpe8Qb5gLIQ==} dev: true - /trim/0.0.1: + /trim@0.0.1: resolution: {integrity: sha512-YzQV+TZg4AxpKxaTHK3c3D+kRDCGVEE7LemdlQZoQXn0iennk10RsIoY6ikzAqJTc9Xjl9C1/waHom/J86ziAQ==} deprecated: Use String.prototype.trim() instead dev: true - /trough/1.0.5: + /trough@1.0.5: resolution: {integrity: sha512-rvuRbTarPXmMb79SmzEp8aqXNKcK+y0XaB298IXueQ8I2PsrATcPBCSPyK/dDNa2iWOhKlfNnOjdAOTBU/nkFA==} dev: true - /ts-dedent/2.2.0: + /ts-dedent@2.2.0: resolution: {integrity: sha512-q5W7tVM71e2xjHZTlgfTDoPF/SmqKG5hddq9SzR49CH2hayqRKJtQ4mtRlSxKaJlR/+9rEM+mnBHf7I2/BQcpQ==} engines: {node: '>=6.10'} dev: true - /ts-interface-checker/0.1.13: + /ts-interface-checker@0.1.13: resolution: {integrity: sha512-Y/arvbn+rrz3JCKl9C4kVNfTfSm2/mEp5FSz5EsZSANGPSlQrpRI5M4PKF+mJnE52jOO90PnPSc3Ur3bTQw0gA==} dev: true - /ts-invariant/0.10.3: + /ts-invariant@0.10.3: resolution: {integrity: sha512-uivwYcQaxAucv1CzRp2n/QdYPo4ILf9VXgH19zEIjFx2EJufV16P0JtJVpYHy89DItG6Kwj2oIUjrcK5au+4tQ==} engines: {node: '>=8'} dependencies: tslib: 2.6.0 dev: false - /ts-node/10.9.1_pqdfkuhuhnwv2d7uogwywwxtqq: + /ts-node@10.9.1(@types/node@18.16.19)(typescript@5.1.6): resolution: {integrity: sha512-NtVysVPkxxrwFGUUxGYhfux8k78pQB3JqYBXlLRZgdGUqTO5wU/UyHop5p70iEbGhB7q5KmiZiU0Y3KlJrScEw==} hasBin: true peerDependencies: @@ -20880,7 +22338,7 @@ packages: yn: 3.1.1 dev: true - /ts-pnp/1.2.0_typescript@4.9.5: + /ts-pnp@1.2.0(typescript@4.9.5): resolution: {integrity: sha512-csd+vJOb/gkzvcCHgTGSChYpy5f1/XKNsmvBGO4JXS+z1v2HobugDz4s1IeFXM3wZB44uczs+eazB5Q/ccdhQw==} engines: {node: '>=6'} peerDependencies: @@ -20892,18 +22350,18 @@ packages: typescript: 4.9.5 dev: true - /tslib/1.14.1: + /tslib@1.14.1: resolution: {integrity: sha512-Xni35NKzjgMrwevysHTCArtLDpPvye8zV/0E4EyYn43P7/7qvQwPh9BGkHewbMulVntbigmcT7rdX3BNo9wRJg==} dev: true - /tslib/2.4.0: + /tslib@2.4.0: resolution: {integrity: sha512-d6xOpEDfsi2CZVlPQzGeux8XMwLT9hssAsaPYExaQMuYskwb+x1x7J371tWlbBdWHroy99KnVB6qIkUbs5X3UQ==} dev: false - /tslib/2.6.0: + /tslib@2.6.0: resolution: {integrity: sha512-7At1WUettjcSRHXCyYtTselblcHl9PJFFVKiCAy/bY97+BPZXSQ2wbq0P9s8tK2G7dFQfNnlJnPAiArVBVBsfA==} - /tsup/6.7.0_kg5gpyde6u3komamnnl67a6oc4: + /tsup@6.7.0(ts-node@10.9.1)(typescript@5.1.6): resolution: {integrity: sha512-L3o8hGkaHnu5TdJns+mCqFsDBo83bJ44rlK7e6VdanIvpea4ArPcU3swWGsLVbXak1PqQx/V+SSmFPujBK+zEQ==} engines: {node: '>=14.18'} hasBin: true @@ -20919,15 +22377,15 @@ packages: typescript: optional: true dependencies: - bundle-require: 4.0.1_esbuild@0.17.19 + bundle-require: 4.0.1(esbuild@0.17.19) cac: 6.7.14 chokidar: 3.5.3 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) esbuild: 0.17.19 execa: 5.1.1 globby: 11.1.0 joycon: 3.1.1 - postcss-load-config: 3.1.4_ts-node@10.9.1 + postcss-load-config: 3.1.4(ts-node@10.9.1) resolve-from: 5.0.0 rollup: 3.26.2 source-map: 0.8.0-beta.0 @@ -20939,7 +22397,7 @@ packages: - ts-node dev: true - /tsutils/3.21.0_typescript@5.1.6: + /tsutils@3.21.0(typescript@5.1.6): resolution: {integrity: sha512-mHKK3iUXL+3UF6xL5k0PEhKRUBKPBCv/+RkEOpjRWxxx27KKRBmmA60A9pgOUvMi8GKhRMPEmjBRPzs2W7O1OA==} engines: {node: '>= 6'} peerDependencies: @@ -20949,7 +22407,7 @@ packages: typescript: 5.1.6 dev: true - /tsx/3.12.7: + /tsx@3.12.7: resolution: {integrity: sha512-C2Ip+jPmqKd1GWVQDvz/Eyc6QJbGfE7NrR3fx5BpEHMZsEHoIxHL1j+lKdGobr8ovEyqeNkPLSKp6SCSOt7gmw==} hasBin: true dependencies: @@ -20960,67 +22418,67 @@ packages: fsevents: 2.3.2 dev: true - /tty-browserify/0.0.0: + /tty-browserify@0.0.0: resolution: {integrity: sha512-JVa5ijo+j/sOoHGjw0sxw734b1LhBkQ3bvUGNdxnVXDCX81Yx7TFgnZygxrIIWn23hbfTaMYLwRmAxFyDuFmIw==} dev: true - /tunnel-agent/0.6.0: + /tunnel-agent@0.6.0: resolution: {integrity: sha512-McnNiV1l8RYeY8tBgEpuodCC1mLUdbSN+CYBL7kJsJNInOP8UjDDEwdk6Mw60vdLLrr5NHKZhMAOSrR2NZuQ+w==} dependencies: safe-buffer: 5.2.1 dev: true - /tweetnacl/0.14.5: + /tweetnacl@0.14.5: resolution: {integrity: sha512-KXXFFdAbFXY4geFIwoyNK+f5Z1b7swfXABfL7HXCmoIWMKU3dmS26672A4EeQtDzLKy7SXmfBu51JolvEKwtGA==} dev: true - /type-check/0.4.0: + /type-check@0.4.0: resolution: {integrity: sha512-XleUoc9uwGXqjWwXaUTZAmzMcFZ5858QA2vvx1Ur5xIcixXIP+8LnFDgRplU30us6teqdlskFfu+ae4K79Ooew==} engines: {node: '>= 0.8.0'} dependencies: prelude-ls: 1.2.1 dev: true - /type-detect/4.0.8: + /type-detect@4.0.8: resolution: {integrity: sha512-0fr/mIH1dlO+x7TlcMy+bIDqKPsw/70tVyeHW787goQjhmqaZe10uwLujubK9q9Lg6Fiho1KUKDYz0Z7k7g5/g==} engines: {node: '>=4'} - /type-fest/0.16.0: + /type-fest@0.16.0: resolution: {integrity: sha512-eaBzG6MxNzEn9kiwvtre90cXaNLkmadMWa1zQMs3XORCXNbsH/OewwbxC5ia9dCxIxnTAsSxXJaa/p5y8DlvJg==} engines: {node: '>=10'} dev: true - /type-fest/0.20.2: + /type-fest@0.20.2: resolution: {integrity: sha512-Ne+eE4r0/iWnpAxD852z3A+N0Bt5RN//NjJwRd2VFHEmrywxf5vsZlh4R6lixl6B+wz/8d+maTSAkN1FIkI3LQ==} engines: {node: '>=10'} dev: true - /type-fest/0.21.3: + /type-fest@0.21.3: resolution: {integrity: sha512-t0rzBq87m3fVcduHDUFhKmyyX+9eo6WQjZvf51Ea/M0Q7+T374Jp1aUiyUl0GKxp8M/OETVHSDvmkyPgvX+X2w==} engines: {node: '>=10'} dev: true - /type-fest/0.6.0: + /type-fest@0.6.0: resolution: {integrity: sha512-q+MB8nYR1KDLrgr4G5yemftpMC7/QLqVndBmEEdqzmNj5dcFOO4Oo8qlwZE3ULT3+Zim1F8Kq4cBnikNhlCMlg==} engines: {node: '>=8'} dev: true - /type-fest/0.8.1: + /type-fest@0.8.1: resolution: {integrity: sha512-4dbzIzqvjtgiM5rw1k5rEHtBANKmdudhGyBEajN01fEyhaAIhsoKNy6y7+IN93IfpFtwY9iqi7kD+xwKhQsNJA==} engines: {node: '>=8'} dev: true - /type-fest/1.4.0: + /type-fest@1.4.0: resolution: {integrity: sha512-yGSza74xk0UG8k+pLh5oeoYirvIiWo5t0/o3zHHAO2tRDiZcxWP7fywNlXhqb6/r6sWvwi+RsyQMWhVLe4BVuA==} engines: {node: '>=10'} dev: true - /type-fest/2.19.0: + /type-fest@2.19.0: resolution: {integrity: sha512-RAH822pAdBgcNMAfWnCBU3CFZcfZ/i1eZjwFU/dsLKumyuuP3niueg2UAukXYF0E2AAoc82ZSSf9J0WQBinzHA==} engines: {node: '>=12.20'} dev: true - /type-is/1.6.18: + /type-is@1.6.18: resolution: {integrity: sha512-TkRKr9sUTxEH8MdfuCSP7VizJyzRNMjj2J2do2Jr3Kym598JVdEksuzPQCnlFPW4ky9Q+iA+ma9BGm06XQBy8g==} engines: {node: '>= 0.6'} dependencies: @@ -21028,7 +22486,7 @@ packages: mime-types: 2.1.35 dev: true - /typed-array-length/1.0.4: + /typed-array-length@1.0.4: resolution: {integrity: sha512-KjZypGq+I/H7HI5HlOoGHkWUUGq+Q0TPhQurLbyrVrvnKTBgzLhIJ7j6J/XTQOi0d1RjyZ0wdas8bKs2p0x3Ng==} dependencies: call-bind: 1.0.2 @@ -21036,46 +22494,46 @@ packages: is-typed-array: 1.1.10 dev: true - /typedarray-to-buffer/3.1.5: + /typedarray-to-buffer@3.1.5: resolution: {integrity: sha512-zdu8XMNEDepKKR+XYOXAVPtWui0ly0NtohUscw+UmaHiAWT8hrV1rr//H6V+0DvJ3OQ19S979M0laLfX8rm82Q==} dependencies: is-typedarray: 1.0.0 dev: true - /typedarray/0.0.6: + /typedarray@0.0.6: resolution: {integrity: sha512-/aCDEGatGvZ2BIk+HmLf4ifCJFwvKFNb9/JeZPMulfgFracn9QFcAf5GO8B/mweUjSoblS5In0cWhqpfs/5PQA==} dev: true - /typescript/4.9.5: + /typescript@4.9.5: resolution: {integrity: sha512-1FXk9E2Hm+QzZQ7z+McJiHL4NW1F2EzMu9Nq9i3zAaGqibafqYwCVU6WyWAuyQRRzOlxou8xZSyXLEN8oKj24g==} engines: {node: '>=4.2.0'} hasBin: true dev: true - /typescript/5.1.6: + /typescript@5.1.6: resolution: {integrity: sha512-zaWCozRZ6DLEWAWFrVDz1H6FVXzUSfTy5FUMWsQlU8Ym5JP9eO4xkTIROFCQvhQf61z6O/G6ugw3SgAnvvm+HA==} engines: {node: '>=14.17'} hasBin: true dev: true - /ua-parser-js/1.0.35: + /ua-parser-js@1.0.35: resolution: {integrity: sha512-fKnGuqmTBnIE+/KXSzCn4db8RTigUzw1AN0DmdU6hJovUTbYJKyqj+8Mt1c4VfRDnOVJnENmfYkIPZ946UrSAA==} dev: true - /ufo/0.8.6: + /ufo@0.8.6: resolution: {integrity: sha512-fk6CmUgwKCfX79EzcDQQpSCMxrHstvbLswFChHS0Vump+kFkw7nJBfTZoC1j0bOGoY9I7R3n2DGek5ajbcYnOw==} dev: true - /ufo/1.1.2: + /ufo@1.1.2: resolution: {integrity: sha512-TrY6DsjTQQgyS3E3dBaOXf0TpPD8u9FVrVYmKVegJuFw51n/YB9XPt+U6ydzFG5ZIN7+DIjPbNmXoBj9esYhgQ==} - /uglify-js/3.17.4: + /uglify-js@3.17.4: resolution: {integrity: sha512-T9q82TJI9e/C1TAxYvfb16xO120tMVFZrGA3f9/P4424DNu6ypK103y0GPFVa17yotwSyZW5iYXgjYHkGrJW/g==} engines: {node: '>=0.8.0'} hasBin: true dev: true - /unbox-primitive/1.0.2: + /unbox-primitive@1.0.2: resolution: {integrity: sha512-61pPlCD9h51VoreyJ0BReideM3MDKMKnh6+V9L08331ipq6Q8OFXZYiqP6n/tbHx4s5I9uRhcye6BrbkizkBDw==} dependencies: call-bind: 1.0.2 @@ -21084,14 +22542,14 @@ packages: which-boxed-primitive: 1.0.2 dev: true - /unbzip2-stream/1.4.3: + /unbzip2-stream@1.4.3: resolution: {integrity: sha512-mlExGW4w71ebDJviH16lQLtZS32VKqsSfk80GCfUlwT/4/hNRFsoscrF/c++9xinkMzECL1uL9DDwXqFWkruPg==} dependencies: buffer: 5.7.1 through: 2.3.8 dev: true - /unconfig/0.3.9: + /unconfig@0.3.9: resolution: {integrity: sha512-8yhetFd48M641mxrkWA+C/lZU4N0rCOdlo3dFsyFPnBHBjMJfjT/3eAZBRT2RxCRqeBMAKBVgikejdS6yeBjMw==} dependencies: '@antfu/utils': 0.7.5 @@ -21099,30 +22557,30 @@ packages: jiti: 1.19.1 dev: true - /undici/5.22.1: + /undici@5.22.1: resolution: {integrity: sha512-Ji2IJhFXZY0x/0tVBXeQwgPlLWw13GVzpsWPQ3rV50IFMMof2I55PZZxtm4P6iNq+L5znYN9nSTAq0ZyE6lSJw==} engines: {node: '>=14.0'} dependencies: busboy: 1.6.0 dev: true - /unfetch/4.2.0: + /unfetch@4.2.0: resolution: {integrity: sha512-F9p7yYCn6cIW9El1zi0HI6vqpeIvBsr3dSuRO6Xuppb1u5rXpCPmMvLSyECLhybr9isec8Ohl0hPekMVrEinDA==} dev: true - /unherit/1.1.3: + /unherit@1.1.3: resolution: {integrity: sha512-Ft16BJcnapDKp0+J/rqFC3Rrk6Y/Ng4nzsC028k2jdDII/rdZ7Wd3pPT/6+vIIxRagwRc9K0IUX0Ra4fKvw+WQ==} dependencies: inherits: 2.0.4 xtend: 4.0.2 dev: true - /unicode-canonical-property-names-ecmascript/2.0.0: + /unicode-canonical-property-names-ecmascript@2.0.0: resolution: {integrity: sha512-yY5PpDlfVIU5+y/BSCxAJRBIS1Zc2dDG3Ujq+sR0U+JjUevW2JhocOF+soROYDSaAezOzOKuyyixhD6mBknSmQ==} engines: {node: '>=4'} dev: true - /unicode-match-property-ecmascript/2.0.0: + /unicode-match-property-ecmascript@2.0.0: resolution: {integrity: sha512-5kaZCrbp5mmbz5ulBkDkbY0SsPOjKqVS35VpL9ulMPfSl0J0Xsm+9Evphv9CoIZFwre7aJoa94AY6seMKGVN5Q==} engines: {node: '>=4'} dependencies: @@ -21130,17 +22588,17 @@ packages: unicode-property-aliases-ecmascript: 2.1.0 dev: true - /unicode-match-property-value-ecmascript/2.1.0: + /unicode-match-property-value-ecmascript@2.1.0: resolution: {integrity: sha512-qxkjQt6qjg/mYscYMC0XKRn3Rh0wFPlfxB0xkt9CfyTvpX1Ra0+rAmdX2QyAobptSEvuy4RtpPRui6XkV+8wjA==} engines: {node: '>=4'} dev: true - /unicode-property-aliases-ecmascript/2.1.0: + /unicode-property-aliases-ecmascript@2.1.0: resolution: {integrity: sha512-6t3foTQI9qne+OZoVQB/8x8rk2k1eVy1gRXhV3oFQ5T6R1dqQ1xtin3XqSlx3+ATBkliTaR/hHyJBm+LVPNM8w==} engines: {node: '>=4'} dev: true - /unified/9.2.0: + /unified@9.2.0: resolution: {integrity: sha512-vx2Z0vY+a3YoTj8+pttM3tiJHCwY5UFbYdiWrwBEbHmK8pvsPj2rtAX2BFfgXen8T39CJWblWRDT4L5WGXtDdg==} dependencies: '@types/unist': 2.0.7 @@ -21152,10 +22610,10 @@ packages: vfile: 4.2.1 dev: true - /unimport/3.0.14: + /unimport@3.0.14(rollup@3.26.2): resolution: {integrity: sha512-67Rh/sGpEuVqdHWkXaZ6NOq+I7sKt86o+DUtKeGB6dh4Hk1A8AQrzyVGg2+LaVEYotStH7HwvV9YSaRjyT7Uqg==} dependencies: - '@rollup/pluginutils': 5.0.2 + '@rollup/pluginutils': 5.0.2(rollup@3.26.2) escape-string-regexp: 5.0.0 fast-glob: 3.3.0 local-pkg: 0.4.3 @@ -21170,7 +22628,7 @@ packages: - rollup dev: true - /union-value/1.0.1: + /union-value@1.0.1: resolution: {integrity: sha512-tJfXmxMeWYnczCVs7XAEvIV7ieppALdyepWMkHkwciRpZraG/xwT+s2JN8+pr1+8jCRf80FFzvr+MpQeeoF4Xg==} engines: {node: '>=0.10.0'} dependencies: @@ -21180,67 +22638,67 @@ packages: set-value: 2.0.1 dev: true - /unique-filename/1.1.1: + /unique-filename@1.1.1: resolution: {integrity: sha512-Vmp0jIp2ln35UTXuryvjzkjGdRyf9b2lTXuSYUiPmzRcl3FDtYqAwOnTJkAngD9SWhnoJzDbTKwaOrZ+STtxNQ==} dependencies: unique-slug: 2.0.2 dev: true - /unique-slug/2.0.2: + /unique-slug@2.0.2: resolution: {integrity: sha512-zoWr9ObaxALD3DOPfjPSqxt4fnZiWblxHIgeWqW8x7UqDzEtHEQLzji2cuJYQFCU6KmoJikOYAZlrTHHebjx2w==} dependencies: imurmurhash: 0.1.4 dev: true - /unique-string/2.0.0: + /unique-string@2.0.0: resolution: {integrity: sha512-uNaeirEPvpZWSgzwsPGtU2zVSTrn/8L5q/IexZmH0eH6SA73CmAA5U4GwORTxQAZs95TAXLNqeLoPPNO5gZfWg==} engines: {node: '>=8'} dependencies: crypto-random-string: 2.0.0 dev: true - /unist-builder/2.0.3: + /unist-builder@2.0.3: resolution: {integrity: sha512-f98yt5pnlMWlzP539tPc4grGMsFaQQlP/vM396b00jngsiINumNmsY8rkXjfoi1c6QaM8nQ3vaGDuoKWbe/1Uw==} dev: true - /unist-util-generated/1.1.6: + /unist-util-generated@1.1.6: resolution: {integrity: sha512-cln2Mm1/CZzN5ttGK7vkoGw+RZ8VcUH6BtGbq98DDtRGquAAOXig1mrBQYelOwMXYS8rK+vZDyyojSjp7JX+Lg==} dev: true - /unist-util-is/4.1.0: + /unist-util-is@4.1.0: resolution: {integrity: sha512-ZOQSsnce92GrxSqlnEEseX0gi7GH9zTJZ0p9dtu87WRb/37mMPO2Ilx1s/t9vBHrFhbgweUwb+t7cIn5dxPhZg==} dev: true - /unist-util-position/3.1.0: + /unist-util-position@3.1.0: resolution: {integrity: sha512-w+PkwCbYSFw8vpgWD0v7zRCl1FpY3fjDSQ3/N/wNd9Ffa4gPi8+4keqt99N3XW6F99t/mUzp2xAhNmfKWp95QA==} dev: true - /unist-util-remove-position/2.0.1: + /unist-util-remove-position@2.0.1: resolution: {integrity: sha512-fDZsLYIe2uT+oGFnuZmy73K6ZxOPG/Qcm+w7jbEjaFcJgbQ6cqjs/eSPzXhsmGpAsWPkqZM9pYjww5QTn3LHMA==} dependencies: unist-util-visit: 2.0.3 dev: true - /unist-util-remove/2.1.0: + /unist-util-remove@2.1.0: resolution: {integrity: sha512-J8NYPyBm4baYLdCbjmf1bhPu45Cr1MWTm77qd9istEkzWpnN6O9tMsEbB2JhNnBCqGENRqEWomQ+He6au0B27Q==} dependencies: unist-util-is: 4.1.0 dev: true - /unist-util-stringify-position/2.0.3: + /unist-util-stringify-position@2.0.3: resolution: {integrity: sha512-3faScn5I+hy9VleOq/qNbAd6pAx7iH5jYBMS9I1HgQVijz/4mv5Bvw5iw1sC/90CODiKo81G/ps8AJrISn687g==} dependencies: '@types/unist': 2.0.7 dev: true - /unist-util-visit-parents/3.1.1: + /unist-util-visit-parents@3.1.1: resolution: {integrity: sha512-1KROIZWo6bcMrZEwiH2UrXDyalAa0uqzWCxCJj6lPOvTve2WkfgCytoDTPaMnodXh1WrXOq0haVYHj99ynJlsg==} dependencies: '@types/unist': 2.0.7 unist-util-is: 4.1.0 dev: true - /unist-util-visit/2.0.3: + /unist-util-visit@2.0.3: resolution: {integrity: sha512-iJ4/RczbJMkD0712mGktuGpm/U4By4FfDonL7N/9tATGIF4imikjOuagyMY53tnZq3NP6BcmlrHhEKAfGWjh7Q==} dependencies: '@types/unist': 2.0.7 @@ -21248,24 +22706,60 @@ packages: unist-util-visit-parents: 3.1.1 dev: true - /universalify/0.2.0: + /universalify@0.2.0: resolution: {integrity: sha512-CJ1QgKmNg3CwvAv/kOFmtnEN05f0D/cn9QntgNOQlQF9dgvVTHj3t+8JPdjqawCHk7V/KA+fbUqzZ9XWhcqPUg==} engines: {node: '>= 4.0.0'} dev: true - /universalify/2.0.0: + /universalify@2.0.0: resolution: {integrity: sha512-hAZsKq7Yy11Zu1DE0OzWjw7nnLZmJZYTDZZyEFHZdUhV8FkH5MCfoU1XMaxXovpyW5nq5scPqq0ZDP9Zyl04oQ==} engines: {node: '>= 10.0.0'} dev: true - /unload/2.2.0: + /unload@2.2.0: resolution: {integrity: sha512-B60uB5TNBLtN6/LsgAf3udH9saB5p7gqJwcFfbOEZ8BcBHnGwCf6G/TGiEqkRAxX7zAFIUtzdrXQSdL3Q/wqNA==} dependencies: '@babel/runtime': 7.22.6 detect-node: 2.1.0 dev: false - /unocss/0.53.5_vite@4.4.3: + /unocss@0.53.5(postcss@8.4.25)(rollup@2.79.1)(vite@4.4.3): + resolution: {integrity: sha512-LXAdtzAaH8iEDWxW4t9i6TvJNw0OSrgdN+jw8rAZAWb73Nx51ZLoKPUB1rFvQMr2Li7LcsUj5hYpOrQbhhafYg==} + engines: {node: '>=14'} + peerDependencies: + '@unocss/webpack': 0.53.5 + peerDependenciesMeta: + '@unocss/webpack': + optional: true + dependencies: + '@unocss/astro': 0.53.5(rollup@2.79.1)(vite@4.4.3) + '@unocss/cli': 0.53.5(rollup@2.79.1) + '@unocss/core': 0.53.5 + '@unocss/extractor-arbitrary-variants': 0.53.5 + '@unocss/postcss': 0.53.5(postcss@8.4.25) + '@unocss/preset-attributify': 0.53.5 + '@unocss/preset-icons': 0.53.5 + '@unocss/preset-mini': 0.53.5 + '@unocss/preset-tagify': 0.53.5 + '@unocss/preset-typography': 0.53.5 + '@unocss/preset-uno': 0.53.5 + '@unocss/preset-web-fonts': 0.53.5 + '@unocss/preset-wind': 0.53.5 + '@unocss/reset': 0.53.5 + '@unocss/transformer-attributify-jsx': 0.53.5 + '@unocss/transformer-attributify-jsx-babel': 0.53.5 + '@unocss/transformer-compile-class': 0.53.5 + '@unocss/transformer-directives': 0.53.5 + '@unocss/transformer-variant-group': 0.53.5 + '@unocss/vite': 0.53.5(rollup@2.79.1)(vite@4.4.3) + transitivePeerDependencies: + - postcss + - rollup + - supports-color + - vite + dev: true + + /unocss@0.53.5(postcss@8.4.25)(rollup@3.26.2)(vite@4.4.3): resolution: {integrity: sha512-LXAdtzAaH8iEDWxW4t9i6TvJNw0OSrgdN+jw8rAZAWb73Nx51ZLoKPUB1rFvQMr2Li7LcsUj5hYpOrQbhhafYg==} engines: {node: '>=14'} peerDependencies: @@ -21274,11 +22768,11 @@ packages: '@unocss/webpack': optional: true dependencies: - '@unocss/astro': 0.53.5_vite@4.4.3 - '@unocss/cli': 0.53.5 + '@unocss/astro': 0.53.5(rollup@3.26.2)(vite@4.4.3) + '@unocss/cli': 0.53.5(rollup@3.26.2) '@unocss/core': 0.53.5 '@unocss/extractor-arbitrary-variants': 0.53.5 - '@unocss/postcss': 0.53.5 + '@unocss/postcss': 0.53.5(postcss@8.4.25) '@unocss/preset-attributify': 0.53.5 '@unocss/preset-icons': 0.53.5 '@unocss/preset-mini': 0.53.5 @@ -21293,19 +22787,20 @@ packages: '@unocss/transformer-compile-class': 0.53.5 '@unocss/transformer-directives': 0.53.5 '@unocss/transformer-variant-group': 0.53.5 - '@unocss/vite': 0.53.5_vite@4.4.3 + '@unocss/vite': 0.53.5(rollup@3.26.2)(vite@4.4.3) transitivePeerDependencies: + - postcss - rollup - supports-color - vite dev: true - /unpipe/1.0.0: + /unpipe@1.0.0: resolution: {integrity: sha512-pjy2bYhSsufwWlKwPc+l3cN7+wuJlK6uz0YdJEOlQDbl6jo/YlPi4mb8agUkVC8BF7V8NuzeyPNqRksA3hztKQ==} engines: {node: '>= 0.8'} dev: true - /unplugin-auto-import/0.16.6: + /unplugin-auto-import@0.16.6(@vueuse/core@10.2.1)(rollup@3.26.2): resolution: {integrity: sha512-M+YIITkx3C/Hg38hp8HmswP5mShUUyJOzpifv7RTlAbeFlO2Tyw0pwrogSSxnipHDPTtI8VHFBpkYkNKzYSuyA==} engines: {node: '>=14'} peerDependencies: @@ -21318,43 +22813,48 @@ packages: optional: true dependencies: '@antfu/utils': 0.7.5 - '@rollup/pluginutils': 5.0.2 + '@rollup/pluginutils': 5.0.2(rollup@3.26.2) + '@vueuse/core': 10.2.1(vue@3.3.4) fast-glob: 3.3.0 local-pkg: 0.4.3 magic-string: 0.30.1 minimatch: 9.0.3 - unimport: 3.0.14 + unimport: 3.0.14(rollup@3.26.2) unplugin: 1.3.2 transitivePeerDependencies: - rollup dev: true - /unplugin-auto-import/0.16.6_@vueuse+core@10.2.1: - resolution: {integrity: sha512-M+YIITkx3C/Hg38hp8HmswP5mShUUyJOzpifv7RTlAbeFlO2Tyw0pwrogSSxnipHDPTtI8VHFBpkYkNKzYSuyA==} + /unplugin-vue-components@0.25.1(rollup@2.79.1)(vue@3.3.4): + resolution: {integrity: sha512-kzS2ZHVMaGU2XEO2keYQcMjNZkanDSGDdY96uQT9EPe+wqSZwwgbFfKVJ5ti0+8rGAcKHColwKUvctBhq2LJ3A==} engines: {node: '>=14'} peerDependencies: + '@babel/parser': ^7.15.8 '@nuxt/kit': ^3.2.2 - '@vueuse/core': '*' + vue: 2 || 3 peerDependenciesMeta: - '@nuxt/kit': + '@babel/parser': optional: true - '@vueuse/core': + '@nuxt/kit': optional: true dependencies: '@antfu/utils': 0.7.5 - '@rollup/pluginutils': 5.0.2 - '@vueuse/core': 10.2.1_vue@3.3.4 + '@rollup/pluginutils': 5.0.2(rollup@2.79.1) + chokidar: 3.5.3 + debug: 4.3.4(supports-color@8.1.1) fast-glob: 3.3.0 local-pkg: 0.4.3 magic-string: 0.30.1 minimatch: 9.0.3 - unimport: 3.0.14 + resolve: 1.22.2 unplugin: 1.3.2 + vue: 3.3.4 transitivePeerDependencies: - rollup + - supports-color dev: true - /unplugin-vue-components/0.25.1_vue@3.3.4: + /unplugin-vue-components@0.25.1(rollup@3.26.2)(vue@3.3.4): resolution: {integrity: sha512-kzS2ZHVMaGU2XEO2keYQcMjNZkanDSGDdY96uQT9EPe+wqSZwwgbFfKVJ5ti0+8rGAcKHColwKUvctBhq2LJ3A==} engines: {node: '>=14'} peerDependencies: @@ -21368,9 +22868,9 @@ packages: optional: true dependencies: '@antfu/utils': 0.7.5 - '@rollup/pluginutils': 5.0.2 + '@rollup/pluginutils': 5.0.2(rollup@3.26.2) chokidar: 3.5.3 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) fast-glob: 3.3.0 local-pkg: 0.4.3 magic-string: 0.30.1 @@ -21383,7 +22883,7 @@ packages: - supports-color dev: true - /unplugin/1.3.2: + /unplugin@1.3.2: resolution: {integrity: sha512-Lh7/2SryjXe/IyWqx9K7IKwuKhuOFZEhotiBquOODsv2IVyDkI9lv/XhgfjdXf/xdbv32txmnBNnC/JVTDJlsA==} dependencies: acorn: 8.10.0 @@ -21392,7 +22892,7 @@ packages: webpack-virtual-modules: 0.5.0 dev: true - /unset-value/1.0.0: + /unset-value@1.0.0: resolution: {integrity: sha512-PcA2tsuGSF9cnySLHTLSh2qrQiJ70mn+r+Glzxv2TWZblxsxCC52BDlZoPCsz7STd9pN7EZetkWZBAvk4cgZdQ==} engines: {node: '>=0.10.0'} dependencies: @@ -21400,7 +22900,7 @@ packages: isobject: 3.0.1 dev: true - /untildify/2.1.0: + /untildify@2.1.0: resolution: {integrity: sha512-sJjbDp2GodvkB0FZZcn7k6afVisqX5BZD7Yq3xp4nN2O15BBK0cLm3Vwn2vQaF7UDS0UUsrQMkkplmDI5fskig==} engines: {node: '>=0.10.0'} dependencies: @@ -21408,17 +22908,17 @@ packages: dev: true optional: true - /untildify/4.0.0: + /untildify@4.0.0: resolution: {integrity: sha512-KK8xQ1mkzZeg9inewmFVDNkg3l5LUhoq9kN6iWYB/CC9YMG8HA+c1Q8HwDe6dEX7kErrEVNVBO3fWsVq5iDgtw==} engines: {node: '>=8'} dev: true - /upath/1.2.0: + /upath@1.2.0: resolution: {integrity: sha512-aZwGpamFO61g3OlfT7OQCHqhGnW43ieH9WZeP7QxN/G/jS4jfqUkZxoryvJgVPEcrl5NL/ggHsSmLMHuH64Lhg==} engines: {node: '>=4'} dev: true - /update-browserslist-db/1.0.11_browserslist@4.21.9: + /update-browserslist-db@1.0.11(browserslist@4.21.9): resolution: {integrity: sha512-dCwEFf0/oT85M1fHBg4F0jtLwJrutGoHSQXCh7u4o2t1drG+c0a9Flnqww6XUKSfQMPpJBRjU8d4RXB09qtvaA==} hasBin: true peerDependencies: @@ -21428,18 +22928,18 @@ packages: escalade: 3.1.1 picocolors: 1.0.0 - /uri-js/4.4.1: + /uri-js@4.4.1: resolution: {integrity: sha512-7rKUyy33Q1yc98pQ1DAmLtwX109F7TIfWlW1Ydo8Wl1ii1SeHieeh0HHfPeL2fMXK6z0s8ecKs9frCuLJvndBg==} dependencies: punycode: 2.3.0 dev: true - /urix/0.1.0: + /urix@0.1.0: resolution: {integrity: sha512-Am1ousAhSLBeB9cG/7k7r2R0zj50uDRlZHPGbazid5s9rlF1F/QKYObEKSIunSjIOkJZqwRRLpvewjEkM7pSqg==} deprecated: Please see https://github.com/lydell/urix#deprecated dev: true - /url-loader/4.1.1_lit45vopotvaqup7lrvlnvtxwy: + /url-loader@4.1.1(file-loader@6.2.0)(webpack@4.46.0): resolution: {integrity: sha512-3BTV812+AVHHOJQO8O5MkWgZ5aosP7GnROJwvzLS9hWDj00lZ6Z0wNak423Lp9PBZN05N+Jk/N5Si8jRAlGyWA==} engines: {node: '>= 10.13.0'} peerDependencies: @@ -21449,28 +22949,28 @@ packages: file-loader: optional: true dependencies: - file-loader: 6.2.0_webpack@4.46.0 + file-loader: 6.2.0(webpack@4.46.0) loader-utils: 2.0.4 mime-types: 2.1.35 schema-utils: 3.3.0 webpack: 4.46.0 dev: true - /url-parse/1.5.10: + /url-parse@1.5.10: resolution: {integrity: sha512-WypcfiRhfeUP9vvF0j6rw0J3hrWrw6iZv3+22h6iRMJ/8z1Tj6XfLP4DsUix5MhMPnXpiHDoKyoZ/bdCkwBCiQ==} dependencies: querystringify: 2.2.0 requires-port: 1.0.0 dev: true - /url/0.11.1: + /url@0.11.1: resolution: {integrity: sha512-rWS3H04/+mzzJkv0eZ7vEDGiQbgquI1fGfOad6zKvgYQi1SzMmhl7c/DdRGxhaWrVH6z0qWITo8rpnxK/RfEhA==} dependencies: punycode: 1.4.1 qs: 6.11.2 dev: true - /use-sync-external-store/1.2.0_react@18.2.0: + /use-sync-external-store@1.2.0(react@18.2.0): resolution: {integrity: sha512-eEgnFxGQ1Ife9bzYs6VLi8/4X6CObHMw9Qr9tPY43iKwsPw8xE8+EFsf/2cFZ5S3esXgpWgtSCtLNS41F+sKPA==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -21478,35 +22978,35 @@ packages: react: 18.2.0 dev: true - /use/3.1.1: + /use@3.1.1: resolution: {integrity: sha512-cwESVXlO3url9YWlFW/TA9cshCEhtu7IKJ/p5soJ/gGpj7vbvFrAY/eIioQ6Dw23KjZhYgiIo8HOs1nQ2vr/oQ==} engines: {node: '>=0.10.0'} dev: true - /util-deprecate/1.0.2: + /util-deprecate@1.0.2: resolution: {integrity: sha512-EPD5q1uXyFxJpCrLnCc1nHnq3gOa6DZBocAIiI2TaSCA7VCJ1UJDMagCzIkXNsUYfD1daK//LTEQ8xiIbrHtcw==} dev: true - /util.promisify/1.0.0: + /util.promisify@1.0.0: resolution: {integrity: sha512-i+6qA2MPhvoKLuxnJNpXAGhg7HphQOSUq2LKMZD0m15EiskXUkMvKdF4Uui0WYeCUGea+o2cw/ZuwehtfsrNkA==} dependencies: define-properties: 1.2.0 object.getownpropertydescriptors: 2.1.6 dev: true - /util/0.10.3: + /util@0.10.3: resolution: {integrity: sha512-5KiHfsmkqacuKjkRkdV7SsfDJ2EGiPsK92s2MhNSY0craxjTdKTtqKsJaCWp4LW33ZZ0OPUv1WO/TFvNQRiQxQ==} dependencies: inherits: 2.0.1 dev: true - /util/0.11.1: + /util@0.11.1: resolution: {integrity: sha512-HShAsny+zS2TZfaXxD9tYj4HQGlBezXZMZuM/S5PKLLoZkShZiGk9o5CzukI1LVHZvjdvZ2Sj1aW/Ndn2NB/HQ==} dependencies: inherits: 2.0.3 dev: true - /util/0.12.5: + /util@0.12.5: resolution: {integrity: sha512-kZf/K6hEIrWHI6XqOFUiiMa+79wE/D8Q+NCNAWclkyg3b4d2k7s0QGepNjiABc+aR3N1PAyHL7p6UcLY6LmrnA==} dependencies: inherits: 2.0.4 @@ -21516,45 +23016,54 @@ packages: which-typed-array: 1.1.10 dev: true - /utila/0.4.0: + /utila@0.4.0: resolution: {integrity: sha512-Z0DbgELS9/L/75wZbro8xAnT50pBVFQZ+hUEueGDU5FN51YSCYM+jdxsfCiHjwNP/4LCDD0i/graKpeBnOXKRA==} dev: true - /utils-merge/1.0.1: + /utils-merge@1.0.1: resolution: {integrity: sha512-pMZTvIkT1d+TFGvDOqodOclx0QWkkgi6Tdoa8gC8ffGAAqz9pzPTZWAybbsHHoED/ztMtkv/VoYTYyShUn81hA==} engines: {node: '>= 0.4.0'} dev: true - /uuid-browser/3.1.0: + /uuid-browser@3.1.0: resolution: {integrity: sha512-dsNgbLaTrd6l3MMxTtouOCFw4CBFc/3a+GgYA2YyrJvyQ1u6q4pcu3ktLoUZ/VN/Aw9WsauazbgsgdfVWgAKQg==} deprecated: Package no longer supported and required. Use the uuid package or crypto.randomUUID instead dev: true - /uuid/3.4.0: + /uuid@3.4.0: resolution: {integrity: sha512-HjSDRw6gZE5JMggctHBcjVak08+KEVhSIiDzFnT9S9aegmp85S/bReBVTb4QTFaRNptJ9kuYaNhnbNEOkbKb/A==} deprecated: Please upgrade to version 7 or higher. Older versions may use Math.random() in certain circumstances, which is known to be problematic. See https://v8.dev/blog/math-random for details. hasBin: true dev: true - /uuid/8.3.2: + /uuid@8.3.2: resolution: {integrity: sha512-+NYs2QeMWy+GWFOEm9xnn6HCDp0l7QBD7ml8zLUmJ+93Q5NF0NocErnwkTkXVFNiX3/fpC6afS8Dhb/gz7R7eg==} hasBin: true dev: true - /uuid/9.0.0: + /uuid@9.0.0: resolution: {integrity: sha512-MXcSTerfPa4uqyzStbRoTgt5XIe3x5+42+q1sDuy3R5MDk66URdLMOZe5aPX/SQd+kuYAh0FdP/pO28IkQyTeg==} hasBin: true dev: true - /v8-compile-cache-lib/3.0.1: + /v8-compile-cache-lib@3.0.1: resolution: {integrity: sha512-wa7YjyUGfNZngI/vtK0UHAN+lgDCxBPCylVXGp0zu59Fz5aiGtNXaq3DhIov063MorB+VfufLh3JlF2KdTK3xg==} dev: true - /v8-compile-cache/2.3.0: + /v8-compile-cache@2.3.0: resolution: {integrity: sha512-l8lCEmLcLYZh4nbunNZvQCJc5pv7+RCwa8q/LdUx8u7lsWvPDKmpodJAJNwkAhJC//dFY48KuIEmjtd4RViDrA==} dev: true - /v8-to-istanbul/9.1.0: + /v8-to-istanbul@8.1.1: + resolution: {integrity: sha512-FGtKtv3xIpR6BYhvgH8MI/y78oT7d8Au3ww4QIxymrCtZEh5b8gCw2siywE+puhEmuWKDtmfrvF5UlB298ut3w==} + engines: {node: '>=10.12.0'} + dependencies: + '@types/istanbul-lib-coverage': 2.0.4 + convert-source-map: 1.9.0 + source-map: 0.7.4 + dev: true + + /v8-to-istanbul@9.1.0: resolution: {integrity: sha512-6z3GW9x8G1gd+JIIgQQQxXuiJtCXeAjp6RaPEPLv62mH3iPHPxV6W3robxtCzNErRo6ZwTmzWhsbNvjyEBKzKA==} engines: {node: '>=10.12.0'} dependencies: @@ -21562,27 +23071,27 @@ packages: '@types/istanbul-lib-coverage': 2.0.4 convert-source-map: 1.9.0 - /validate-html-nesting/1.2.2: + /validate-html-nesting@1.2.2: resolution: {integrity: sha512-hGdgQozCsQJMyfK5urgFcWEqsSSrK63Awe0t/IMR0bZ0QMtnuaiHzThW81guu3qx9abLi99NEuiaN6P9gVYsNg==} dev: true - /validate-npm-package-license/3.0.4: + /validate-npm-package-license@3.0.4: resolution: {integrity: sha512-DpKm2Ui/xN7/HQKCtpZxoRWBhZ9Z0kqtygG8XCgNQ8ZlDnxuQmWhj566j8fN4Cu3/JmbhsDo7fcAJq4s9h27Ew==} dependencies: spdx-correct: 3.2.0 spdx-expression-parse: 3.0.1 dev: true - /vary/1.1.2: + /vary@1.1.2: resolution: {integrity: sha512-BNGbWLfd0eUPabhkXUVm0j8uuvREyTh5ovRa/dyow/BqAbZJyC+5fU+IzQOzmAKzYqYRAISoRhdQr3eIZ/PXqg==} engines: {node: '>= 0.8'} dev: true - /vecti/2.1.40: + /vecti@2.1.40: resolution: {integrity: sha512-89P1Siijv7itxmhQP2gf/X3X+DTszUEYyUHuHF2EsHE9lgNWULx2WWvVZXCt71DBXx3YJ/Aj8yTZmly9qOkF0g==} dev: true - /verror/1.10.0: + /verror@1.10.0: resolution: {integrity: sha512-ZZKSmDAEFOijERBLkmYfJ+vmk3w+7hOLYDNkRCuRuMJGEmqYNCNLyBBFwWKVMhfwaEF3WOd0Zlw86U/WC/+nYw==} engines: {'0': node >=0.6.0} dependencies: @@ -21591,18 +23100,18 @@ packages: extsprintf: 1.3.0 dev: true - /vfile-location/3.2.0: + /vfile-location@3.2.0: resolution: {integrity: sha512-aLEIZKv/oxuCDZ8lkJGhuhztf/BW4M+iHdCwglA/eWc+vtuRFJj8EtgceYFX4LRjOhCAAiNHsKGssC6onJ+jbA==} dev: true - /vfile-message/2.0.4: + /vfile-message@2.0.4: resolution: {integrity: sha512-DjssxRGkMvifUOJre00juHoP9DPWuzjxKuMDrhNbk2TdaYYBNMStsNhEOt3idrtI12VQYM/1+iM0KOzXi4pxwQ==} dependencies: '@types/unist': 2.0.7 unist-util-stringify-position: 2.0.3 dev: true - /vfile/4.2.1: + /vfile@4.2.1: resolution: {integrity: sha512-O6AE4OskCG5S1emQ/4gl8zK586RqA3srz3nfK/Viy0UPToBc5Trp9BVFb1u0CjsKrAWwnpr4ifM/KBXPWwJbCA==} dependencies: '@types/unist': 2.0.7 @@ -21611,7 +23120,7 @@ packages: vfile-message: 2.0.4 dev: true - /victory-vendor/36.6.11: + /victory-vendor@36.6.11: resolution: {integrity: sha512-nT8kCiJp8dQh8g991J/R5w5eE2KnO8EAIP0xocWlh9l2okngMWglOPoMZzJvek8Q1KUc4XE/mJxTZnvOB1sTYg==} dependencies: '@types/d3-array': 3.0.5 @@ -21630,7 +23139,7 @@ packages: d3-timer: 3.0.1 dev: false - /vite-plugin-pages/0.31.0_vite@4.4.3: + /vite-plugin-pages@0.31.0(vite@4.4.3): resolution: {integrity: sha512-fw3onBfVTXQI7rOzAbSZhmfwvk50+3qNnGZpERjmD93c8nEjrGLyd53eFXYMxcJV4KA1vzi4qIHt2+6tS4dEMw==} peerDependencies: '@vue/compiler-sfc': ^2.7.0 || ^3.0.0 @@ -21640,103 +23149,69 @@ packages: optional: true dependencies: '@types/debug': 4.1.8 - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) deep-equal: 2.2.2 extract-comments: 1.1.0 fast-glob: 3.3.0 json5: 2.2.3 local-pkg: 0.4.3 picocolors: 1.0.0 - vite: 4.4.3 + vite: 4.4.3(@types/node@18.16.19) yaml: 2.3.1 transitivePeerDependencies: - supports-color dev: true - /vite-plugin-pwa/0.16.4_cqwyifvz3q2qdw6r4piqd2mqaa: + /vite-plugin-pwa@0.16.4(vite@4.4.3)(workbox-build@7.0.0)(workbox-window@7.0.0): resolution: {integrity: sha512-lmwHFIs9zI2H9bXJld/zVTbCqCQHZ9WrpyDMqosICDV0FVnCJwniX1NMDB79HGTIZzOQkY4gSZaVTJTw6maz/Q==} engines: {node: '>=16.0.0'} peerDependencies: vite: ^3.1.0 || ^4.0.0 + workbox-build: ^7.0.0 workbox-window: ^7.0.0 dependencies: - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) fast-glob: 3.3.0 pretty-bytes: 6.1.0 - vite: 4.4.3 + vite: 4.4.3(@types/node@18.16.19) workbox-build: 7.0.0 workbox-window: 7.0.0 transitivePeerDependencies: - - '@types/babel__core' - supports-color dev: true - /vite-plugin-ruby/3.2.2_vite@4.4.3: + /vite-plugin-ruby@3.2.2(vite@4.4.3): resolution: {integrity: sha512-cuHG1MajRWPR8YdfF6lvgsQRnKFEBRwZF//asFbRiI1psacxB5aPlHSvYZYxAu5IflrAa0MdR0HxEq+g98M3iQ==} peerDependencies: vite: '>=4.0.0' dependencies: - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) fast-glob: 3.3.0 - vite: 4.4.3 + vite: 4.4.3(@types/node@18.16.19) transitivePeerDependencies: - supports-color dev: true - /vite-plugin-solid/2.7.0_solid-js@1.7.8+vite@4.4.3: + /vite-plugin-solid@2.7.0(solid-js@1.7.8)(vite@4.4.3): resolution: {integrity: sha512-avp/Jl5zOp/Itfo67xtDB2O61U7idviaIp4mLsjhCa13PjKNasz+IID0jYTyqUp9SFx6/PmBr6v4KgDppqompg==} peerDependencies: solid-js: ^1.7.2 vite: ^3.0.0 || ^4.0.0 dependencies: '@babel/core': 7.22.8 - '@babel/preset-typescript': 7.22.5_@babel+core@7.22.8 + '@babel/preset-typescript': 7.22.5(@babel/core@7.22.8) '@types/babel__core': 7.20.1 - babel-preset-solid: 1.7.7_@babel+core@7.22.8 + babel-preset-solid: 1.7.7(@babel/core@7.22.8) merge-anything: 5.1.7 solid-js: 1.7.8 - solid-refresh: 0.5.3_solid-js@1.7.8 - vite: 4.4.3 - vitefu: 0.2.4_vite@4.4.3 + solid-refresh: 0.5.3(solid-js@1.7.8) + vite: 4.4.3(@types/node@18.16.19) + vitefu: 0.2.4(vite@4.4.3) transitivePeerDependencies: - supports-color dev: true - /vite/4.4.3: - resolution: {integrity: sha512-IMnXQXXWgLi5brBQx/4WzDxdzW0X3pjO4nqFJAuNvwKtxzAmPzFE1wszW3VDpAGQJm3RZkm/brzRdyGsnwgJIA==} - engines: {node: ^14.18.0 || >=16.0.0} - hasBin: true - peerDependencies: - '@types/node': '>= 14' - less: '*' - lightningcss: ^1.21.0 - sass: '*' - stylus: '*' - sugarss: '*' - terser: ^5.4.0 - peerDependenciesMeta: - '@types/node': - optional: true - less: - optional: true - lightningcss: - optional: true - sass: - optional: true - stylus: - optional: true - sugarss: - optional: true - terser: - optional: true - dependencies: - esbuild: 0.18.11 - postcss: 8.4.25 - rollup: 3.26.2 - optionalDependencies: - fsevents: 2.3.2 - - /vite/4.4.3_@types+node@18.16.19: + /vite@4.4.3(@types/node@18.16.19): resolution: {integrity: sha512-IMnXQXXWgLi5brBQx/4WzDxdzW0X3pjO4nqFJAuNvwKtxzAmPzFE1wszW3VDpAGQJm3RZkm/brzRdyGsnwgJIA==} engines: {node: ^14.18.0 || >=16.0.0} hasBin: true @@ -21770,9 +23245,8 @@ packages: rollup: 3.26.2 optionalDependencies: fsevents: 2.3.2 - dev: true - /vite/4.4.3_@types+node@20.4.1: + /vite@4.4.3(@types/node@20.4.1): resolution: {integrity: sha512-IMnXQXXWgLi5brBQx/4WzDxdzW0X3pjO4nqFJAuNvwKtxzAmPzFE1wszW3VDpAGQJm3RZkm/brzRdyGsnwgJIA==} engines: {node: ^14.18.0 || >=16.0.0} hasBin: true @@ -21806,9 +23280,8 @@ packages: rollup: 3.26.2 optionalDependencies: fsevents: 2.3.2 - dev: false - /vitefu/0.2.4_vite@4.4.3: + /vitefu@0.2.4(vite@4.4.3): resolution: {integrity: sha512-fanAXjSaf9xXtOOeno8wZXIhgia+CZury481LsDaV++lSvcU2R9Ch2bPh3PYFyoHW+w9LqAeYRISVQjUIew14g==} peerDependencies: vite: ^3.0.0 || ^4.0.0 @@ -21816,25 +23289,25 @@ packages: vite: optional: true dependencies: - vite: 4.4.3 + vite: 4.4.3(@types/node@18.16.19) dev: true - /vitepress/1.0.0-beta.5: + /vitepress@1.0.0-beta.5(@types/node@18.16.19)(search-insights@2.7.0): resolution: {integrity: sha512-/RjqqRsSEKkzF6HhK5e5Ij+bZ7ETb9jNCRRgIMm10gJ+ZLC3D1OqkE465lEqCeJUgt2HZ6jmWjDqIBfrJSpv7w==} hasBin: true dependencies: '@docsearch/css': 3.5.1 - '@docsearch/js': 3.5.1 - '@vitejs/plugin-vue': 4.2.3_vite@4.4.3+vue@3.3.4 + '@docsearch/js': 3.5.1(search-insights@2.7.0) + '@vitejs/plugin-vue': 4.2.3(vite@4.4.3)(vue@3.3.4) '@vue/devtools-api': 6.5.0 - '@vueuse/core': 10.2.1_vue@3.3.4 - '@vueuse/integrations': 10.2.1_focus-trap@7.5.2+vue@3.3.4 + '@vueuse/core': 10.2.1(vue@3.3.4) + '@vueuse/integrations': 10.2.1(focus-trap@7.5.2)(vue@3.3.4) body-scroll-lock: 4.0.0-beta.0 focus-trap: 7.5.2 mark.js: 8.11.1 minisearch: 6.1.0 shiki: 0.14.3 - vite: 4.4.3 + vite: 4.4.3(@types/node@18.16.19) vue: 3.3.4 transitivePeerDependencies: - '@algolia/client-search' @@ -21863,7 +23336,7 @@ packages: - universal-cookie dev: true - /vitest-sonar-reporter/0.3.3_vitest@packages+vitest: + /vitest-sonar-reporter@0.3.3(vitest@packages+vitest): resolution: {integrity: sha512-OvH+AYMgDFk3SK7sohn5KUHUOhB42tWgSTW7YzB/v/dN3x+7bgXD2L0FZpDYjC1hvBMJJ4HFqOsiO9LsETmgxg==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} peerDependencies: @@ -21873,23 +23346,23 @@ packages: vitest: link:packages/vitest dev: true - /vm-browserify/1.1.2: + /vm-browserify@1.1.2: resolution: {integrity: sha512-2ham8XPWTONajOR0ohOKOHXkm3+gaBmGut3SRuu75xLd/RRaY6vqgh8NBYYk7+RW3u5AtzPQZG8F10LHkl0lAQ==} dev: true - /vscode-oniguruma/1.7.0: + /vscode-oniguruma@1.7.0: resolution: {integrity: sha512-L9WMGRfrjOhgHSdOYgCt/yRMsXzLDJSL7BPrOZt73gU0iWO4mpqzqQzOz5srxqTvMBaR0XZTSrVWo4j55Rc6cA==} dev: true - /vscode-textmate/8.0.0: + /vscode-textmate@8.0.0: resolution: {integrity: sha512-AFbieoL7a5LMqcnOF04ji+rpXadgOXnZsxQr//r83kLPr7biP7am3g9zbaZIaBGwBRWeSvoMD4mgPdX3e4NWBg==} dev: true - /vue-component-type-helpers/1.6.5: + /vue-component-type-helpers@1.6.5: resolution: {integrity: sha512-iGdlqtajmiqed8ptURKPJ/Olz0/mwripVZszg6tygfZSIL9kYFPJTNY6+Q6OjWGznl2L06vxG5HvNvAnWrnzbg==} dev: true - /vue-demi/0.14.5_vue@3.3.4: + /vue-demi@0.14.5(vue@3.3.4): resolution: {integrity: sha512-o9NUVpl/YlsGJ7t+xuqJKx8EBGf1quRhCiT6D/J0pfwmk9zUwYkC7yrF4SZCe6fETvSM3UNL2edcbYrSyc4QHA==} engines: {node: '>=12'} hasBin: true @@ -21903,13 +23376,13 @@ packages: dependencies: vue: 3.3.4 - /vue-eslint-parser/9.3.1_eslint@8.44.0: + /vue-eslint-parser@9.3.1(eslint@8.44.0): resolution: {integrity: sha512-Clr85iD2XFZ3lJ52/ppmUDG/spxQu6+MAeHXjjyI4I1NUYZ9xmenQp4N0oaHJhrA8OOxltCVxMRfANGa70vU0g==} engines: {node: ^14.17.0 || >=16.0.0} peerDependencies: eslint: '>=6.0.0' dependencies: - debug: 4.3.4 + debug: 4.3.4(supports-color@8.1.1) eslint: 8.44.0 eslint-scope: 7.2.0 eslint-visitor-keys: 3.4.1 @@ -21921,7 +23394,7 @@ packages: - supports-color dev: true - /vue-resize/2.0.0-alpha.1_vue@3.3.4: + /vue-resize@2.0.0-alpha.1(vue@3.3.4): resolution: {integrity: sha512-7+iqOueLU7uc9NrMfrzbG8hwMqchfVfSzpVlCMeJQe4pyibqyoifDNbKTZvwxZKDvGkB+PdFeKvnGZMoEb8esg==} peerDependencies: vue: ^3.0.0 @@ -21929,7 +23402,7 @@ packages: vue: 3.3.4 dev: true - /vue-router/4.2.4_vue@3.3.4: + /vue-router@4.2.4(vue@3.3.4): resolution: {integrity: sha512-9PISkmaCO02OzPVOMq2w82ilty6+xJmQrarYZDkjZBfl4RvYAlt4PKnEX21oW4KTtWfa9OuO/b3qk1Od3AEdCQ==} peerDependencies: vue: ^3.2.0 @@ -21938,7 +23411,7 @@ packages: vue: 3.3.4 dev: true - /vue-template-compiler/2.7.14: + /vue-template-compiler@2.7.14: resolution: {integrity: sha512-zyA5Y3ArvVG0NacJDkkzJuPQDF8RFeRlzV2vLeSnhSpieO6LK2OVbdLPi5MPPs09Ii+gMO8nY4S3iKQxBxDmWQ==} dependencies: de-indent: 1.0.2 @@ -21946,7 +23419,7 @@ packages: vue: 2.7.14 dev: true - /vue-tsc/0.40.13_typescript@4.9.5: + /vue-tsc@0.40.13(typescript@4.9.5): resolution: {integrity: sha512-xzuN3g5PnKfJcNrLv4+mAjteMd5wLm5fRhW0034OfNJZY4WhB07vhngea/XeGn7wNYt16r7syonzvW/54dcNiA==} hasBin: true peerDependencies: @@ -21957,35 +23430,49 @@ packages: typescript: 4.9.5 dev: true - /vue/2.7.14: + /vue@2.7.14: resolution: {integrity: sha512-b2qkFyOM0kwqWFuQmgd4o+uHGU7T+2z3T+WQp8UBjADfEv2n4FEMffzBmCKNP0IGzOEEfYjvtcC62xaSKeQDrQ==} dependencies: '@vue/compiler-sfc': 2.7.14 csstype: 3.1.2 - /vue/3.3.4: + /vue@3.3.4: resolution: {integrity: sha512-VTyEYn3yvIeY1Py0WaYGZsXnz3y5UnGi62GjVEqvEGPl6nxbOrCXbVOTQWBEJUqAyTUk2uJ5JLVnYJ6ZzGbrSw==} dependencies: '@vue/compiler-dom': 3.3.4 '@vue/compiler-sfc': 3.3.4 '@vue/runtime-dom': 3.3.4 - '@vue/server-renderer': 3.3.4_vue@3.3.4 + '@vue/server-renderer': 3.3.4(vue@3.3.4) '@vue/shared': 3.3.4 - /w3c-xmlserializer/4.0.0: + /w3c-hr-time@1.0.2: + resolution: {integrity: sha512-z8P5DvDNjKDoFIHK7q8r8lackT6l+jo/Ye3HOle7l9nICP9lf1Ci25fy9vHd0JOWewkIFzXIEig3TdKT7JQ5fQ==} + deprecated: Use your platform's native performance.now() and performance.timeOrigin. + dependencies: + browser-process-hrtime: 1.0.0 + dev: true + + /w3c-xmlserializer@2.0.0: + resolution: {integrity: sha512-4tzD0mF8iSiMiNs30BiLO3EpfGLZUT2MSX/G+o7ZywDzliWQ3OPtTZ0PTC3B3ca1UAf4cJMHB+2Bf56EriJuRA==} + engines: {node: '>=10'} + dependencies: + xml-name-validator: 3.0.0 + dev: true + + /w3c-xmlserializer@4.0.0: resolution: {integrity: sha512-d+BFHzbiCx6zGfz0HyQ6Rg69w9k19nviJspaj4yNscGjrHu94sVP+aRm75yEbCh+r2/yR+7q6hux9LVtbuTGBw==} engines: {node: '>=14'} dependencies: xml-name-validator: 4.0.0 dev: true - /walker/1.0.8: + /walker@1.0.8: resolution: {integrity: sha512-ts/8E8l5b7kY0vlWLewOkDXMmPdLcVV4GmOQLyxuSswIJsweeFZtAsMF7k1Nszz+TYBQrlYRmzOnr398y1JemQ==} dependencies: makeerror: 1.0.12 dev: true - /watchpack-chokidar2/2.0.1: + /watchpack-chokidar2@2.0.1: resolution: {integrity: sha512-nCFfBIPKr5Sh61s4LPpy1Wtfi0HE8isJ3d2Yb5/Ppw2P2B/3eVSEBjKfN0fmHJSK14+31KwMKmcrzs2GM4P0Ww==} requiresBuild: true dependencies: @@ -21995,7 +23482,7 @@ packages: dev: true optional: true - /watchpack/1.7.5: + /watchpack@1.7.5: resolution: {integrity: sha512-9P3MWk6SrKjHsGkLT2KHXdQ/9SNkyoJbabxnKOoJepsvJjJG8uYTR3yTPxPQvNDI3w4Nz1xnE0TLHK4RIVe/MQ==} dependencies: graceful-fs: 4.2.11 @@ -22007,7 +23494,7 @@ packages: - supports-color dev: true - /watchpack/2.4.0: + /watchpack@2.4.0: resolution: {integrity: sha512-Lcvm7MGST/4fup+ifyKi2hjyIAwcdI4HRgtvTpIUxBRhB+RFtUh8XtDOxUfctVCnhVi+QQj49i91OyvzkJl6cg==} engines: {node: '>=10.13.0'} dependencies: @@ -22015,19 +23502,19 @@ packages: graceful-fs: 4.2.11 dev: true - /wbuf/1.7.3: + /wbuf@1.7.3: resolution: {integrity: sha512-O84QOnr0icsbFGLS0O3bI5FswxzRr8/gHwWkDlQFskhSPryQXvrTMxjxGP4+iWYoauLoBvfDpkrOauZ+0iZpDA==} dependencies: minimalistic-assert: 1.0.1 dev: true - /wcwidth/1.0.1: + /wcwidth@1.0.1: resolution: {integrity: sha512-XHPEwS0q6TaxcvG85+8EYkbiCux2XtWG2mkc47Ng2A77BQu9+DqIOJldST4HgPkuea7dvKSj5VgX3P1d4rW8Tg==} dependencies: defaults: 1.0.4 dev: true - /web-encoding/1.1.5: + /web-encoding@1.1.5: resolution: {integrity: sha512-HYLeVCdJ0+lBYV2FvNZmv3HJ2Nt0QYXqZojk3d9FJOLkwnuhzM9tmamh8d7HPM8QqjKH8DeHkFTx+CFlWpZZDA==} dependencies: util: 0.12.5 @@ -22035,11 +23522,11 @@ packages: '@zxing/text-encoding': 0.9.0 dev: true - /web-namespaces/1.1.4: + /web-namespaces@1.1.4: resolution: {integrity: sha512-wYxSGajtmoP4WxfejAPIr4l0fVh+jeMXZb08wNc0tMg6xsfZXj3cECqIK0G7ZAqUq0PP8WlMDtaOGVBTAWztNw==} dev: true - /webdriver/8.12.1: + /webdriver@8.12.1: resolution: {integrity: sha512-Ca+MUYUXfl5gsnX40xAIUgfoa76qQsfX7REGFzMl09Cb7vHKtM17bEOGDaTbXIX4kbkXylyUSAuBpe3gCtDDKg==} engines: {node: ^16.13 || >=18} dependencies: @@ -22059,7 +23546,7 @@ packages: - utf-8-validate dev: true - /webdriverio/8.12.1: + /webdriverio@8.12.1(typescript@5.1.6): resolution: {integrity: sha512-lW0Qo3fy64cVbYWWAZbXxLIOK0pbTARgpY89J+0Sr6zh2K2NKtd/0D11k3WfMeYxd0b0he7E7XC1b6M6w4h75A==} engines: {node: ^16.13 || >=18} dependencies: @@ -22074,7 +23561,7 @@ packages: aria-query: 5.3.0 css-shorthand-properties: 1.1.1 css-value: 0.0.1 - devtools: 8.12.1 + devtools: 8.12.1(typescript@5.1.6) devtools-protocol: 0.0.1161598 grapheme-splitter: 1.0.4 import-meta-resolve: 3.0.0 @@ -22082,7 +23569,7 @@ packages: lodash.clonedeep: 4.5.0 lodash.zip: 4.2.0 minimatch: 9.0.3 - puppeteer-core: 20.3.0 + puppeteer-core: 20.3.0(typescript@5.1.6) query-selector-shadow-dom: 1.0.1 resq: 1.11.0 rgb2hex: 0.2.5 @@ -22096,19 +23583,29 @@ packages: - utf-8-validate dev: true - /webidl-conversions/3.0.1: + /webidl-conversions@3.0.1: resolution: {integrity: sha512-2JAn3z8AR6rjK8Sm8orRC0h/bcl/DqL7tRPdGZ4I1CjdF+EaMLmYxBHyXuKL849eucPFhvBoxMsflfOb8kxaeQ==} - /webidl-conversions/4.0.2: + /webidl-conversions@4.0.2: resolution: {integrity: sha512-YQ+BmxuTgd6UXZW3+ICGfyqRyHXVlD5GtQr5+qjiNW7bF0cqrzX500HVXPBOvgXb5YnzDd+h0zqyv61KUD7+Sg==} dev: true - /webidl-conversions/7.0.0: + /webidl-conversions@5.0.0: + resolution: {integrity: sha512-VlZwKPCkYKxQgeSbH5EyngOmRp7Ww7I9rQLERETtf5ofd9pGeswWiOtogpEO850jziPRarreGxn5QIiTqpb2wA==} + engines: {node: '>=8'} + dev: true + + /webidl-conversions@6.1.0: + resolution: {integrity: sha512-qBIvFLGiBpLjfwmYAaHPXsn+ho5xZnGvyGvsarywGNc8VyQJUMHJ8OBKGGrPER0okBeMDaan4mNBlgBROxuI8w==} + engines: {node: '>=10.4'} + dev: true + + /webidl-conversions@7.0.0: resolution: {integrity: sha512-VwddBukDzu71offAQR975unBIGqfKZpM+8ZX6ySk8nYhVoo5CYaZyzt3YBvYtRtO+aoGlqxPg/B87NGVZ/fu6g==} engines: {node: '>=12'} dev: true - /webpack-dev-middleware/3.7.3_webpack@4.46.0: + /webpack-dev-middleware@3.7.3(webpack@4.46.0): resolution: {integrity: sha512-djelc/zGiz9nZj/U7PTBi2ViorGJXEWo/3ltkPbDyxCXhhEXkW0ce99falaok4TPj+AsxLiXJR0EBOb0zh9fKQ==} engines: {node: '>= 6'} peerDependencies: @@ -22122,7 +23619,7 @@ packages: webpack-log: 2.0.0 dev: true - /webpack-filter-warnings-plugin/1.2.1_webpack@4.46.0: + /webpack-filter-warnings-plugin@1.2.1(webpack@4.46.0): resolution: {integrity: sha512-Ez6ytc9IseDMLPo0qCuNNYzgtUl8NovOqjIq4uAU8LTD4uoa1w1KpZyyzFtLTEMZpkkOkLfL9eN+KGYdk1Qtwg==} engines: {node: '>= 4.3 < 5.0.0 || >= 5.10'} peerDependencies: @@ -22131,7 +23628,7 @@ packages: webpack: 4.46.0 dev: true - /webpack-hot-middleware/2.25.4: + /webpack-hot-middleware@2.25.4: resolution: {integrity: sha512-IRmTspuHM06aZh98OhBJtqLpeWFM8FXJS5UYpKYxCJzyFoyWj1w6VGFfomZU7OPA55dMLrQK0pRT1eQ3PACr4w==} dependencies: ansi-html-community: 0.0.8 @@ -22139,7 +23636,7 @@ packages: strip-ansi: 6.0.1 dev: true - /webpack-log/2.0.0: + /webpack-log@2.0.0: resolution: {integrity: sha512-cX8G2vR/85UYG59FgkoMamwHUIkSSlV3bBMRsbxVXVUk2j6NleCKjQ/WE9eYg9WY4w25O9w8wKP4rzNZFmUcUg==} engines: {node: '>= 6'} dependencies: @@ -22147,31 +23644,31 @@ packages: uuid: 3.4.0 dev: true - /webpack-sources/1.4.3: + /webpack-sources@1.4.3: resolution: {integrity: sha512-lgTS3Xhv1lCOKo7SA5TjKXMjpSM4sBjNV5+q2bqesbSPs5FjGmU6jjtBSkX9b4qW87vDIsCIlUPOEhbZrMdjeQ==} dependencies: source-list-map: 2.0.1 source-map: 0.6.1 dev: true - /webpack-sources/3.2.3: + /webpack-sources@3.2.3: resolution: {integrity: sha512-/DyMEOrDgLKKIG0fmvtz+4dUX/3Ghozwgm6iPp8KRhvn+eQf9+Q7GWxVNMk3+uCPWfdXYC4ExGBckIXdFEfH1w==} engines: {node: '>=10.13.0'} dev: true - /webpack-virtual-modules/0.2.2: + /webpack-virtual-modules@0.2.2: resolution: {integrity: sha512-kDUmfm3BZrei0y+1NTHJInejzxfhtU8eDj2M7OKb2IWrPFAeO1SOH2KuQ68MSZu9IGEHcxbkKKR1v18FrUSOmA==} dependencies: - debug: 3.2.7 + debug: 3.2.7(supports-color@8.1.1) transitivePeerDependencies: - supports-color dev: true - /webpack-virtual-modules/0.5.0: + /webpack-virtual-modules@0.5.0: resolution: {integrity: sha512-kyDivFZ7ZM0BVOUteVbDFhlRt7Ah/CSPwJdi8hBpkK7QLumUqdLtVfm/PX/hkcnrvr0i77fO5+TjZ94Pe+C9iw==} dev: true - /webpack/4.46.0: + /webpack@4.46.0: resolution: {integrity: sha512-6jJuJjg8znb/xRItk7bkT0+Q7AHCYjjFnvKIWQPkNIOyRqoCGvkOs0ipeQzrqz4l5FtN5ZI/ukEHroeX/o1/5Q==} engines: {node: '>=6.11.5'} hasBin: true @@ -22190,7 +23687,7 @@ packages: '@webassemblyjs/wasm-parser': 1.9.0 acorn: 6.4.2 ajv: 6.12.6 - ajv-keywords: 3.5.2_ajv@6.12.6 + ajv-keywords: 3.5.2(ajv@6.12.6) chrome-trace-event: 1.0.3 enhanced-resolve: 4.5.0 eslint-scope: 4.0.3 @@ -22204,14 +23701,14 @@ packages: node-libs-browser: 2.2.1 schema-utils: 1.0.0 tapable: 1.1.3 - terser-webpack-plugin: 1.4.5_webpack@4.46.0 + terser-webpack-plugin: 1.4.5(webpack@4.46.0) watchpack: 1.7.5 webpack-sources: 1.4.3 transitivePeerDependencies: - supports-color dev: true - /webpack/5.88.1: + /webpack@5.88.1(esbuild@0.18.11): resolution: {integrity: sha512-FROX3TxQnC/ox4N+3xQoWZzvGXSuscxR32rbzjpXgEzWudJFEJBpdlkkob2ylrv5yzzufD1zph1OoFsLtm6stQ==} engines: {node: '>=10.13.0'} hasBin: true @@ -22227,7 +23724,7 @@ packages: '@webassemblyjs/wasm-edit': 1.11.6 '@webassemblyjs/wasm-parser': 1.11.6 acorn: 8.10.0 - acorn-import-assertions: 1.9.0_acorn@8.10.0 + acorn-import-assertions: 1.9.0(acorn@8.10.0) browserslist: 4.21.9 chrome-trace-event: 1.0.3 enhanced-resolve: 5.15.0 @@ -22242,7 +23739,7 @@ packages: neo-async: 2.6.2 schema-utils: 3.3.0 tapable: 2.2.1 - terser-webpack-plugin: 5.3.9_webpack@5.88.1 + terser-webpack-plugin: 5.3.9(esbuild@0.18.11)(webpack@5.88.1) watchpack: 2.4.0 webpack-sources: 3.2.3 transitivePeerDependencies: @@ -22251,19 +23748,29 @@ packages: - uglify-js dev: true - /whatwg-encoding/2.0.0: + /whatwg-encoding@1.0.5: + resolution: {integrity: sha512-b5lim54JOPN9HtzvK9HFXvBma/rnfFeqsic0hSpjtDbVxR3dJKLc+KB4V6GgiGOvl7CY/KNh8rxSo9DKQrnUEw==} + dependencies: + iconv-lite: 0.4.24 + dev: true + + /whatwg-encoding@2.0.0: resolution: {integrity: sha512-p41ogyeMUrw3jWclHWTQg1k05DSVXPLcVxRTYsXUk+ZooOCZLcoYgPZ/HL/D/N+uQPOtcp1me1WhBEaX02mhWg==} engines: {node: '>=12'} dependencies: iconv-lite: 0.6.3 dev: true - /whatwg-mimetype/3.0.0: + /whatwg-mimetype@2.3.0: + resolution: {integrity: sha512-M4yMwr6mAnQz76TbJm914+gPpB/nCwvZbJU28cUD6dR004SAxDLOOSUaB1JDRqLtaOV/vi0IC5lEAGFgrjGv/g==} + dev: true + + /whatwg-mimetype@3.0.0: resolution: {integrity: sha512-nt+N2dzIutVRxARx1nghPKGv1xHikU7HKdfafKkLNLindmPU/ch3U31NOCGGA/dmPcmb1VlofO0vnKAcsm0o/Q==} engines: {node: '>=12'} dev: true - /whatwg-url/11.0.0: + /whatwg-url@11.0.0: resolution: {integrity: sha512-RKT8HExMpoYx4igMiVMY83lN6UeITKJlBQ+vR/8ZJ8OCdSiN3RwCq+9gH0+Xzj0+5IrM6i4j/6LuvzbZIQgEcQ==} engines: {node: '>=12'} dependencies: @@ -22271,7 +23778,7 @@ packages: webidl-conversions: 7.0.0 dev: true - /whatwg-url/12.0.1: + /whatwg-url@12.0.1: resolution: {integrity: sha512-Ed/LrqB8EPlGxjS+TrsXcpUond1mhccS3pchLhzSgPCnTimUCKj3IZE75pAs5m6heB2U2TMerKFUXheyHY+VDQ==} engines: {node: '>=14'} dependencies: @@ -22279,13 +23786,13 @@ packages: webidl-conversions: 7.0.0 dev: true - /whatwg-url/5.0.0: + /whatwg-url@5.0.0: resolution: {integrity: sha512-saE57nupxk6v3HY35+jzBwYa0rKSy0XR8JSxZPwgLr7ys0IBzhGviA1/TUGJLmSVqs8pb9AnvICXEuOHLprYTw==} dependencies: tr46: 0.0.3 webidl-conversions: 3.0.1 - /whatwg-url/7.1.0: + /whatwg-url@7.1.0: resolution: {integrity: sha512-WUu7Rg1DroM7oQvGWfOiAK21n74Gg+T4elXEQYkOhtyLeWiJFoOGLXPKI/9gzIie9CtwVLm8wtw6YJdKyxSjeg==} dependencies: lodash.sortby: 4.7.0 @@ -22293,7 +23800,16 @@ packages: webidl-conversions: 4.0.2 dev: true - /which-boxed-primitive/1.0.2: + /whatwg-url@8.7.0: + resolution: {integrity: sha512-gAojqb/m9Q8a5IV96E3fHJM70AzCkgt4uXYX2O7EmuyOnLrViCQlsEBmF9UQIu3/aeAIp2U17rtbpZWNntQqdg==} + engines: {node: '>=10'} + dependencies: + lodash: 4.17.21 + tr46: 2.1.0 + webidl-conversions: 6.1.0 + dev: true + + /which-boxed-primitive@1.0.2: resolution: {integrity: sha512-bwZdv0AKLpplFY2KZRX6TvyuN7ojjr7lwkg6ml0roIy9YeuSr7JS372qlNW18UQYzgYK9ziGcerWqZOmEn9VNg==} dependencies: is-bigint: 1.0.4 @@ -22303,7 +23819,7 @@ packages: is-symbol: 1.0.4 dev: true - /which-collection/1.0.1: + /which-collection@1.0.1: resolution: {integrity: sha512-W8xeTUwaln8i3K/cY1nGXzdnVZlidBcagyNFtBdD5kxnb4TvGKR7FfSIS3mYpwWS1QUCutfKz8IY8RjftB0+1A==} dependencies: is-map: 2.0.2 @@ -22312,7 +23828,7 @@ packages: is-weakset: 2.0.2 dev: true - /which-typed-array/1.1.10: + /which-typed-array@1.1.10: resolution: {integrity: sha512-uxoA5vLUfRPdjCuJ1h5LlYdmTLbYfums398v3WLkM+i/Wltl2/XyZpQWKbN++ck5L64SR/grOHqtXCUKmlZPNA==} engines: {node: '>= 0.4'} dependencies: @@ -22324,14 +23840,14 @@ packages: is-typed-array: 1.1.10 dev: true - /which/1.3.1: + /which@1.3.1: resolution: {integrity: sha512-HxJdYWq1MTIQbJ3nw0cqssHoTNU267KlrDuGZ1WYlxDStUtKUhOaJmh112/TZmHxxUfuJqPXSOm7tDyas0OSIQ==} hasBin: true dependencies: isexe: 2.0.0 dev: true - /which/2.0.2: + /which@2.0.2: resolution: {integrity: sha512-BLI3Tl1TW3Pvl70l3yq3Y64i+awpwXqsGBYWkkqMtnbXgrMD+yj7rhW0kuEDxzJaYXGjEW5ogapKNMEKNMjibA==} engines: {node: '>= 8'} hasBin: true @@ -22339,7 +23855,7 @@ packages: isexe: 2.0.0 dev: true - /which/3.0.1: + /which@3.0.1: resolution: {integrity: sha512-XA1b62dzQzLfaEOSQFTCOd5KFf/1VSzZo7/7TUjnya6u0vGGKzU96UQBZTAThCb2j4/xjBAyii1OhRLJEivHvg==} engines: {node: ^14.17.0 || ^16.13.0 || >=18.0.0} hasBin: true @@ -22347,7 +23863,7 @@ packages: isexe: 2.0.0 dev: true - /why-is-node-running/2.2.2: + /why-is-node-running@2.2.2: resolution: {integrity: sha512-6tSwToZxTOcotxHeA+qGCq1mVzKR3CwcJGmVcY+QE8SHy6TnpFnh8PAvPNHYr7EcuVeG0QSMxtYCuO1ta/G/oA==} engines: {node: '>=8'} hasBin: true @@ -22356,47 +23872,47 @@ packages: stackback: 0.0.2 dev: false - /wide-align/1.1.5: + /wide-align@1.1.5: resolution: {integrity: sha512-eDMORYaPNZ4sQIuuYPDHdQvf4gyCF9rEEV/yPxGfwPkRodwEgiMUUXTx/dex+Me0wxx53S+NgUHaP7y3MGlDmg==} dependencies: string-width: 4.2.3 dev: true - /widest-line/3.1.0: + /widest-line@3.1.0: resolution: {integrity: sha512-NsmoXalsWVDMGupxZ5R08ka9flZjjiLvHVAWYOKtiKM8ujtZWr9cRffak+uSE48+Ob8ObalXpwyeUiyDD6QFgg==} engines: {node: '>=8'} dependencies: string-width: 4.2.3 dev: true - /wordwrap/1.0.0: + /wordwrap@1.0.0: resolution: {integrity: sha512-gvVzJFlPycKc5dZN4yPkP8w7Dc37BtP1yczEneOb4uq34pXZcvrtRTmWV8W+Ume+XCxKgbjM+nevkyFPMybd4Q==} dev: true - /workbox-background-sync/7.0.0: + /workbox-background-sync@7.0.0: resolution: {integrity: sha512-S+m1+84gjdueM+jIKZ+I0Lx0BDHkk5Nu6a3kTVxP4fdj3gKouRNmhO8H290ybnJTOPfBDtTMXSQA/QLTvr7PeA==} dependencies: idb: 7.1.1 workbox-core: 7.0.0 dev: true - /workbox-broadcast-update/7.0.0: + /workbox-broadcast-update@7.0.0: resolution: {integrity: sha512-oUuh4jzZrLySOo0tC0WoKiSg90bVAcnE98uW7F8GFiSOXnhogfNDGZelPJa+6KpGBO5+Qelv04Hqx2UD+BJqNQ==} dependencies: workbox-core: 7.0.0 dev: true - /workbox-build/7.0.0: + /workbox-build@7.0.0: resolution: {integrity: sha512-CttE7WCYW9sZC+nUYhQg3WzzGPr4IHmrPnjKiu3AMXsiNQKx+l4hHl63WTrnicLmKEKHScWDH8xsGBdrYgtBzg==} engines: {node: '>=16.0.0'} dependencies: - '@apideck/better-ajv-errors': 0.3.6_ajv@8.12.0 + '@apideck/better-ajv-errors': 0.3.6(ajv@8.12.0) '@babel/core': 7.22.8 - '@babel/preset-env': 7.22.7_@babel+core@7.22.8 + '@babel/preset-env': 7.22.7(@babel/core@7.22.8) '@babel/runtime': 7.22.6 - '@rollup/plugin-babel': 5.3.1_dk2tutsrvslwzit5bccevt2cya - '@rollup/plugin-node-resolve': 11.2.1_rollup@2.79.1 - '@rollup/plugin-replace': 2.4.2_rollup@2.79.1 + '@rollup/plugin-babel': 5.3.1(@babel/core@7.22.8)(rollup@2.79.1) + '@rollup/plugin-node-resolve': 11.2.1(rollup@2.79.1) + '@rollup/plugin-replace': 2.4.2(rollup@2.79.1) '@surma/rollup-plugin-off-main-thread': 2.2.3 ajv: 8.12.0 common-tags: 1.8.2 @@ -22406,7 +23922,7 @@ packages: lodash: 4.17.21 pretty-bytes: 5.6.0 rollup: 2.79.1 - rollup-plugin-terser: 7.0.2_rollup@2.79.1 + rollup-plugin-terser: 7.0.2(rollup@2.79.1) source-map: 0.8.0-beta.0 stringify-object: 3.3.0 strip-comments: 2.0.1 @@ -22432,24 +23948,24 @@ packages: - supports-color dev: true - /workbox-cacheable-response/7.0.0: + /workbox-cacheable-response@7.0.0: resolution: {integrity: sha512-0lrtyGHn/LH8kKAJVOQfSu3/80WDc9Ma8ng0p2i/5HuUndGttH+mGMSvOskjOdFImLs2XZIimErp7tSOPmu/6g==} dependencies: workbox-core: 7.0.0 dev: true - /workbox-core/7.0.0: + /workbox-core@7.0.0: resolution: {integrity: sha512-81JkAAZtfVP8darBpfRTovHg8DGAVrKFgHpOArZbdFd78VqHr5Iw65f2guwjE2NlCFbPFDoez3D3/6ZvhI/rwQ==} dev: true - /workbox-expiration/7.0.0: + /workbox-expiration@7.0.0: resolution: {integrity: sha512-MLK+fogW+pC3IWU9SFE+FRStvDVutwJMR5if1g7oBJx3qwmO69BNoJQVaMXq41R0gg3MzxVfwOGKx3i9P6sOLQ==} dependencies: idb: 7.1.1 workbox-core: 7.0.0 dev: true - /workbox-google-analytics/7.0.0: + /workbox-google-analytics@7.0.0: resolution: {integrity: sha512-MEYM1JTn/qiC3DbpvP2BVhyIH+dV/5BjHk756u9VbwuAhu0QHyKscTnisQuz21lfRpOwiS9z4XdqeVAKol0bzg==} dependencies: workbox-background-sync: 7.0.0 @@ -22458,13 +23974,13 @@ packages: workbox-strategies: 7.0.0 dev: true - /workbox-navigation-preload/7.0.0: + /workbox-navigation-preload@7.0.0: resolution: {integrity: sha512-juWCSrxo/fiMz3RsvDspeSLGmbgC0U9tKqcUPZBCf35s64wlaLXyn2KdHHXVQrb2cqF7I0Hc9siQalainmnXJA==} dependencies: workbox-core: 7.0.0 dev: true - /workbox-precaching/7.0.0: + /workbox-precaching@7.0.0: resolution: {integrity: sha512-EC0vol623LJqTJo1mkhD9DZmMP604vHqni3EohhQVwhJlTgyKyOkMrZNy5/QHfOby+39xqC01gv4LjOm4HSfnA==} dependencies: workbox-core: 7.0.0 @@ -22472,13 +23988,13 @@ packages: workbox-strategies: 7.0.0 dev: true - /workbox-range-requests/7.0.0: + /workbox-range-requests@7.0.0: resolution: {integrity: sha512-SxAzoVl9j/zRU9OT5+IQs7pbJBOUOlriB8Gn9YMvi38BNZRbM+RvkujHMo8FOe9IWrqqwYgDFBfv6sk76I1yaQ==} dependencies: workbox-core: 7.0.0 dev: true - /workbox-recipes/7.0.0: + /workbox-recipes@7.0.0: resolution: {integrity: sha512-DntcK9wuG3rYQOONWC0PejxYYIDHyWWZB/ueTbOUDQgefaeIj1kJ7pdP3LZV2lfrj8XXXBWt+JDRSw1lLLOnww==} dependencies: workbox-cacheable-response: 7.0.0 @@ -22489,49 +24005,49 @@ packages: workbox-strategies: 7.0.0 dev: true - /workbox-routing/7.0.0: + /workbox-routing@7.0.0: resolution: {integrity: sha512-8YxLr3xvqidnbVeGyRGkaV4YdlKkn5qZ1LfEePW3dq+ydE73hUUJJuLmGEykW3fMX8x8mNdL0XrWgotcuZjIvA==} dependencies: workbox-core: 7.0.0 dev: true - /workbox-strategies/7.0.0: + /workbox-strategies@7.0.0: resolution: {integrity: sha512-dg3qJU7tR/Gcd/XXOOo7x9QoCI9nk74JopaJaYAQ+ugLi57gPsXycVdBnYbayVj34m6Y8ppPwIuecrzkpBVwbA==} dependencies: workbox-core: 7.0.0 dev: true - /workbox-streams/7.0.0: + /workbox-streams@7.0.0: resolution: {integrity: sha512-moVsh+5to//l6IERWceYKGiftc+prNnqOp2sgALJJFbnNVpTXzKISlTIsrWY+ogMqt+x1oMazIdHj25kBSq/HQ==} dependencies: workbox-core: 7.0.0 workbox-routing: 7.0.0 dev: true - /workbox-sw/7.0.0: + /workbox-sw@7.0.0: resolution: {integrity: sha512-SWfEouQfjRiZ7GNABzHUKUyj8pCoe+RwjfOIajcx6J5mtgKkN+t8UToHnpaJL5UVVOf5YhJh+OHhbVNIHe+LVA==} dev: true - /workbox-window/7.0.0: + /workbox-window@7.0.0: resolution: {integrity: sha512-j7P/bsAWE/a7sxqTzXo3P2ALb1reTfZdvVp6OJ/uLr/C2kZAMvjeWGm8V4htQhor7DOvYg0sSbFN2+flT5U0qA==} dependencies: '@types/trusted-types': 2.0.3 workbox-core: 7.0.0 dev: true - /worker-farm/1.7.0: + /worker-farm@1.7.0: resolution: {integrity: sha512-rvw3QTZc8lAxyVrqcSGVm5yP/IJ2UcB3U0graE3LCFoZ0Yn2x4EoVSqJKdB/T5M+FLcRPjz4TDacRf3OCfNUzw==} dependencies: errno: 0.1.8 dev: true - /worker-rpc/0.1.1: + /worker-rpc@0.1.1: resolution: {integrity: sha512-P1WjMrUB3qgJNI9jfmpZ/htmBEjFh//6l/5y8SD9hg1Ef5zTTVVoRjTrTEzPrNBQvmhMxkoTsjOXN10GWU7aCg==} dependencies: microevent.ts: 0.1.1 dev: true - /wrap-ansi/6.2.0: + /wrap-ansi@6.2.0: resolution: {integrity: sha512-r6lPcBGxZXlIcymEu7InxDMhdW0KDxpLgoFLcguasxCaJ/SOIZwINatK9KY/tf+ZrlywOKU0UDj3ATXUBfxJXA==} engines: {node: '>=8'} dependencies: @@ -22540,7 +24056,7 @@ packages: strip-ansi: 6.0.1 dev: true - /wrap-ansi/7.0.0: + /wrap-ansi@7.0.0: resolution: {integrity: sha512-YVGIj2kamLSTxw6NsZjoBxfSwsn0ycdesmc4p+Q21c5zPuZ1pl+NfxVdxPtdHvmNVOQ6XSYG4AUtyt/Fi7D16Q==} engines: {node: '>=10'} dependencies: @@ -22549,7 +24065,7 @@ packages: strip-ansi: 6.0.1 dev: true - /wrap-ansi/8.1.0: + /wrap-ansi@8.1.0: resolution: {integrity: sha512-si7QWI6zUMq56bESFvagtmzMdGOtoxfR+Sez11Mobfc7tm+VkUckk9bW2UeffTGVUbOksxmSw0AA2gs8g71NCQ==} engines: {node: '>=12'} dependencies: @@ -22558,10 +24074,10 @@ packages: strip-ansi: 7.1.0 dev: true - /wrappy/1.0.2: + /wrappy@1.0.2: resolution: {integrity: sha512-l4Sp/DRseor9wL6EvV2+TuQn63dMkPjZ/sp9XkghTEbV9KlPS1xUsZ3u7/IQO4wxtcFB4bgpQPRcR3QCvezPcQ==} - /write-file-atomic/3.0.3: + /write-file-atomic@3.0.3: resolution: {integrity: sha512-AvHcyZ5JnSfq3ioSyjrBkH9yW4m7Ayk8/9My/DD9onKeu/94fwrMocemO2QAJFAlnnDN+ZDS+ZjAR5ua1/PV/Q==} dependencies: imurmurhash: 0.1.4 @@ -22570,7 +24086,20 @@ packages: typedarray-to-buffer: 3.1.5 dev: true - /ws/8.13.0: + /ws@7.5.9: + resolution: {integrity: sha512-F+P9Jil7UiSKSkppIiD94dN07AwvFixvLIj1Og1Rl9GGMuNipJnV9JzjD6XuqmAeiswGvUmNLjr5cFuXwNS77Q==} + engines: {node: '>=8.3.0'} + peerDependencies: + bufferutil: ^4.0.1 + utf-8-validate: ^5.0.2 + peerDependenciesMeta: + bufferutil: + optional: true + utf-8-validate: + optional: true + dev: true + + /ws@8.13.0: resolution: {integrity: sha512-x9vcZYTrFPC7aSIbj7sRCYo7L/Xb8Iy+pW0ng0wt2vCJv7M9HOMy0UoN3rr+IFC7hb7vXoqS+P9ktyLLLhO+LA==} engines: {node: '>=10.0.0'} peerDependencies: @@ -22582,7 +24111,7 @@ packages: utf-8-validate: optional: true - /ws/8.5.0: + /ws@8.5.0: resolution: {integrity: sha512-BWX0SWVgLPzYwF8lTzEy1egjhS4S4OEAHfsO8o65WOVsrnSRGaSiUaa9e0ggGlkMTtBlmOpEXiie9RUcBO86qg==} engines: {node: '>=10.0.0'} peerDependencies: @@ -22595,48 +24124,52 @@ packages: optional: true dev: true - /x-default-browser/0.4.0: + /x-default-browser@0.4.0: resolution: {integrity: sha512-7LKo7RtWfoFN/rHx1UELv/2zHGMx8MkZKDq1xENmOCTkfIqZJ0zZ26NEJX8czhnPXVcqS0ARjjfJB+eJ0/5Cvw==} hasBin: true optionalDependencies: default-browser-id: 1.0.4 dev: true - /xml-name-validator/4.0.0: + /xml-name-validator@3.0.0: + resolution: {integrity: sha512-A5CUptxDsvxKJEU3yO6DuWBSJz/qizqzJKOMIfUJHETbBw/sFaDxgd6fxm1ewUaM0jZ444Fc5vC5ROYurg/4Pw==} + dev: true + + /xml-name-validator@4.0.0: resolution: {integrity: sha512-ICP2e+jsHvAj2E2lIHxa5tjXRlKDJo4IdvPvCXbXQGdzSfmSpNVyIKMvoZHjDY9DP0zV17iI85o90vRFXNccRw==} engines: {node: '>=12'} dev: true - /xmlchars/2.2.0: + /xmlchars@2.2.0: resolution: {integrity: sha512-JZnDKK8B0RCDw84FNdDAIpZK+JuJw+s7Lz8nksI7SIuU3UXJJslUthsi+uWBUYOwPFwW7W7PRLRfUKpxjtjFCw==} dev: true - /xtend/4.0.2: + /xtend@4.0.2: resolution: {integrity: sha512-LKYU1iAXJXUgAXn9URjiu+MWhyUXHsvfp7mcuYm9dSUKK0/CjtrUwFAxD82/mCWbtLsGjFIad0wIsod4zrTAEQ==} engines: {node: '>=0.4'} dev: true - /y18n/4.0.3: + /y18n@4.0.3: resolution: {integrity: sha512-JKhqTOwSrqNA1NY5lSztJ1GrBiUodLMmIZuLiDaMRJ+itFd+ABVE8XBjOvIWL+rSqNDC74LCSFmlb/U4UZ4hJQ==} dev: true - /y18n/5.0.8: + /y18n@5.0.8: resolution: {integrity: sha512-0pfFzegeDWJHJIAmTLRP2DwHjdF5s7jo9tuztdQxAhINCdvS+3nGINqPd00AphqJR/0LhANUS6/+7SCb98YOfA==} engines: {node: '>=10'} dev: true - /yallist/2.1.2: + /yallist@2.1.2: resolution: {integrity: sha512-ncTzHV7NvsQZkYe1DW7cbDLm0YpzHmZF5r/iyP3ZnQtMiJ+pjzisCiMNI+Sj+xQF5pXhSHxSB3uDbsBTzY/c2A==} dev: true - /yallist/3.1.1: + /yallist@3.1.1: resolution: {integrity: sha512-a4UGQaWPH59mOXUYnAG2ewncQS4i4F43Tv3JoAM+s2VDAmS9NsK8GpDMLrCHPksFT7h3K6TOoUNn2pb7RoXx4g==} - /yallist/4.0.0: + /yallist@4.0.0: resolution: {integrity: sha512-3wdGidZyq5PB084XLES5TpOSRA3wjXAlIWMhum2kRcv/41Sn2emQ0dycQW4uZXLejwKvg6EsvbdlVL+FYEct7A==} dev: true - /yaml-eslint-parser/1.2.2: + /yaml-eslint-parser@1.2.2: resolution: {integrity: sha512-pEwzfsKbTrB8G3xc/sN7aw1v6A6c/pKxLAkjclnAyo5g5qOh6eL9WGu0o3cSDQZKrTNk4KL4lQSwZW+nBkANEg==} engines: {node: ^14.17.0 || >=16.0.0} dependencies: @@ -22645,26 +24178,26 @@ packages: yaml: 2.3.1 dev: true - /yaml/1.10.2: + /yaml@1.10.2: resolution: {integrity: sha512-r3vXyErRCYJ7wg28yvBY5VSoAF8ZvlcW9/BwUzEtUsjvX/DKs24dIkuwjtuprwJJHsbyUbLApepYTR1BN4uHrg==} engines: {node: '>= 6'} - /yaml/2.3.1: + /yaml@2.3.1: resolution: {integrity: sha512-2eHWfjaoXgTBC2jNM1LRef62VQa0umtvRiDSk6HSzW7RvS5YtkabJrwYLLEKWBc8a5U2PTSCs+dJjUTJdlHsWQ==} engines: {node: '>= 14'} dev: true - /yargs-parser/20.2.9: + /yargs-parser@20.2.9: resolution: {integrity: sha512-y11nGElTIV+CT3Zv9t7VKl+Q3hTQoT9a1Qzezhhl6Rp21gJ/IVTW7Z3y9EWXhuUBC2Shnf+DX0antecpAwSP8w==} engines: {node: '>=10'} dev: true - /yargs-parser/21.1.1: + /yargs-parser@21.1.1: resolution: {integrity: sha512-tVpsJW7DdjecAiFpbIB1e3qxIQsE6NoPc5/eTdrbbIC4h0LVsWhnoa3g+m2HclBIujHzsxZ4VJVA+GUuc2/LBw==} engines: {node: '>=12'} dev: true - /yargs/16.2.0: + /yargs@16.2.0: resolution: {integrity: sha512-D1mvvtDG0L5ft/jGWkLpG1+m0eQxOfaBvTNELraWj22wSVUMWxZUvYgJYcKh6jGGIkJFhH4IZPQhR4TKpc8mBw==} engines: {node: '>=10'} dependencies: @@ -22677,7 +24210,7 @@ packages: yargs-parser: 20.2.9 dev: true - /yargs/17.7.1: + /yargs@17.7.1: resolution: {integrity: sha512-cwiTb08Xuv5fqF4AovYacTFNxk62th7LKJ6BL9IGUpTJrWoU7/7WdQGTP2SjKf1dUNBGzDd28p/Yfs/GI6JrLw==} engines: {node: '>=12'} dependencies: @@ -22690,7 +24223,7 @@ packages: yargs-parser: 21.1.1 dev: true - /yargs/17.7.2: + /yargs@17.7.2: resolution: {integrity: sha512-7dSzzRQ++CKnNI/krKnYRV7JKKPUXMEh61soaHKg9mrWEhzFWhFnxPxGl+69cD1Ou63C13NUPCnmIcrvqCuM6w==} engines: {node: '>=12'} dependencies: @@ -22703,38 +24236,38 @@ packages: yargs-parser: 21.1.1 dev: true - /yauzl/2.10.0: + /yauzl@2.10.0: resolution: {integrity: sha512-p4a9I6X6nu6IhoGmBqAcbJy1mlC4j27vEPZX9F4L4/vZT3Lyq1VkFHw/V/PUcB9Buo+DG3iHkT0x3Qya58zc3g==} dependencies: buffer-crc32: 0.2.13 fd-slicer: 1.1.0 dev: true - /yn/3.1.1: + /yn@3.1.1: resolution: {integrity: sha512-Ux4ygGWsu2c7isFWe8Yu1YluJmqVhxqK2cLXNQA5AcC3QfbGNpM7fu0Y8b/z16pXLnFxZYvWhd3fhBY9DLmC6Q==} engines: {node: '>=6'} dev: true - /yocto-queue/0.1.0: + /yocto-queue@0.1.0: resolution: {integrity: sha512-rVksvsnNCdJ/ohGc6xgPwyN8eheCxsiLM8mxuE/t/mOVqJewPuO1miLpTHQiRgTKCLexL4MeAFVagts7HmNZ2Q==} engines: {node: '>=10'} dev: true - /yocto-queue/1.0.0: + /yocto-queue@1.0.0: resolution: {integrity: sha512-9bnSc/HEW2uRy67wc+T8UwauLuPJVn28jb+GtJY16iiKWyvmYJRXVT4UamsAEGQfPohgr2q4Tq0sQbQlxTfi1g==} engines: {node: '>=12.20'} - /zen-observable-ts/1.2.5: + /zen-observable-ts@1.2.5: resolution: {integrity: sha512-QZWQekv6iB72Naeake9hS1KxHlotfRpe+WGNbNx5/ta+R3DNjVO2bswf63gXlWDcs+EMd7XY8HfVQyP1X6T4Zg==} dependencies: zen-observable: 0.8.15 dev: false - /zen-observable/0.8.15: + /zen-observable@0.8.15: resolution: {integrity: sha512-PQ2PC7R9rslx84ndNBZB/Dkv8V8fZEpk83RLgXtYd0fwUgEjseMn1Dgajh2x6S8QbZAFa9p2qVCEuYZNgve0dQ==} dev: false - /zip-stream/4.1.0: + /zip-stream@4.1.0: resolution: {integrity: sha512-zshzwQW7gG7hjpBlgeQP9RuyPGNxvJdzR8SUM3QhxCnLjWN2E7j3dOvpeDcQoETfHx0urRS7EtmVToql7YpU4A==} engines: {node: '>= 10'} dependencies: @@ -22743,7 +24276,7 @@ packages: readable-stream: 3.6.2 dev: true - /zustand/4.3.9_react@18.2.0: + /zustand@4.3.9(react@18.2.0): resolution: {integrity: sha512-Tat5r8jOMG1Vcsj8uldMyqYKC5IZvQif8zetmLHs9WoZlntTHmIoNM8TpLRY31ExncuUvUOXehd0kvahkuHjDw==} engines: {node: '>=12.7.0'} peerDependencies: @@ -22756,10 +24289,10 @@ packages: optional: true dependencies: react: 18.2.0 - use-sync-external-store: 1.2.0_react@18.2.0 + use-sync-external-store: 1.2.0(react@18.2.0) dev: true - /zwitch/1.0.5: + /zwitch@1.0.5: resolution: {integrity: sha512-V50KMwwzqJV0NpZIZFwfOD5/lyny3WlSzRiXgA0G7VUnRlqttta1L6UQIHzd6EuBY/cHGfwTIck7w1yH6Q5zUw==} dev: true From 4504d02e81d2765d65af79c7a4f28972ec6342cb Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Wed, 12 Jul 2023 11:17:29 +0200 Subject: [PATCH 64/87] chore: revert lockfile --- pnpm-lock.yaml | 9112 ++++++++++++++++++++++++++++-------------------- 1 file changed, 5365 insertions(+), 3747 deletions(-) diff --git a/pnpm-lock.yaml b/pnpm-lock.yaml index db66ac3aa42c..4815ef2bb0fc 100644 --- a/pnpm-lock.yaml +++ b/pnpm-lock.yaml @@ -14,22 +14,22 @@ importers: devDependencies: '@antfu/eslint-config': specifier: ^0.39.6 - version: 0.39.7(eslint@8.44.0)(typescript@5.1.6) + version: 0.39.6(eslint@8.44.0)(typescript@5.1.6) '@antfu/ni': specifier: ^0.21.4 version: 0.21.4 '@rollup/plugin-alias': specifier: ^5.0.0 - version: 5.0.0(rollup@3.26.2) + version: 5.0.0(rollup@3.26.0) '@rollup/plugin-commonjs': specifier: ^25.0.2 - version: 25.0.2(rollup@3.26.2) + version: 25.0.2(rollup@3.26.0) '@rollup/plugin-json': specifier: ^6.0.0 - version: 6.0.0(rollup@3.26.2) + version: 6.0.0(rollup@3.26.0) '@rollup/plugin-node-resolve': specifier: ^15.1.0 - version: 15.1.0(rollup@3.26.2) + version: 15.1.0(rollup@3.26.0) '@types/fs-extra': specifier: ^11.0.1 version: 11.0.1 @@ -98,16 +98,16 @@ importers: version: 5.0.1 rollup: specifier: ^3.26.0 - version: 3.26.2 + version: 3.26.0 rollup-plugin-dts: specifier: ^5.3.0 - version: 5.3.0(rollup@3.26.2)(typescript@5.1.6) + version: 5.3.0(rollup@3.26.0)(typescript@5.1.6) rollup-plugin-esbuild: specifier: ^5.0.0 - version: 5.0.0(esbuild@0.18.11)(rollup@3.26.2) + version: 5.0.0(esbuild@0.18.11)(rollup@3.26.0) rollup-plugin-license: specifier: ^3.0.1 - version: 3.0.1(rollup@3.26.2) + version: 3.0.1(rollup@3.26.0) simple-git-hooks: specifier: ^2.8.1 version: 2.8.1 @@ -122,7 +122,7 @@ importers: version: 5.1.6 vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:packages/vitest @@ -134,7 +134,7 @@ importers: version: 10.2.1(vue@3.3.4) jiti: specifier: ^1.18.2 - version: 1.19.1 + version: 1.18.2 vue: specifier: latest version: 3.3.4 @@ -144,7 +144,7 @@ importers: version: 1.1.18 '@unocss/reset': specifier: ^0.53.4 - version: 0.53.5 + version: 0.53.4 '@vite-pwa/assets-generator': specifier: ^0.0.3 version: 0.0.3 @@ -153,7 +153,7 @@ importers: version: 0.2.0(vite-plugin-pwa@0.16.4) '@vitejs/plugin-vue': specifier: latest - version: 4.2.3(vite@4.4.3)(vue@3.3.4) + version: 4.2.3(vite@4.3.9)(vue@3.3.4) esno: specifier: ^0.16.3 version: 0.16.3 @@ -168,19 +168,19 @@ importers: version: 4.7.1 unocss: specifier: ^0.53.4 - version: 0.53.5(postcss@8.4.25)(rollup@2.79.1)(vite@4.4.3) + version: 0.53.4(postcss@8.4.24)(rollup@2.79.1)(vite@4.3.9) unplugin-vue-components: specifier: ^0.25.1 version: 0.25.1(rollup@2.79.1)(vue@3.3.4) vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vite-plugin-pwa: specifier: ^0.16.4 - version: 0.16.4(vite@4.4.3)(workbox-build@7.0.0)(workbox-window@7.0.0) + version: 0.16.4(vite@4.3.9)(workbox-build@7.0.0)(workbox-window@7.0.0) vitepress: specifier: 1.0.0-beta.5 - version: 1.0.0-beta.5(@types/node@18.16.19)(search-insights@2.7.0) + version: 1.0.0-beta.5(@types/node@18.16.19)(search-insights@2.6.0) workbox-window: specifier: ^7.0.0 version: 7.0.0 @@ -192,7 +192,7 @@ importers: version: link:../../packages/ui vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -213,10 +213,10 @@ importers: version: 6.2.4 tsx: specifier: ^3.9.0 - version: 3.12.7 + version: 3.9.0 vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -225,17 +225,17 @@ importers: dependencies: '@rollup/plugin-graphql': specifier: ^1.1.0 - version: 1.1.0(graphql@16.7.1)(rollup@2.79.1) + version: 1.1.0(graphql@16.6.0)(rollup@2.79.1) graphql: specifier: ^16.5.0 - version: 16.7.1 + version: 16.6.0 devDependencies: '@vitest/ui': specifier: latest version: link:../../packages/ui vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -250,7 +250,7 @@ importers: version: 4.5.1(jest@27.5.1) vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -259,7 +259,7 @@ importers: dependencies: lit: specifier: ^2.2.5 - version: 2.7.6 + version: 2.3.1 devDependencies: '@vitest/ui': specifier: latest @@ -269,7 +269,7 @@ importers: version: 22.1.0 vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -278,7 +278,7 @@ importers: dependencies: '@vueuse/integrations': specifier: ^8.5.0 - version: 8.9.4(axios@0.26.1)(vue@3.3.4) + version: 8.9.4(axios@0.26.1)(vue@3.2.39) axios: specifier: ^0.26.1 version: 0.26.1 @@ -294,25 +294,25 @@ importers: version: 18.2.0 sweetalert2: specifier: ^11.6.16 - version: 11.7.16 + version: 11.6.16 vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest vue: specifier: ^3.2.39 - version: 3.3.4 + version: 3.2.39 zustand: specifier: ^4.1.1 - version: 4.3.9(react@18.2.0) + version: 4.1.1(react@18.2.0) examples/nextjs: dependencies: next: specifier: 12.1.5 - version: 12.1.5(@babel/core@7.22.8)(react-dom@18.0.0)(react@18.0.0) + version: 12.1.5(@babel/core@7.22.5)(react-dom@18.0.0)(react@18.0.0) react: specifier: 18.0.0 version: 18.0.0 @@ -322,7 +322,7 @@ importers: devDependencies: '@testing-library/react': specifier: ^13.2.0 - version: 13.4.0(react-dom@18.0.0)(react@18.0.0) + version: 13.3.0(react-dom@18.0.0)(react@18.0.0) '@types/node': specifier: latest version: 20.4.1 @@ -331,13 +331,13 @@ importers: version: 18.2.14 '@vitejs/plugin-react': specifier: latest - version: 4.0.3(vite@4.4.3) + version: 4.0.3(vite@4.3.9) jsdom: specifier: latest version: 22.1.0 typescript: specifier: ^4.8.4 - version: 4.9.5 + version: 4.8.4 vitest: specifier: workspace:* version: link:../../packages/vitest @@ -346,16 +346,16 @@ importers: devDependencies: '@playwright/test': specifier: ^1.28.0 - version: 1.36.0 + version: 1.28.0 '@vitest/ui': specifier: latest version: link:../../packages/ui playwright: specifier: ^1.28.0 - version: 1.36.0 + version: 1.28.0 vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -370,7 +370,7 @@ importers: version: 13.7.0 vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -383,13 +383,13 @@ importers: devDependencies: '@types/react': specifier: ^17.0.45 - version: 17.0.62 + version: 17.0.49 '@types/react-test-renderer': specifier: ^17.0.2 version: 17.0.2 '@vitejs/plugin-react': specifier: latest - version: 4.0.3(vite@4.4.3) + version: 4.0.3(vite@4.3.9) '@vitest/ui': specifier: latest version: link:../../packages/ui @@ -404,7 +404,7 @@ importers: version: 17.0.2(react@17.0.2) vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -420,16 +420,16 @@ importers: devDependencies: '@types/enzyme': specifier: ^3.10.12 - version: 3.10.13 + version: 3.10.12 '@types/react': specifier: ^17.0.45 - version: 17.0.62 + version: 17.0.49 '@types/react-dom': specifier: ^17.0.17 - version: 17.0.20 + version: 17.0.17 '@vitejs/plugin-react': specifier: latest - version: 4.0.3(vite@4.4.3) + version: 4.0.3(vite@4.3.9) '@vitest/ui': specifier: latest version: link:../../packages/ui @@ -444,7 +444,7 @@ importers: version: 20.0.3 vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -453,22 +453,22 @@ importers: dependencies: '@emotion/react': specifier: ^11.9.3 - version: 11.11.1(react@18.2.0) + version: 11.10.4(@babel/core@7.22.5)(react@18.2.0) '@emotion/styled': specifier: ^11.9.3 - version: 11.11.0(@emotion/react@11.11.1)(react@18.2.0) + version: 11.10.4(@babel/core@7.22.5)(@emotion/react@11.10.4)(react@18.2.0) '@mui/material': specifier: ^5.9.0 - version: 5.14.0(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(react-dom@18.2.0)(react@18.2.0) + version: 5.10.3(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(react-dom@18.2.0)(react@18.2.0) '@mui/x-date-pickers': specifier: 5.0.0-beta.0 - version: 5.0.0-beta.0(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(@mui/material@5.14.0)(@mui/system@5.14.0)(date-fns@2.30.0)(react-dom@18.2.0)(react@18.2.0) + version: 5.0.0-beta.0(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(@mui/material@5.10.3)(@mui/system@5.10.3)(date-fns@2.29.2)(react-dom@18.2.0)(react@18.2.0) history: specifier: ^5.3.0 version: 5.3.0 notistack: specifier: ^2.0.5 - version: 2.0.8(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(@mui/material@5.14.0)(react-dom@18.2.0)(react@18.2.0) + version: 2.0.5(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(@mui/material@5.10.3)(react-dom@18.2.0)(react@18.2.0) react: specifier: ^18.2.0 version: 18.2.0 @@ -477,10 +477,10 @@ importers: version: 18.2.0(react@18.2.0) react-router-dom: specifier: ^6.3.0 - version: 6.14.1(react-dom@18.2.0)(react@18.2.0) + version: 6.3.0(react-dom@18.2.0)(react@18.2.0) recharts: specifier: ^2.1.12 - version: 2.7.2(prop-types@15.8.1)(react-dom@18.2.0)(react@18.2.0) + version: 2.1.13(prop-types@15.8.1)(react-dom@18.2.0)(react@18.2.0) swr: specifier: ^1.3.0 version: 1.3.0(react@18.2.0) @@ -490,7 +490,7 @@ importers: version: 5.16.5 '@testing-library/react': specifier: ^13.3.0 - version: 13.4.0(react-dom@18.2.0)(react@18.2.0) + version: 13.3.0(react-dom@18.2.0)(react@18.2.0) '@testing-library/user-event': specifier: ^14.2.3 version: 14.4.3(@testing-library/dom@9.3.1) @@ -499,13 +499,13 @@ importers: version: link:../../packages/ui date-fns: specifier: ^2.28.0 - version: 2.30.0 + version: 2.29.2 jsdom: specifier: latest version: 22.1.0 vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -514,7 +514,7 @@ importers: dependencies: cross-fetch: specifier: ^3.1.5 - version: 3.1.8 + version: 3.1.5 react: specifier: ^17.0.2 version: 17.0.2 @@ -523,32 +523,32 @@ importers: version: 17.0.2(react@17.0.2) react-query: specifier: ^3.39.0 - version: 3.39.3(react-dom@17.0.2)(react@17.0.2) + version: 3.39.2(react-dom@17.0.2)(react@17.0.2) devDependencies: '@babel/core': specifier: ^7.18.2 - version: 7.22.8 + version: 7.18.13 '@storybook/addon-actions': specifier: ^6.5.5 - version: 6.5.16(react-dom@17.0.2)(react@17.0.2) + version: 6.5.10(react-dom@17.0.2)(react@17.0.2) '@storybook/addon-essentials': specifier: ^6.5.5 - version: 6.5.16(@babel/core@7.22.8)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5)(webpack@5.88.1) + version: 6.5.10(@babel/core@7.18.13)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4)(webpack@5.74.0) '@storybook/addon-links': specifier: ^6.5.5 - version: 6.5.16(react-dom@17.0.2)(react@17.0.2) + version: 6.5.10(react-dom@17.0.2)(react@17.0.2) '@storybook/builder-vite': specifier: ^0.1.35 - version: 0.1.41(@babel/core@7.22.8)(@storybook/core-common@6.5.16)(@storybook/node-logger@6.5.16)(@storybook/source-loader@6.5.16)(react@17.0.2)(typescript@4.9.5)(vite@4.4.3) + version: 0.1.41(@babel/core@7.18.13)(@storybook/core-common@6.5.10)(@storybook/node-logger@6.5.10)(@storybook/source-loader@6.5.10)(react@17.0.2)(typescript@4.8.4)(vite@4.3.9) '@storybook/react': specifier: ^6.5.5 - version: 6.5.16(@babel/core@7.22.8)(esbuild@0.18.11)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(require-from-string@2.0.2)(typescript@4.9.5) + version: 6.5.10(@babel/core@7.18.13)(esbuild@0.18.11)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(require-from-string@2.0.2)(typescript@4.8.4) '@storybook/testing-library': specifier: ^0.0.11 - version: 0.0.11 + version: 0.0.11(react-dom@17.0.2)(react@17.0.2) '@storybook/testing-react': specifier: ^1.3.0 - version: 1.3.0(@storybook/addons@6.5.16)(@storybook/client-api@6.5.16)(@storybook/preview-web@6.5.16)(@storybook/react@6.5.16)(react@17.0.2) + version: 1.3.0(@storybook/addons@6.5.10)(@storybook/client-api@6.5.10)(@storybook/preview-web@6.5.10)(@storybook/react@6.5.10)(react@17.0.2) '@testing-library/jest-dom': specifier: ^5.16.4 version: 5.16.5 @@ -557,34 +557,34 @@ importers: version: 12.1.5(react-dom@17.0.2)(react@17.0.2) '@types/react': specifier: ^17.0.45 - version: 17.0.62 + version: 17.0.49 '@types/react-dom': specifier: ^17.0.17 - version: 17.0.20 + version: 17.0.17 '@vitejs/plugin-react': specifier: ^4.0.1 - version: 4.0.3(vite@4.4.3) + version: 4.0.3(vite@4.3.9) '@vitest/ui': specifier: latest version: link:../../packages/ui babel-loader: specifier: ^8.2.5 - version: 8.3.0(@babel/core@7.22.8)(webpack@5.88.1) + version: 8.2.5(@babel/core@7.18.13)(webpack@5.74.0) jsdom: specifier: latest version: 22.1.0 msw: specifier: ^0.49.2 - version: 0.49.3(typescript@4.9.5) + version: 0.49.2(typescript@4.8.4) msw-storybook-addon: specifier: ^1.6.3 - version: 1.8.0(msw@0.49.3) + version: 1.6.3(msw@0.49.2)(react-dom@17.0.2)(react@17.0.2) typescript: specifier: ^4.8.4 - version: 4.9.5 + version: 4.8.4 vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -609,13 +609,13 @@ importers: version: 14.4.3(@testing-library/dom@9.3.1) '@types/react': specifier: ^18.0.24 - version: 18.2.14 + version: 18.0.25 '@types/react-dom': specifier: ^18.0.8 - version: 18.2.6 + version: 18.0.8 '@vitejs/plugin-react': specifier: latest - version: 4.0.3(vite@4.4.3) + version: 4.0.3(vite@4.3.9) '@vitest/coverage-v8': specifier: latest version: link:../../packages/coverage-v8 @@ -627,10 +627,10 @@ importers: version: 22.1.0 typescript: specifier: ^4.8.4 - version: 4.9.5 + version: 4.8.4 vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -639,7 +639,7 @@ importers: dependencies: '@apollo/client': specifier: ^3.6.6 - version: 3.7.17(graphql@16.7.1)(react-dom@17.0.2)(react@17.0.2) + version: 3.6.9(graphql@16.6.0)(react@17.0.2) react: specifier: ^17.0.2 version: 17.0.2 @@ -655,28 +655,28 @@ importers: version: 13.5.0(@testing-library/dom@9.3.1) '@types/react': specifier: ^17.0.45 - version: 17.0.62 + version: 17.0.49 '@types/react-dom': specifier: ^17.0.17 - version: 17.0.20 + version: 17.0.17 '@vitejs/plugin-react': specifier: ^4.0.1 - version: 4.0.3(vite@4.4.3) + version: 4.0.3(vite@4.3.9) '@vitest/ui': specifier: latest version: link:../../packages/ui cross-fetch: specifier: ^3.1.5 - version: 3.1.8 + version: 3.1.5 jsdom: specifier: latest version: 22.1.0 msw: specifier: ^1.2.1 - version: 1.2.2(typescript@5.1.6) + version: 1.2.1(typescript@5.1.6) vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -685,7 +685,7 @@ importers: devDependencies: '@vitejs/plugin-vue': specifier: latest - version: 4.2.3(vite@4.4.3)(vue@3.3.4) + version: 4.2.3(vite@4.3.9)(vue@3.3.4) '@vue/test-utils': specifier: latest version: 2.4.0(vue@3.3.4) @@ -694,10 +694,10 @@ importers: version: 22.1.0 vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vite-plugin-ruby: specifier: ^3.0.12 - version: 3.2.2(vite@4.4.3) + version: 3.1.2(vite@4.3.9) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -709,7 +709,7 @@ importers: dependencies: solid-js: specifier: ^1.4.3 - version: 1.7.8 + version: 1.5.2 devDependencies: '@testing-library/jest-dom': specifier: ^5.16.4 @@ -719,13 +719,13 @@ importers: version: 22.1.0 solid-testing-library: specifier: ^0.5.0 - version: 0.5.1(solid-js@1.7.8) + version: 0.5.0(solid-js@1.5.2) vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vite-plugin-solid: specifier: ^2.5.0 - version: 2.7.0(solid-js@1.7.8)(vite@4.4.3) + version: 2.5.0(solid-js@1.5.2)(vite@4.3.9) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -734,7 +734,7 @@ importers: devDependencies: '@sveltejs/vite-plugin-svelte': specifier: latest - version: 2.4.2(svelte@4.0.5)(vite@4.4.3) + version: 2.4.2(svelte@4.0.5)(vite@4.3.9) '@testing-library/svelte': specifier: ^4.0.3 version: 4.0.3(svelte@4.0.5) @@ -749,7 +749,7 @@ importers: version: 4.0.5 vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -758,31 +758,31 @@ importers: devDependencies: '@sveltejs/adapter-auto': specifier: ^2.1.0 - version: 2.1.0(@sveltejs/kit@1.22.2) + version: 2.1.0(@sveltejs/kit@1.20.2) '@sveltejs/kit': specifier: ^1.20.2 - version: 1.22.2(svelte@3.59.2)(vite@4.4.3) + version: 1.20.2(svelte@3.59.1)(vite@4.3.9) prettier: specifier: ^2.8.8 version: 2.8.8 prettier-plugin-svelte: specifier: ^2.10.1 - version: 2.10.1(prettier@2.8.8)(svelte@3.59.2) + version: 2.10.1(prettier@2.8.8)(svelte@3.59.1) svelte: specifier: ^3.59.1 - version: 3.59.2 + version: 3.59.1 svelte-check: specifier: ^3.4.3 - version: 3.4.6(svelte@3.59.2) + version: 3.4.3(svelte@3.59.1) tslib: specifier: ^2.5.3 - version: 2.6.0 + version: 2.5.3 typescript: specifier: ^5.1.3 - version: 5.1.6 + version: 5.1.3 vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -795,22 +795,22 @@ importers: devDependencies: '@vitejs/plugin-vue': specifier: latest - version: 4.2.3(vite@4.4.3)(vue@3.3.4) + version: 4.2.3(vite@4.3.9)(vue@3.3.4) '@vue/test-utils': specifier: ^2.0.2 - version: 2.4.0(vue@3.3.4) + version: 2.0.2(vue@3.3.4) jsdom: specifier: latest version: 22.1.0 unplugin-auto-import: specifier: latest - version: 0.16.6(@vueuse/core@10.2.1)(rollup@3.26.2) + version: 0.16.6(rollup@3.26.0) unplugin-vue-components: specifier: latest - version: 0.25.1(rollup@3.26.2)(vue@3.3.4) + version: 0.25.1(rollup@3.26.0)(vue@3.3.4) vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -823,16 +823,16 @@ importers: devDependencies: '@vitejs/plugin-vue': specifier: latest - version: 4.2.3(vite@4.4.3)(vue@3.3.4) + version: 4.2.3(vite@4.3.9)(vue@3.3.4) '@vue/test-utils': specifier: ^2.0.0 - version: 2.4.0(vue@3.3.4) + version: 2.0.0(vue@3.3.4) jsdom: specifier: latest version: 22.1.0 vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -841,10 +841,10 @@ importers: devDependencies: '@vitejs/plugin-vue': specifier: latest - version: 4.2.3(vite@4.4.3)(vue@3.3.4) + version: 4.2.3(vite@4.3.9)(vue@3.3.4) '@vitejs/plugin-vue-jsx': specifier: latest - version: 3.0.1(vite@4.4.3)(vue@3.3.4) + version: 3.0.1(vite@4.3.9)(vue@3.3.4) '@vue/test-utils': specifier: latest version: 2.4.0(vue@3.3.4) @@ -853,7 +853,7 @@ importers: version: 22.1.0 vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -865,26 +865,26 @@ importers: dependencies: vue: specifier: ^2.7.2 - version: 2.7.14 + version: 2.7.10 devDependencies: '@vitejs/plugin-vue2': specifier: ^1.1.2 - version: 1.1.2(vite@4.4.3)(vue@2.7.14) + version: 1.1.2(vite@4.3.9)(vue@2.7.10) '@vue/test-utils': specifier: ^1.3.0 - version: 1.3.6(vue-template-compiler@2.7.14)(vue@2.7.14) + version: 1.3.0(vue-template-compiler@2.7.10)(vue@2.7.10) jsdom: specifier: latest version: 22.1.0 vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest vue-template-compiler: specifier: ^2.7.2 - version: 2.7.14 + version: 2.7.10 packages/browser: dependencies: @@ -896,7 +896,7 @@ importers: version: 0.30.1 modern-node-polyfills: specifier: ^0.1.3 - version: 0.1.3(rollup@3.26.2) + version: 0.1.3(rollup@3.26.0) sirv: specifier: ^2.0.3 version: 2.0.3 @@ -921,7 +921,7 @@ importers: version: 3.1.0 rollup: specifier: ^3.26.0 - version: 3.26.2 + version: 3.26.0 vitest: specifier: workspace:* version: link:../vitest @@ -1068,7 +1068,7 @@ importers: version: 1.1.1 pretty-format: specifier: ^29.5.0 - version: 29.6.1 + version: 29.5.0 devDependencies: '@types/natural-compare': specifier: ^1.4.1 @@ -1118,7 +1118,7 @@ importers: version: 8.0.2 '@testing-library/cypress': specifier: ^9.0.0 - version: 9.0.0(cypress@12.17.1) + version: 9.0.0(cypress@12.16.0) '@types/codemirror': specifier: ^5.60.8 version: 5.60.8 @@ -1133,13 +1133,13 @@ importers: version: 8.5.5 '@unocss/reset': specifier: ^0.53.4 - version: 0.53.5 + version: 0.53.4 '@vitejs/plugin-vue': specifier: ^4.2.3 - version: 4.2.3(vite@4.4.3)(vue@3.3.4) + version: 4.2.3(vite@4.3.9)(vue@3.3.4) '@vitejs/plugin-vue-jsx': specifier: ^3.0.1 - version: 3.0.1(vite@4.4.3)(vue@3.3.4) + version: 3.0.1(vite@4.3.9)(vue@3.3.4) '@vitest/runner': specifier: workspace:* version: link:../runner @@ -1163,7 +1163,7 @@ importers: version: 0.1.2 cypress: specifier: ^12.16.0 - version: 12.17.1 + version: 12.16.0 d3-graph-controller: specifier: ^2.5.2 version: 2.5.2 @@ -1175,25 +1175,25 @@ importers: version: 3.1.5 unocss: specifier: ^0.53.4 - version: 0.53.5(postcss@8.4.25)(rollup@3.26.2)(vite@4.4.3) + version: 0.53.4(postcss@8.4.24)(rollup@3.26.0)(vite@4.3.9) unplugin-auto-import: specifier: ^0.16.4 - version: 0.16.6(@vueuse/core@10.2.1)(rollup@3.26.2) + version: 0.16.4(@vueuse/core@10.2.1)(rollup@3.26.0) unplugin-vue-components: specifier: ^0.25.1 - version: 0.25.1(rollup@3.26.2)(vue@3.3.4) + version: 0.25.1(rollup@3.26.0)(vue@3.3.4) vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vite-plugin-pages: specifier: ^0.31.0 - version: 0.31.0(vite@4.4.3) + version: 0.31.0(vite@4.3.9) vue: specifier: ^3.3.4 version: 3.3.4 vue-router: specifier: ^4.2.2 - version: 4.2.4(vue@3.3.4) + version: 4.2.2(vue@3.3.4) packages/utils: dependencies: @@ -1205,7 +1205,7 @@ importers: version: 2.3.6 pretty-format: specifier: ^29.5.0 - version: 29.6.1 + version: 29.5.0 packages/vite-node: dependencies: @@ -1226,7 +1226,7 @@ importers: version: 1.0.0 vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) devDependencies: '@jridgewell/trace-mapping': specifier: ^0.3.18 @@ -1248,7 +1248,7 @@ importers: version: 1.3.3 '@types/node': specifier: '*' - version: 20.4.1 + version: 18.7.13 '@vitest/browser': specifier: '*' version: link:../browser @@ -1272,7 +1272,7 @@ importers: version: link:../utils acorn: specifier: ^8.9.0 - version: 8.10.0 + version: 8.9.0 acorn-walk: specifier: ^8.2.0 version: 8.2.0 @@ -1311,7 +1311,7 @@ importers: version: 0.7.0 vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@20.4.1) + version: 4.3.9(@types/node@18.7.13) vite-node: specifier: workspace:* version: link:../vite-node @@ -1411,10 +1411,10 @@ importers: version: 1.0.3 playwright: specifier: ^1.35.1 - version: 1.36.0 + version: 1.35.1 pretty-format: specifier: ^29.5.0 - version: 29.6.1 + version: 29.5.0 prompts: specifier: ^2.4.2 version: 2.4.2 @@ -1476,7 +1476,7 @@ importers: version: link:../../packages/browser vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -1524,7 +1524,7 @@ importers: version: 9.0.13 '@types/prettier': specifier: ^2.6.1 - version: 2.7.3 + version: 2.7.0 fs-extra: specifier: ^10.1.0 version: 10.1.0 @@ -1539,7 +1539,7 @@ importers: version: 4.17.21 prettier: specifier: ^2.6.2 - version: 2.8.8 + version: 2.7.1 temp-dir: specifier: ^2.0.0 version: 2.0.0 @@ -1551,7 +1551,7 @@ importers: devDependencies: vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -1569,13 +1569,13 @@ importers: version: link:../../packages/utils acorn: specifier: ^8.8.2 - version: 8.10.0 + version: 8.8.2 tinyspy: specifier: ^1.0.2 - version: 1.1.1 + version: 1.0.2 url: specifier: ^0.11.0 - version: 0.11.1 + version: 0.11.0 vitest: specifier: workspace:* version: link:../../packages/vitest @@ -1587,7 +1587,7 @@ importers: version: 2.0.4 '@vitejs/plugin-vue': specifier: latest - version: 4.2.3(vite@4.4.3)(vue@3.3.4) + version: 4.2.3(vite@4.3.9)(vue@3.3.4) '@vitest/browser': specifier: workspace:* version: link:../../packages/browser @@ -1608,7 +1608,7 @@ importers: version: 3.2.0 vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -1623,7 +1623,7 @@ importers: devDependencies: jsdom: specifier: ^20.0.0 - version: 20.0.3 + version: 20.0.0 vitest: specifier: workspace:* version: link:../../packages/vitest @@ -1662,7 +1662,7 @@ importers: version: 10.1.1 vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -1696,7 +1696,7 @@ importers: version: link:../../packages/coverage-istanbul jsdom: specifier: ^21.0.0 - version: 21.1.2 + version: 21.0.0 vitest: specifier: workspace:* version: link:../../packages/vitest @@ -1705,7 +1705,7 @@ importers: devDependencies: vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -1776,7 +1776,7 @@ importers: version: link:reportPkg strip-ansi: specifier: ^7.0.1 - version: 7.1.0 + version: 7.0.1 vitest: specifier: workspace:* version: link:../../packages/vitest @@ -1797,7 +1797,7 @@ importers: devDependencies: vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -1845,10 +1845,10 @@ importers: version: 7.1.1 strip-ansi: specifier: ^7.0.1 - version: 7.1.0 + version: 7.0.1 vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -1861,10 +1861,10 @@ importers: devDependencies: typescript: specifier: ^4.8.4 - version: 4.9.5 + version: 4.8.4 vue-tsc: specifier: ^0.40.13 - version: 0.40.13(typescript@4.9.5) + version: 0.40.13(typescript@4.8.4) test/ui: devDependencies: @@ -1876,7 +1876,7 @@ importers: version: 10.1.0 playwright-chromium: specifier: ^1.27.0 - version: 1.36.0 + version: 1.30.0 vitest: specifier: workspace:* version: link:../../packages/vitest @@ -1894,7 +1894,7 @@ importers: devDependencies: pathe: specifier: ^1.1.0 - version: 1.1.1 + version: 1.1.0 vitest: specifier: workspace:* version: link:../../packages/vitest @@ -1924,7 +1924,7 @@ importers: version: link:../../packages/browser vite: specifier: ^4.3.9 - version: 4.4.3(@types/node@18.16.19) + version: 4.3.9(@types/node@18.16.19) vitest: specifier: workspace:* version: link:../../packages/vitest @@ -1963,34 +1963,34 @@ packages: engines: {node: '>=0.10.0'} dev: true - /@adobe/css-tools@4.2.0: - resolution: {integrity: sha512-E09FiIft46CmH5Qnjb0wsW54/YQd69LsxeKUOWawmws1XWvyFGURnAChH0mlr7YPFR1ofwvUQfcL0J3lMxXqPA==} + /@adobe/css-tools@4.0.1: + resolution: {integrity: sha512-+u76oB43nOHrF4DDWRLWDCtci7f3QJoEBigemIdIeTi1ODqjx6Tad9NCVnPRwewWlKkVab5PlK8DCtPTyX7S8g==} dev: true - /@algolia/autocomplete-core@1.9.3(algoliasearch@4.18.0)(search-insights@2.7.0): + /@algolia/autocomplete-core@1.9.3(algoliasearch@4.14.2)(search-insights@2.6.0): resolution: {integrity: sha512-009HdfugtGCdC4JdXUbVJClA0q0zh24yyePn+KUGk3rP7j8FEe/m5Yo/z65gn6nP/cM39PxpzqKrL7A6fP6PPw==} dependencies: - '@algolia/autocomplete-plugin-algolia-insights': 1.9.3(algoliasearch@4.18.0)(search-insights@2.7.0) - '@algolia/autocomplete-shared': 1.9.3(algoliasearch@4.18.0) + '@algolia/autocomplete-plugin-algolia-insights': 1.9.3(algoliasearch@4.14.2)(search-insights@2.6.0) + '@algolia/autocomplete-shared': 1.9.3(algoliasearch@4.14.2) transitivePeerDependencies: - '@algolia/client-search' - algoliasearch - search-insights dev: true - /@algolia/autocomplete-plugin-algolia-insights@1.9.3(algoliasearch@4.18.0)(search-insights@2.7.0): + /@algolia/autocomplete-plugin-algolia-insights@1.9.3(algoliasearch@4.14.2)(search-insights@2.6.0): resolution: {integrity: sha512-a/yTUkcO/Vyy+JffmAnTWbr4/90cLzw+CC3bRbhnULr/EM0fGNvM13oQQ14f2moLMcVDyAx/leczLlAOovhSZg==} peerDependencies: search-insights: '>= 1 < 3' dependencies: - '@algolia/autocomplete-shared': 1.9.3(algoliasearch@4.18.0) - search-insights: 2.7.0 + '@algolia/autocomplete-shared': 1.9.3(algoliasearch@4.14.2) + search-insights: 2.6.0 transitivePeerDependencies: - '@algolia/client-search' - algoliasearch dev: true - /@algolia/autocomplete-preset-algolia@1.9.3(algoliasearch@4.18.0): + /@algolia/autocomplete-preset-algolia@1.9.3(algoliasearch@4.14.2): resolution: {integrity: sha512-d4qlt6YmrLMYy95n5TB52wtNDr6EgAIPH81dvvvW8UmuWRgxEtY0NJiPwl/h95JtG2vmRM804M0DSwMCNZlzRA==} peerDependencies: '@algolia/client-search': '>= 4.9.1 < 6' @@ -1999,11 +1999,11 @@ packages: '@algolia/client-search': optional: true dependencies: - '@algolia/autocomplete-shared': 1.9.3(algoliasearch@4.18.0) - algoliasearch: 4.18.0 + '@algolia/autocomplete-shared': 1.9.3(algoliasearch@4.14.2) + algoliasearch: 4.14.2 dev: true - /@algolia/autocomplete-shared@1.9.3(algoliasearch@4.18.0): + /@algolia/autocomplete-shared@1.9.3(algoliasearch@4.14.2): resolution: {integrity: sha512-Wnm9E4Ye6Rl6sTTqjoymD+l8DjSTHsHboVRYrKgEt8Q7UHm9nYbqhN/i0fhUYA3OAEH7WA8x3jfpnmJm3rKvaQ==} peerDependencies: '@algolia/client-search': '>= 4.9.1 < 6' @@ -2012,123 +2012,130 @@ packages: '@algolia/client-search': optional: true dependencies: - algoliasearch: 4.18.0 + algoliasearch: 4.14.2 dev: true - /@algolia/cache-browser-local-storage@4.18.0: - resolution: {integrity: sha512-rUAs49NLlO8LVLgGzM4cLkw8NJLKguQLgvFmBEe3DyzlinoqxzQMHfKZs6TSq4LZfw/z8qHvRo8NcTAAUJQLcw==} + /@algolia/cache-browser-local-storage@4.14.2: + resolution: {integrity: sha512-FRweBkK/ywO+GKYfAWbrepewQsPTIEirhi1BdykX9mxvBPtGNKccYAxvGdDCumU1jL4r3cayio4psfzKMejBlA==} dependencies: - '@algolia/cache-common': 4.18.0 + '@algolia/cache-common': 4.14.2 dev: true - /@algolia/cache-common@4.18.0: - resolution: {integrity: sha512-BmxsicMR4doGbeEXQu8yqiGmiyvpNvejYJtQ7rvzttEAMxOPoWEHrWyzBQw4x7LrBY9pMrgv4ZlUaF8PGzewHg==} + /@algolia/cache-common@4.14.2: + resolution: {integrity: sha512-SbvAlG9VqNanCErr44q6lEKD2qoK4XtFNx9Qn8FK26ePCI8I9yU7pYB+eM/cZdS9SzQCRJBbHUumVr4bsQ4uxg==} dev: true - /@algolia/cache-in-memory@4.18.0: - resolution: {integrity: sha512-evD4dA1nd5HbFdufBxLqlJoob7E2ozlqJZuV3YlirNx5Na4q1LckIuzjNYZs2ddLzuTc/Xd5O3Ibf7OwPskHxw==} + /@algolia/cache-in-memory@4.14.2: + resolution: {integrity: sha512-HrOukWoop9XB/VFojPv1R5SVXowgI56T9pmezd/djh2JnVN/vXswhXV51RKy4nCpqxyHt/aGFSq2qkDvj6KiuQ==} dependencies: - '@algolia/cache-common': 4.18.0 + '@algolia/cache-common': 4.14.2 dev: true - /@algolia/client-account@4.18.0: - resolution: {integrity: sha512-XsDnlROr3+Z1yjxBJjUMfMazi1V155kVdte6496atvBgOEtwCzTs3A+qdhfsAnGUvaYfBrBkL0ThnhMIBCGcew==} + /@algolia/client-account@4.14.2: + resolution: {integrity: sha512-WHtriQqGyibbb/Rx71YY43T0cXqyelEU0lB2QMBRXvD2X0iyeGl4qMxocgEIcbHyK7uqE7hKgjT8aBrHqhgc1w==} dependencies: - '@algolia/client-common': 4.18.0 - '@algolia/client-search': 4.18.0 - '@algolia/transporter': 4.18.0 + '@algolia/client-common': 4.14.2 + '@algolia/client-search': 4.14.2 + '@algolia/transporter': 4.14.2 dev: true - /@algolia/client-analytics@4.18.0: - resolution: {integrity: sha512-chEUSN4ReqU7uRQ1C8kDm0EiPE+eJeAXiWcBwLhEynfNuTfawN9P93rSZktj7gmExz0C8XmkbBU19IQ05wCNrQ==} + /@algolia/client-analytics@4.14.2: + resolution: {integrity: sha512-yBvBv2mw+HX5a+aeR0dkvUbFZsiC4FKSnfqk9rrfX+QrlNOKEhCG0tJzjiOggRW4EcNqRmaTULIYvIzQVL2KYQ==} dependencies: - '@algolia/client-common': 4.18.0 - '@algolia/client-search': 4.18.0 - '@algolia/requester-common': 4.18.0 - '@algolia/transporter': 4.18.0 + '@algolia/client-common': 4.14.2 + '@algolia/client-search': 4.14.2 + '@algolia/requester-common': 4.14.2 + '@algolia/transporter': 4.14.2 dev: true - /@algolia/client-common@4.18.0: - resolution: {integrity: sha512-7N+soJFP4wn8tjTr3MSUT/U+4xVXbz4jmeRfWfVAzdAbxLAQbHa0o/POSdTvQ8/02DjCLelloZ1bb4ZFVKg7Wg==} + /@algolia/client-common@4.14.2: + resolution: {integrity: sha512-43o4fslNLcktgtDMVaT5XwlzsDPzlqvqesRi4MjQz2x4/Sxm7zYg5LRYFol1BIhG6EwxKvSUq8HcC/KxJu3J0Q==} dependencies: - '@algolia/requester-common': 4.18.0 - '@algolia/transporter': 4.18.0 + '@algolia/requester-common': 4.14.2 + '@algolia/transporter': 4.14.2 dev: true - /@algolia/client-personalization@4.18.0: - resolution: {integrity: sha512-+PeCjODbxtamHcPl+couXMeHEefpUpr7IHftj4Y4Nia1hj8gGq4VlIcqhToAw8YjLeCTfOR7r7xtj3pJcYdP8A==} + /@algolia/client-personalization@4.14.2: + resolution: {integrity: sha512-ACCoLi0cL8CBZ1W/2juehSltrw2iqsQBnfiu/Rbl9W2yE6o2ZUb97+sqN/jBqYNQBS+o0ekTMKNkQjHHAcEXNw==} dependencies: - '@algolia/client-common': 4.18.0 - '@algolia/requester-common': 4.18.0 - '@algolia/transporter': 4.18.0 + '@algolia/client-common': 4.14.2 + '@algolia/requester-common': 4.14.2 + '@algolia/transporter': 4.14.2 dev: true - /@algolia/client-search@4.18.0: - resolution: {integrity: sha512-F9xzQXTjm6UuZtnsLIew6KSraXQ0AzS/Ee+OD+mQbtcA/K1sg89tqb8TkwjtiYZ0oij13u3EapB3gPZwm+1Y6g==} + /@algolia/client-search@4.14.2: + resolution: {integrity: sha512-L5zScdOmcZ6NGiVbLKTvP02UbxZ0njd5Vq9nJAmPFtjffUSOGEp11BmD2oMJ5QvARgx2XbX4KzTTNS5ECYIMWw==} dependencies: - '@algolia/client-common': 4.18.0 - '@algolia/requester-common': 4.18.0 - '@algolia/transporter': 4.18.0 + '@algolia/client-common': 4.14.2 + '@algolia/requester-common': 4.14.2 + '@algolia/transporter': 4.14.2 dev: true - /@algolia/logger-common@4.18.0: - resolution: {integrity: sha512-46etYgSlkoKepkMSyaoriSn2JDgcrpc/nkOgou/lm0y17GuMl9oYZxwKKTSviLKI5Irk9nSKGwnBTQYwXOYdRg==} + /@algolia/logger-common@4.14.2: + resolution: {integrity: sha512-/JGlYvdV++IcMHBnVFsqEisTiOeEr6cUJtpjz8zc0A9c31JrtLm318Njc72p14Pnkw3A/5lHHh+QxpJ6WFTmsA==} dev: true - /@algolia/logger-console@4.18.0: - resolution: {integrity: sha512-3P3VUYMl9CyJbi/UU1uUNlf6Z8N2ltW3Oqhq/nR7vH0CjWv32YROq3iGWGxB2xt3aXobdUPXs6P0tHSKRmNA6g==} + /@algolia/logger-console@4.14.2: + resolution: {integrity: sha512-8S2PlpdshbkwlLCSAB5f8c91xyc84VM9Ar9EdfE9UmX+NrKNYnWR1maXXVDQQoto07G1Ol/tYFnFVhUZq0xV/g==} dependencies: - '@algolia/logger-common': 4.18.0 + '@algolia/logger-common': 4.14.2 dev: true - /@algolia/requester-browser-xhr@4.18.0: - resolution: {integrity: sha512-/AcWHOBub2U4TE/bPi4Gz1XfuLK6/7dj4HJG+Z2SfQoS1RjNLshZclU3OoKIkFp8D2NC7+BNsPvr9cPLyW8nyQ==} + /@algolia/requester-browser-xhr@4.14.2: + resolution: {integrity: sha512-CEh//xYz/WfxHFh7pcMjQNWgpl4wFB85lUMRyVwaDPibNzQRVcV33YS+63fShFWc2+42YEipFGH2iPzlpszmDw==} dependencies: - '@algolia/requester-common': 4.18.0 + '@algolia/requester-common': 4.14.2 dev: true - /@algolia/requester-common@4.18.0: - resolution: {integrity: sha512-xlT8R1qYNRBCi1IYLsx7uhftzdfsLPDGudeQs+xvYB4sQ3ya7+ppolB/8m/a4F2gCkEO6oxpp5AGemM7kD27jA==} + /@algolia/requester-common@4.14.2: + resolution: {integrity: sha512-73YQsBOKa5fvVV3My7iZHu1sUqmjjfs9TteFWwPwDmnad7T0VTCopttcsM3OjLxZFtBnX61Xxl2T2gmG2O4ehg==} dev: true - /@algolia/requester-node-http@4.18.0: - resolution: {integrity: sha512-TGfwj9aeTVgOUhn5XrqBhwUhUUDnGIKlI0kCBMdR58XfXcfdwomka+CPIgThRbfYw04oQr31A6/95ZH2QVJ9UQ==} + /@algolia/requester-node-http@4.14.2: + resolution: {integrity: sha512-oDbb02kd1o5GTEld4pETlPZLY0e+gOSWjWMJHWTgDXbv9rm/o2cF7japO6Vj1ENnrqWvLBmW1OzV9g6FUFhFXg==} dependencies: - '@algolia/requester-common': 4.18.0 + '@algolia/requester-common': 4.14.2 dev: true - /@algolia/transporter@4.18.0: - resolution: {integrity: sha512-xbw3YRUGtXQNG1geYFEDDuFLZt4Z8YNKbamHPkzr3rWc6qp4/BqEeXcI2u/P/oMq2yxtXgMxrCxOPA8lyIe5jw==} + /@algolia/transporter@4.14.2: + resolution: {integrity: sha512-t89dfQb2T9MFQHidjHcfhh6iGMNwvuKUvojAj+JsrHAGbuSy7yE4BylhLX6R0Q1xYRoC4Vvv+O5qIw/LdnQfsQ==} dependencies: - '@algolia/cache-common': 4.18.0 - '@algolia/logger-common': 4.18.0 - '@algolia/requester-common': 4.18.0 + '@algolia/cache-common': 4.14.2 + '@algolia/logger-common': 4.14.2 + '@algolia/requester-common': 4.14.2 dev: true + /@ampproject/remapping@2.2.0: + resolution: {integrity: sha512-qRmjj8nj9qmLTQXXmaR1cck3UXSRMPrbsLJAasZpF+t3riI71BXed5ebIOYwQntykeZuhjsdweEc9BxH5Jc26w==} + engines: {node: '>=6.0.0'} + dependencies: + '@jridgewell/gen-mapping': 0.1.1 + '@jridgewell/trace-mapping': 0.3.18 + /@ampproject/remapping@2.2.1: resolution: {integrity: sha512-lFMjJTrFL3j7L9yBxwYfCq2k6qqwHyzuUl/XBnif78PWTJYyL/dfowQHWE3sp6U6ZzqWiiIZnpTMO96zhkjwtg==} engines: {node: '>=6.0.0'} dependencies: - '@jridgewell/gen-mapping': 0.3.3 + '@jridgewell/gen-mapping': 0.3.2 '@jridgewell/trace-mapping': 0.3.18 - /@antfu/eslint-config-basic@0.39.7(@typescript-eslint/eslint-plugin@5.62.0)(@typescript-eslint/parser@5.62.0)(eslint@8.44.0)(typescript@5.1.6): - resolution: {integrity: sha512-R7usUebEr+T5EcZ8sMy2/naNU5etpXtzC34wHCEBETlmYVGQpkYcpSztDy67T3B3Ywj95VsgGLDjW77fANW/LQ==} + /@antfu/eslint-config-basic@0.39.6(@typescript-eslint/eslint-plugin@5.60.0)(@typescript-eslint/parser@5.60.0)(eslint@8.44.0)(typescript@5.1.6): + resolution: {integrity: sha512-vFy/qk6sCstCJmgj01tVtuC+pZ5PseJkuZueD2mtzWwFLewOMeeDn1UbyOWQEiLtmW7o6aqhikgp3VOHgxzFxw==} peerDependencies: eslint: '>=7.4.0' dependencies: eslint: 8.44.0 - eslint-plugin-antfu: 0.39.7(eslint@8.44.0)(typescript@5.1.6) + eslint-plugin-antfu: 0.39.6(eslint@8.44.0)(typescript@5.1.6) eslint-plugin-eslint-comments: 3.2.0(eslint@8.44.0) eslint-plugin-html: 7.1.0 - eslint-plugin-import: /eslint-plugin-i@2.27.5-3(@typescript-eslint/parser@5.62.0)(eslint@8.44.0) + eslint-plugin-import: /eslint-plugin-i@2.27.5-3(@typescript-eslint/parser@5.60.0)(eslint@8.44.0) eslint-plugin-jsonc: 2.9.0(eslint@8.44.0) eslint-plugin-markdown: 3.0.0(eslint@8.44.0) - eslint-plugin-n: 16.0.1(eslint@8.44.0) + eslint-plugin-n: 16.0.0(eslint@8.44.0) eslint-plugin-no-only-tests: 3.1.0 eslint-plugin-promise: 6.1.1(eslint@8.44.0) eslint-plugin-unicorn: 47.0.0(eslint@8.44.0) - eslint-plugin-unused-imports: 2.0.0(@typescript-eslint/eslint-plugin@5.62.0)(eslint@8.44.0) + eslint-plugin-unused-imports: 2.0.0(@typescript-eslint/eslint-plugin@5.60.0)(eslint@8.44.0) eslint-plugin-yml: 1.8.0(eslint@8.44.0) jsonc-eslint-parser: 2.3.0 yaml-eslint-parser: 1.2.2 @@ -2141,17 +2148,17 @@ packages: - typescript dev: true - /@antfu/eslint-config-ts@0.39.7(eslint@8.44.0)(typescript@5.1.6): - resolution: {integrity: sha512-EaeR9VeCGFMNUr4mf8DBJa82UfZNM9o2fc27sVzX3ORDEjf6wtsc2YVVBlKlhAoZBNTj2qtX2DeCNC38N/j+Lg==} + /@antfu/eslint-config-ts@0.39.6(eslint@8.44.0)(typescript@5.1.6): + resolution: {integrity: sha512-ri1WebgsBSfEFftMgRAmM4AxqN37sP4Ft+OdaXJ9AHSh1EvJCzGOgVARcEEDvSVDFRoRuTTg99dMXwfwsYdiPA==} peerDependencies: eslint: '>=7.4.0' typescript: '>=3.9' dependencies: - '@antfu/eslint-config-basic': 0.39.7(@typescript-eslint/eslint-plugin@5.62.0)(@typescript-eslint/parser@5.62.0)(eslint@8.44.0)(typescript@5.1.6) - '@typescript-eslint/eslint-plugin': 5.62.0(@typescript-eslint/parser@5.62.0)(eslint@8.44.0)(typescript@5.1.6) - '@typescript-eslint/parser': 5.62.0(eslint@8.44.0)(typescript@5.1.6) + '@antfu/eslint-config-basic': 0.39.6(@typescript-eslint/eslint-plugin@5.60.0)(@typescript-eslint/parser@5.60.0)(eslint@8.44.0)(typescript@5.1.6) + '@typescript-eslint/eslint-plugin': 5.60.0(@typescript-eslint/parser@5.60.0)(eslint@8.44.0)(typescript@5.1.6) + '@typescript-eslint/parser': 5.60.0(eslint@8.44.0)(typescript@5.1.6) eslint: 8.44.0 - eslint-plugin-jest: 27.2.2(@typescript-eslint/eslint-plugin@5.62.0)(eslint@8.44.0)(typescript@5.1.6) + eslint-plugin-jest: 27.2.1(@typescript-eslint/eslint-plugin@5.60.0)(eslint@8.44.0)(typescript@5.1.6) typescript: 5.1.6 transitivePeerDependencies: - eslint-import-resolver-typescript @@ -2160,15 +2167,15 @@ packages: - supports-color dev: true - /@antfu/eslint-config-vue@0.39.7(@typescript-eslint/eslint-plugin@5.62.0)(@typescript-eslint/parser@5.62.0)(eslint@8.44.0)(typescript@5.1.6): - resolution: {integrity: sha512-YAhU+88cu9c/TFY4VIs4MhOzaxK7ZPiT7DVs+4PpQvTEOOV17dZipp7HGJHfBK/5MtscCm7FGWuo5TamN5gydw==} + /@antfu/eslint-config-vue@0.39.6(@typescript-eslint/eslint-plugin@5.60.0)(@typescript-eslint/parser@5.60.0)(eslint@8.44.0)(typescript@5.1.6): + resolution: {integrity: sha512-+GOo5No7IWnjMK2fZ9crhdJrsUa4C13aiT28hlZpWLg8Chd9QqyqBN8O4bBYnGhifoDnBWHVyDMp2rlAiNLI/g==} peerDependencies: eslint: '>=7.4.0' dependencies: - '@antfu/eslint-config-basic': 0.39.7(@typescript-eslint/eslint-plugin@5.62.0)(@typescript-eslint/parser@5.62.0)(eslint@8.44.0)(typescript@5.1.6) - '@antfu/eslint-config-ts': 0.39.7(eslint@8.44.0)(typescript@5.1.6) + '@antfu/eslint-config-basic': 0.39.6(@typescript-eslint/eslint-plugin@5.60.0)(@typescript-eslint/parser@5.60.0)(eslint@8.44.0)(typescript@5.1.6) + '@antfu/eslint-config-ts': 0.39.6(eslint@8.44.0)(typescript@5.1.6) eslint: 8.44.0 - eslint-plugin-vue: 9.15.1(eslint@8.44.0) + eslint-plugin-vue: 9.15.0(eslint@8.44.0) local-pkg: 0.4.3 transitivePeerDependencies: - '@typescript-eslint/eslint-plugin' @@ -2180,23 +2187,23 @@ packages: - typescript dev: true - /@antfu/eslint-config@0.39.7(eslint@8.44.0)(typescript@5.1.6): - resolution: {integrity: sha512-xztW6zdjHz+yIaw25kn97e3s6vGtAI43YF6wdooioUJPmOXsjSYY9lRh2k3RaHzQALKbNRUjZO8KdjOOLasg1g==} + /@antfu/eslint-config@0.39.6(eslint@8.44.0)(typescript@5.1.6): + resolution: {integrity: sha512-RlSWVhqSF7L5w8+ZUB8iR2GF+pZjyE0GstzaecR5xFnv8BJOXeNW1f594ODbznkytaLixJZd/eJZacRK/yfWrA==} peerDependencies: eslint: '>=7.4.0' dependencies: - '@antfu/eslint-config-vue': 0.39.7(@typescript-eslint/eslint-plugin@5.62.0)(@typescript-eslint/parser@5.62.0)(eslint@8.44.0)(typescript@5.1.6) - '@typescript-eslint/eslint-plugin': 5.62.0(@typescript-eslint/parser@5.62.0)(eslint@8.44.0)(typescript@5.1.6) - '@typescript-eslint/parser': 5.62.0(eslint@8.44.0)(typescript@5.1.6) + '@antfu/eslint-config-vue': 0.39.6(@typescript-eslint/eslint-plugin@5.60.0)(@typescript-eslint/parser@5.60.0)(eslint@8.44.0)(typescript@5.1.6) + '@typescript-eslint/eslint-plugin': 5.60.0(@typescript-eslint/parser@5.60.0)(eslint@8.44.0)(typescript@5.1.6) + '@typescript-eslint/parser': 5.60.0(eslint@8.44.0)(typescript@5.1.6) eslint: 8.44.0 eslint-plugin-eslint-comments: 3.2.0(eslint@8.44.0) eslint-plugin-html: 7.1.0 - eslint-plugin-import: /eslint-plugin-i@2.27.5-3(@typescript-eslint/parser@5.62.0)(eslint@8.44.0) + eslint-plugin-import: /eslint-plugin-i@2.27.5-3(@typescript-eslint/parser@5.60.0)(eslint@8.44.0) eslint-plugin-jsonc: 2.9.0(eslint@8.44.0) - eslint-plugin-n: 16.0.1(eslint@8.44.0) + eslint-plugin-n: 16.0.0(eslint@8.44.0) eslint-plugin-promise: 6.1.1(eslint@8.44.0) eslint-plugin-unicorn: 47.0.0(eslint@8.44.0) - eslint-plugin-vue: 9.15.1(eslint@8.44.0) + eslint-plugin-vue: 9.15.0(eslint@8.44.0) eslint-plugin-yml: 1.8.0(eslint@8.44.0) jsonc-eslint-parser: 2.3.0 yaml-eslint-parser: 1.2.2 @@ -2220,66 +2227,71 @@ packages: hasBin: true dev: true + /@antfu/utils@0.7.4: + resolution: {integrity: sha512-qe8Nmh9rYI/HIspLSTwtbMFPj6dISG6+dJnOguTlPNXtCvS2uezdxscVBb7/3DrmNbQK49TDqpkSQ1chbRGdpQ==} + dev: true + /@antfu/utils@0.7.5: resolution: {integrity: sha512-dlR6LdS+0SzOAPx/TPRhnoi7hE251OVeT2Snw0RguNbBSbjUHdWr0l3vcUUDg26rEysT89kCbtw1lVorBXLLCg==} dev: true - /@apideck/better-ajv-errors@0.3.6(ajv@8.12.0): + /@apideck/better-ajv-errors@0.3.6(ajv@8.11.0): resolution: {integrity: sha512-P+ZygBLZtkp0qqOAJJVX4oX/sFo5JR3eBWwwuqHHhK0GIgQOKWrAfiAaWX0aArHkRWHMuggFEgAZNxVPwPZYaA==} engines: {node: '>=10'} peerDependencies: ajv: '>=8' dependencies: - ajv: 8.12.0 + ajv: 8.11.0 json-schema: 0.4.0 jsonpointer: 5.0.1 leven: 3.1.0 dev: true - /@apollo/client@3.7.17(graphql@16.7.1)(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-0EErSHEtKPNl5wgWikHJbKFAzJ/k11O0WO2QyqZSHpdxdAnw7UWHY4YiLbHCFG7lhrD+NTQ3Z/H9Jn4rcikoJA==} + /@apollo/client@3.6.9(graphql@16.6.0)(react@17.0.2): + resolution: {integrity: sha512-Y1yu8qa2YeaCUBVuw08x8NHenFi0sw2I3KCu7Kw9mDSu86HmmtHJkCAifKVrN2iPgDTW/BbP3EpSV8/EQCcxZA==} peerDependencies: graphql: ^14.0.0 || ^15.0.0 || ^16.0.0 graphql-ws: ^5.5.5 react: ^16.8.0 || ^17.0.0 || ^18.0.0 - react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 subscriptions-transport-ws: ^0.9.0 || ^0.11.0 peerDependenciesMeta: graphql-ws: optional: true react: optional: true - react-dom: - optional: true subscriptions-transport-ws: optional: true dependencies: - '@graphql-typed-document-node/core': 3.2.0(graphql@16.7.1) - '@wry/context': 0.7.3 - '@wry/equality': 0.5.6 - '@wry/trie': 0.4.3 - graphql: 16.7.1 - graphql-tag: 2.12.6(graphql@16.7.1) + '@graphql-typed-document-node/core': 3.1.1(graphql@16.6.0) + '@wry/context': 0.6.1 + '@wry/equality': 0.5.3 + '@wry/trie': 0.3.2 + graphql: 16.6.0 + graphql-tag: 2.12.6(graphql@16.6.0) hoist-non-react-statics: 3.3.2 - optimism: 0.16.2 + optimism: 0.16.1 prop-types: 15.8.1 react: 17.0.2 - react-dom: 17.0.2(react@17.0.2) - response-iterator: 0.2.6 symbol-observable: 4.0.0 ts-invariant: 0.10.3 - tslib: 2.6.0 + tslib: 2.4.0 zen-observable-ts: 1.2.5 dev: false + /@babel/code-frame@7.18.6: + resolution: {integrity: sha512-TDCmlK5eOvH+eH7cdAFlNXeVJqWIQ7gW9tY1GJIpUtFb6CmjVyq2VM3u71bOyR8CRihcCgMUYoDNyLXao3+70Q==} + engines: {node: '>=6.9.0'} + dependencies: + '@babel/highlight': 7.22.5 + /@babel/code-frame@7.22.5: resolution: {integrity: sha512-Xmwn266vad+6DAqEB2A6V/CcZVp62BbwVmcOJc2RPuwih1kw02TjQvWVWlcKGbBPd+8/0V5DEkOcizRGYsspYQ==} engines: {node: '>=6.9.0'} dependencies: '@babel/highlight': 7.22.5 - /@babel/compat-data@7.22.6: - resolution: {integrity: sha512-29tfsWTq2Ftu7MXmimyC0C5FDZv5DYxOZkh3XD3+QW4V/BYuv/LyEsjj3c0hqedEaDt6DBfDvexMKU8YevdqFg==} + /@babel/compat-data@7.22.5: + resolution: {integrity: sha512-4Jc/YuIaYqKnDDz892kPIledykKg12Aw1PYX5i/TY28anJtacvM1Rrr8wbieB9GfEJwlzqT0hUEao0CxEebiDA==} engines: {node: '>=6.9.0'} /@babel/core@7.12.9: @@ -2287,12 +2299,12 @@ packages: engines: {node: '>=6.9.0'} dependencies: '@babel/code-frame': 7.22.5 - '@babel/generator': 7.22.7 + '@babel/generator': 7.22.5 '@babel/helper-module-transforms': 7.22.5 - '@babel/helpers': 7.22.6 - '@babel/parser': 7.22.7 + '@babel/helpers': 7.22.5 + '@babel/parser': 7.22.5 '@babel/template': 7.22.5 - '@babel/traverse': 7.22.8 + '@babel/traverse': 7.22.5 '@babel/types': 7.22.5 convert-source-map: 1.9.0 debug: 4.3.4(supports-color@8.1.1) @@ -2300,131 +2312,289 @@ packages: json5: 2.2.3 lodash: 4.17.21 resolve: 1.22.2 - semver: 5.7.2 + semver: 5.7.1 source-map: 0.5.7 transitivePeerDependencies: - supports-color dev: true - /@babel/core@7.22.8: - resolution: {integrity: sha512-75+KxFB4CZqYRXjx4NlR4J7yGvKumBuZTmV4NV6v09dVXXkuYVYLT68N6HCzLvfJ+fWCxQsntNzKwwIXL4bHnw==} + /@babel/core@7.18.13: + resolution: {integrity: sha512-ZisbOvRRusFktksHSG6pjj1CSvkPkcZq/KHD45LAkVP/oiHJkNBZWfpvlLmX8OtHDG8IuzsFlVRWo08w7Qxn0A==} + engines: {node: '>=6.9.0'} + dependencies: + '@ampproject/remapping': 2.2.0 + '@babel/code-frame': 7.18.6 + '@babel/generator': 7.18.13 + '@babel/helper-compilation-targets': 7.18.9(@babel/core@7.18.13) + '@babel/helper-module-transforms': 7.18.9 + '@babel/helpers': 7.18.9 + '@babel/parser': 7.18.13 + '@babel/template': 7.18.10 + '@babel/traverse': 7.18.13 + '@babel/types': 7.18.13 + convert-source-map: 1.8.0 + debug: 4.3.4(supports-color@8.1.1) + gensync: 1.0.0-beta.2 + json5: 2.2.1 + semver: 6.3.0 + transitivePeerDependencies: + - supports-color + + /@babel/core@7.20.5: + resolution: {integrity: sha512-UdOWmk4pNWTm/4DlPUl/Pt4Gz4rcEMb7CY0Y3eJl5Yz1vI8ZJGmHWaVE55LoxRjdpx0z259GE9U5STA9atUinQ==} + engines: {node: '>=6.9.0'} + dependencies: + '@ampproject/remapping': 2.2.1 + '@babel/code-frame': 7.22.5 + '@babel/generator': 7.22.5 + '@babel/helper-compilation-targets': 7.22.5(@babel/core@7.20.5) + '@babel/helper-module-transforms': 7.22.5 + '@babel/helpers': 7.22.5 + '@babel/parser': 7.22.5 + '@babel/template': 7.22.5 + '@babel/traverse': 7.22.5 + '@babel/types': 7.22.5 + convert-source-map: 1.9.0 + debug: 4.3.4(supports-color@8.1.1) + gensync: 1.0.0-beta.2 + json5: 2.2.3 + semver: 6.3.0 + transitivePeerDependencies: + - supports-color + dev: true + + /@babel/core@7.22.5: + resolution: {integrity: sha512-SBuTAjg91A3eKOvD+bPEz3LlhHZRNu1nFOVts9lzDJTXshHTjII0BAtDS3Y2DAkdZdDKWVZGVwkDfc4Clxn1dg==} engines: {node: '>=6.9.0'} dependencies: '@ampproject/remapping': 2.2.1 '@babel/code-frame': 7.22.5 - '@babel/generator': 7.22.7 - '@babel/helper-compilation-targets': 7.22.6(@babel/core@7.22.8) + '@babel/generator': 7.22.5 + '@babel/helper-compilation-targets': 7.22.5(@babel/core@7.22.5) '@babel/helper-module-transforms': 7.22.5 - '@babel/helpers': 7.22.6 - '@babel/parser': 7.22.7 + '@babel/helpers': 7.22.5 + '@babel/parser': 7.22.5 '@babel/template': 7.22.5 - '@babel/traverse': 7.22.8 + '@babel/traverse': 7.22.5 '@babel/types': 7.22.5 - '@nicolo-ribaudo/semver-v6': 6.3.3 convert-source-map: 1.9.0 debug: 4.3.4(supports-color@8.1.1) gensync: 1.0.0-beta.2 json5: 2.2.3 + semver: 6.3.0 transitivePeerDependencies: - supports-color - /@babel/generator@7.22.7: - resolution: {integrity: sha512-p+jPjMG+SI8yvIaxGgeW24u7q9+5+TGpZh8/CuB7RhBKd7RCy8FayNEFNNKrNK/eUcY/4ExQqLmyrvBXKsIcwQ==} + /@babel/generator@7.18.13: + resolution: {integrity: sha512-CkPg8ySSPuHTYPJYo7IRALdqyjM9HCbt/3uOBEFbzyGVP6Mn8bwFPB0jX6982JVNBlYzM1nnPkfjuXSOPtQeEQ==} + engines: {node: '>=6.9.0'} + dependencies: + '@babel/types': 7.22.5 + '@jridgewell/gen-mapping': 0.3.2 + jsesc: 2.5.2 + + /@babel/generator@7.22.5: + resolution: {integrity: sha512-+lcUbnTRhd0jOewtFSedLyiPsD5tswKkbgcezOqqWFUVNEwoUTlpPOBmvhG7OXWLR4jMdv0czPGH5XbflnD1EA==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 - '@jridgewell/gen-mapping': 0.3.3 + '@jridgewell/gen-mapping': 0.3.2 '@jridgewell/trace-mapping': 0.3.18 jsesc: 2.5.2 - /@babel/helper-annotate-as-pure@7.22.5: - resolution: {integrity: sha512-LvBTxu8bQSQkcyKOU+a1btnNFQ1dMAd0R6PyW3arXes06F6QLWLIrd681bxRPIXlrMGR3XYnW9JyML7dP3qgxg==} + /@babel/helper-annotate-as-pure@7.18.6: + resolution: {integrity: sha512-duORpUiYrEpzKIop6iNbjnwKLAKnJ47csTyRACyEmWj0QdUrm5aqNJGHSSEQSUAvNW0ojX0dOmK9dZduvkfeXA==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 dev: true - /@babel/helper-builder-binary-assignment-operator-visitor@7.22.5: - resolution: {integrity: sha512-m1EP3lVOPptR+2DwD125gziZNcmoNSHGmJROKoy87loWUQyJaVXDgpmruWqDARZSmtYQ+Dl25okU8+qhVzuykw==} + /@babel/helper-builder-binary-assignment-operator-visitor@7.18.9: + resolution: {integrity: sha512-yFQ0YCHoIqarl8BCRwBL8ulYUaZpz3bNsA7oFepAzee+8/+ImtADXNOmO5vJvsPff3qi+hvpkY/NYBTrBQgdNw==} engines: {node: '>=6.9.0'} dependencies: + '@babel/helper-explode-assignable-expression': 7.18.6 '@babel/types': 7.22.5 dev: true - /@babel/helper-compilation-targets@7.22.6(@babel/core@7.22.8): - resolution: {integrity: sha512-534sYEqWD9VfUm3IPn2SLcH4Q3P86XL+QvqdC7ZsFrzyyPF3T4XGiVghF6PTYNdWg6pXuoqXxNQAhbYeEInTzA==} + /@babel/helper-compilation-targets@7.18.9(@babel/core@7.18.13): + resolution: {integrity: sha512-tzLCyVmqUiFlcFoAPLA/gL9TeYrF61VLNtb+hvkuVaB5SUjW7jcfrglBIX1vUIoT7CLP3bBlIMeyEsIl2eFQNg==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0 + dependencies: + '@babel/compat-data': 7.22.5 + '@babel/core': 7.18.13 + '@babel/helper-validator-option': 7.22.5 + browserslist: 4.21.3 + semver: 6.3.0 + + /@babel/helper-compilation-targets@7.22.5(@babel/core@7.18.13): + resolution: {integrity: sha512-Ji+ywpHeuqxB8WDxraCiqR0xfhYjiDE/e6k7FuIaANnoOFxAHskHChz4vA1mJC9Lbm01s1PVAGhQY4FUKSkGZw==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0 + dependencies: + '@babel/compat-data': 7.22.5 + '@babel/core': 7.18.13 + '@babel/helper-validator-option': 7.22.5 + browserslist: 4.21.3 + lru-cache: 5.1.1 + semver: 6.3.0 + dev: true + + /@babel/helper-compilation-targets@7.22.5(@babel/core@7.20.5): + resolution: {integrity: sha512-Ji+ywpHeuqxB8WDxraCiqR0xfhYjiDE/e6k7FuIaANnoOFxAHskHChz4vA1mJC9Lbm01s1PVAGhQY4FUKSkGZw==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0 + dependencies: + '@babel/compat-data': 7.22.5 + '@babel/core': 7.20.5 + '@babel/helper-validator-option': 7.22.5 + browserslist: 4.21.3 + lru-cache: 5.1.1 + semver: 6.3.0 + dev: true + + /@babel/helper-compilation-targets@7.22.5(@babel/core@7.22.5): + resolution: {integrity: sha512-Ji+ywpHeuqxB8WDxraCiqR0xfhYjiDE/e6k7FuIaANnoOFxAHskHChz4vA1mJC9Lbm01s1PVAGhQY4FUKSkGZw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0 dependencies: - '@babel/compat-data': 7.22.6 - '@babel/core': 7.22.8 + '@babel/compat-data': 7.22.5 + '@babel/core': 7.22.5 '@babel/helper-validator-option': 7.22.5 - '@nicolo-ribaudo/semver-v6': 6.3.3 - browserslist: 4.21.9 + browserslist: 4.21.3 lru-cache: 5.1.1 + semver: 6.3.0 + + /@babel/helper-create-class-features-plugin@7.21.0(@babel/core@7.18.13): + resolution: {integrity: sha512-Q8wNiMIdwsv5la5SPxNYzzkPnjgC0Sy0i7jLkVOCdllu/xcVNkr3TeZzbHBJrj+XXRqzX5uCyCoV9eu6xUG7KQ==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-annotate-as-pure': 7.18.6 + '@babel/helper-environment-visitor': 7.22.5 + '@babel/helper-function-name': 7.22.5 + '@babel/helper-member-expression-to-functions': 7.21.0 + '@babel/helper-optimise-call-expression': 7.18.6 + '@babel/helper-replace-supers': 7.20.7 + '@babel/helper-skip-transparent-expression-wrappers': 7.20.0 + '@babel/helper-split-export-declaration': 7.22.5 + transitivePeerDependencies: + - supports-color + dev: true + + /@babel/helper-create-class-features-plugin@7.21.0(@babel/core@7.20.5): + resolution: {integrity: sha512-Q8wNiMIdwsv5la5SPxNYzzkPnjgC0Sy0i7jLkVOCdllu/xcVNkr3TeZzbHBJrj+XXRqzX5uCyCoV9eu6xUG7KQ==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0 + dependencies: + '@babel/core': 7.20.5 + '@babel/helper-annotate-as-pure': 7.18.6 + '@babel/helper-environment-visitor': 7.22.5 + '@babel/helper-function-name': 7.22.5 + '@babel/helper-member-expression-to-functions': 7.21.0 + '@babel/helper-optimise-call-expression': 7.18.6 + '@babel/helper-replace-supers': 7.20.7 + '@babel/helper-skip-transparent-expression-wrappers': 7.20.0 + '@babel/helper-split-export-declaration': 7.22.5 + transitivePeerDependencies: + - supports-color + dev: true - /@babel/helper-create-class-features-plugin@7.22.6(@babel/core@7.22.8): - resolution: {integrity: sha512-iwdzgtSiBxF6ni6mzVnZCF3xt5qE6cEA0J7nFt8QOAWZ0zjCFceEgpn3vtb2V7WFR6QzP2jmIFOHMTRo7eNJjQ==} + /@babel/helper-create-class-features-plugin@7.21.0(@babel/core@7.22.5): + resolution: {integrity: sha512-Q8wNiMIdwsv5la5SPxNYzzkPnjgC0Sy0i7jLkVOCdllu/xcVNkr3TeZzbHBJrj+XXRqzX5uCyCoV9eu6xUG7KQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-annotate-as-pure': 7.22.5 + '@babel/core': 7.22.5 + '@babel/helper-annotate-as-pure': 7.18.6 '@babel/helper-environment-visitor': 7.22.5 '@babel/helper-function-name': 7.22.5 - '@babel/helper-member-expression-to-functions': 7.22.5 - '@babel/helper-optimise-call-expression': 7.22.5 - '@babel/helper-replace-supers': 7.22.5 - '@babel/helper-skip-transparent-expression-wrappers': 7.22.5 - '@babel/helper-split-export-declaration': 7.22.6 - '@nicolo-ribaudo/semver-v6': 6.3.3 + '@babel/helper-member-expression-to-functions': 7.21.0 + '@babel/helper-optimise-call-expression': 7.18.6 + '@babel/helper-replace-supers': 7.20.7 + '@babel/helper-skip-transparent-expression-wrappers': 7.20.0 + '@babel/helper-split-export-declaration': 7.22.5 transitivePeerDependencies: - supports-color dev: true - /@babel/helper-create-regexp-features-plugin@7.22.6(@babel/core@7.22.8): - resolution: {integrity: sha512-nBookhLKxAWo/TUCmhnaEJyLz2dekjQvv5SRpE9epWQBcpedWLKt8aZdsuT9XV5ovzR3fENLjRXVT0GsSlGGhA==} + /@babel/helper-create-regexp-features-plugin@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-7LcpH1wnQLGrI+4v+nPp+zUvIkF9x0ddv1Hkdue10tg3gmRnLy97DXh4STiOf1qeIInyD69Qv5kKSZzKD8B/7A==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-annotate-as-pure': 7.18.6 + regexpu-core: 5.1.0 + dev: true + + /@babel/helper-create-regexp-features-plugin@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-7LcpH1wnQLGrI+4v+nPp+zUvIkF9x0ddv1Hkdue10tg3gmRnLy97DXh4STiOf1qeIInyD69Qv5kKSZzKD8B/7A==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-annotate-as-pure': 7.22.5 - '@nicolo-ribaudo/semver-v6': 6.3.3 - regexpu-core: 5.3.2 + '@babel/core': 7.22.5 + '@babel/helper-annotate-as-pure': 7.18.6 + regexpu-core: 5.1.0 dev: true - /@babel/helper-define-polyfill-provider@0.1.5(@babel/core@7.22.8): + /@babel/helper-define-polyfill-provider@0.1.5(@babel/core@7.22.5): resolution: {integrity: sha512-nXuzCSwlJ/WKr8qxzW816gwyT6VZgiJG17zR40fou70yfAcqjoNyTLl/DQ+FExw5Hx5KNqshmN8Ldl/r2N7cTg==} peerDependencies: '@babel/core': ^7.4.0-0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-compilation-targets': 7.22.6(@babel/core@7.22.8) + '@babel/core': 7.22.5 + '@babel/helper-compilation-targets': 7.22.5(@babel/core@7.22.5) '@babel/helper-module-imports': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 - '@babel/traverse': 7.22.8 + '@babel/traverse': 7.22.5 + debug: 4.3.4(supports-color@8.1.1) + lodash.debounce: 4.0.8 + resolve: 1.22.2 + semver: 6.3.0 + transitivePeerDependencies: + - supports-color + dev: true + + /@babel/helper-define-polyfill-provider@0.3.2(@babel/core@7.18.13): + resolution: {integrity: sha512-r9QJJ+uDWrd+94BSPcP6/de67ygLtvVy6cK4luE6MOuDsZIdoaPBnfSpbO/+LTifjPckbKXRuI9BB/Z2/y3iTg==} + peerDependencies: + '@babel/core': ^7.4.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-compilation-targets': 7.22.5(@babel/core@7.18.13) + '@babel/helper-plugin-utils': 7.22.5 debug: 4.3.4(supports-color@8.1.1) lodash.debounce: 4.0.8 resolve: 1.22.2 - semver: 6.3.1 + semver: 6.3.0 transitivePeerDependencies: - supports-color dev: true - /@babel/helper-define-polyfill-provider@0.4.1(@babel/core@7.22.8): - resolution: {integrity: sha512-kX4oXixDxG197yhX+J3Wp+NpL2wuCFjWQAr6yX2jtCnflK9ulMI51ULFGIrWiX1jGfvAxdHp+XQCcP2bZGPs9A==} + /@babel/helper-define-polyfill-provider@0.3.2(@babel/core@7.22.5): + resolution: {integrity: sha512-r9QJJ+uDWrd+94BSPcP6/de67ygLtvVy6cK4luE6MOuDsZIdoaPBnfSpbO/+LTifjPckbKXRuI9BB/Z2/y3iTg==} peerDependencies: '@babel/core': ^7.4.0-0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-compilation-targets': 7.22.6(@babel/core@7.22.8) + '@babel/core': 7.22.5 + '@babel/helper-compilation-targets': 7.22.5(@babel/core@7.22.5) '@babel/helper-plugin-utils': 7.22.5 debug: 4.3.4(supports-color@8.1.1) lodash.debounce: 4.0.8 resolve: 1.22.2 + semver: 6.3.0 transitivePeerDependencies: - supports-color dev: true @@ -2433,6 +2603,13 @@ packages: resolution: {integrity: sha512-XGmhECfVA/5sAt+H+xpSg0mfrHq6FzNr9Oxh7PSEBBRUb/mL7Kz3NICXb194rCqAEdxkhPT1a88teizAFyvk8Q==} engines: {node: '>=6.9.0'} + /@babel/helper-explode-assignable-expression@7.18.6: + resolution: {integrity: sha512-eyAYAsQmB80jNfg4baAtLeWAQHfHFiR483rzFK+BhETlGZaQC9bsfrugfXDCbRHLQbIA7U5NxhhOxN7p/dWIcg==} + engines: {node: '>=6.9.0'} + dependencies: + '@babel/types': 7.22.5 + dev: true + /@babel/helper-function-name@7.22.5: resolution: {integrity: sha512-wtHSq6jMRE3uF2otvfuD3DIvVhOsSNshQl0Qrd7qC9oQJzHvOL4qQXlQn2916+CXGywIjpGuIkoyZRRxHPiNQQ==} engines: {node: '>=6.9.0'} @@ -2446,15 +2623,15 @@ packages: dependencies: '@babel/types': 7.22.5 - /@babel/helper-member-expression-to-functions@7.22.5: - resolution: {integrity: sha512-aBiH1NKMG0H2cGZqspNvsaBe6wNGjbJjuLy29aU+eDZjSbbN53BaxlpB02xm9v34pLTZ1nIQPFYn2qMZoa5BQQ==} + /@babel/helper-member-expression-to-functions@7.21.0: + resolution: {integrity: sha512-Muu8cdZwNN6mRRNG6lAYErJ5X3bRevgYR2O8wN0yn7jJSnGDu6eG59RfT29JHxGUovyfrh6Pj0XzmR7drNVL3Q==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 dev: true - /@babel/helper-module-imports@7.18.6: - resolution: {integrity: sha512-0NFvs3VkuSYbFi1x2Vd6tKrywq+z/cLeYC/RJNFrIX/30Bf5aiGYbtvGXolEktzJH8o5E5KJ3tT+nkxuuZFVlA==} + /@babel/helper-module-imports@7.16.0: + resolution: {integrity: sha512-kkH7sWzKPq0xt3H1n+ghb4xEMP8k0U7XV3kkB+ZGy69kDk2ySFW1qPi06sjKzFY3t1j6XbJSqr4mF9L7CYVyhg==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 @@ -2466,6 +2643,21 @@ packages: dependencies: '@babel/types': 7.22.5 + /@babel/helper-module-transforms@7.18.9: + resolution: {integrity: sha512-KYNqY0ICwfv19b31XzvmI/mfcylOzbLtowkw+mfvGPAQ3kfCnMLYbED3YecL5tPd8nAYFQFAd6JHp2LxZk/J1g==} + engines: {node: '>=6.9.0'} + dependencies: + '@babel/helper-environment-visitor': 7.22.5 + '@babel/helper-module-imports': 7.22.5 + '@babel/helper-simple-access': 7.22.5 + '@babel/helper-split-export-declaration': 7.22.5 + '@babel/helper-validator-identifier': 7.22.5 + '@babel/template': 7.22.5 + '@babel/traverse': 7.22.5 + '@babel/types': 7.22.5 + transitivePeerDependencies: + - supports-color + /@babel/helper-module-transforms@7.22.5: resolution: {integrity: sha512-+hGKDt/Ze8GFExiVHno/2dvG5IdstpzCq0y4Qc9OJ25D4q3pKfiIP/4Vp3/JvhDkLKsDK2api3q3fpIgiIF5bw==} engines: {node: '>=6.9.0'} @@ -2473,16 +2665,16 @@ packages: '@babel/helper-environment-visitor': 7.22.5 '@babel/helper-module-imports': 7.22.5 '@babel/helper-simple-access': 7.22.5 - '@babel/helper-split-export-declaration': 7.22.6 + '@babel/helper-split-export-declaration': 7.22.5 '@babel/helper-validator-identifier': 7.22.5 '@babel/template': 7.22.5 - '@babel/traverse': 7.22.8 + '@babel/traverse': 7.22.5 '@babel/types': 7.22.5 transitivePeerDependencies: - supports-color - /@babel/helper-optimise-call-expression@7.22.5: - resolution: {integrity: sha512-HBwaojN0xFRx4yIvpwGqxiV2tUfl7401jlok564NgB9EHS1y6QT17FmKWm4ztqjeVdXLuC4fSvHc5ePpQjoTbw==} + /@babel/helper-optimise-call-expression@7.18.6: + resolution: {integrity: sha512-HP59oD9/fEHQkdcbgFCnbmgH5vIQTJbxh2yf+CdM89/glUNnuzr87Q8GIjGEnOktTROemO0Pe0iPAYbqZuOUiA==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 @@ -2495,32 +2687,46 @@ packages: /@babel/helper-plugin-utils@7.22.5: resolution: {integrity: sha512-uLls06UVKgFG9QD4OeFYLEGteMIAa5kpTPcFL28yuCIIzsf6ZyKZMllKVOCZFhiZ5ptnwX4mtKdWCBE/uT4amg==} engines: {node: '>=6.9.0'} + + /@babel/helper-remap-async-to-generator@7.18.9(@babel/core@7.18.13): + resolution: {integrity: sha512-dI7q50YKd8BAv3VEfgg7PS7yD3Rtbi2J1XMXaalXO0W0164hYLnh8zpjRS0mte9MfVp/tltvr/cfdXPvJr1opA==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-annotate-as-pure': 7.18.6 + '@babel/helper-environment-visitor': 7.22.5 + '@babel/helper-wrap-function': 7.18.11 + '@babel/types': 7.22.5 + transitivePeerDependencies: + - supports-color dev: true - /@babel/helper-remap-async-to-generator@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-cU0Sq1Rf4Z55fgz7haOakIyM7+x/uCFwXpLPaeRzfoUtAEAuUZjZvFPjL/rk5rW693dIgn2hng1W7xbT7lWT4g==} + /@babel/helper-remap-async-to-generator@7.18.9(@babel/core@7.22.5): + resolution: {integrity: sha512-dI7q50YKd8BAv3VEfgg7PS7yD3Rtbi2J1XMXaalXO0W0164hYLnh8zpjRS0mte9MfVp/tltvr/cfdXPvJr1opA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-annotate-as-pure': 7.22.5 + '@babel/core': 7.22.5 + '@babel/helper-annotate-as-pure': 7.18.6 '@babel/helper-environment-visitor': 7.22.5 - '@babel/helper-wrap-function': 7.22.5 + '@babel/helper-wrap-function': 7.18.11 '@babel/types': 7.22.5 transitivePeerDependencies: - supports-color dev: true - /@babel/helper-replace-supers@7.22.5: - resolution: {integrity: sha512-aLdNM5I3kdI/V9xGNyKSF3X/gTyMUBohTZ+/3QdQKAA9vxIiy12E+8E2HoOP1/DjeqU+g6as35QHJNMDDYpuCg==} + /@babel/helper-replace-supers@7.20.7: + resolution: {integrity: sha512-vujDMtB6LVfNW13jhlCrp48QNslK6JXi7lQG736HVbHz/mbf4Dc7tIRh1Xf5C0rF7BP8iiSxGMCmY6Ci1ven3A==} engines: {node: '>=6.9.0'} dependencies: '@babel/helper-environment-visitor': 7.22.5 - '@babel/helper-member-expression-to-functions': 7.22.5 - '@babel/helper-optimise-call-expression': 7.22.5 + '@babel/helper-member-expression-to-functions': 7.21.0 + '@babel/helper-optimise-call-expression': 7.18.6 '@babel/template': 7.22.5 - '@babel/traverse': 7.22.8 + '@babel/traverse': 7.22.5 '@babel/types': 7.22.5 transitivePeerDependencies: - supports-color @@ -2532,15 +2738,15 @@ packages: dependencies: '@babel/types': 7.22.5 - /@babel/helper-skip-transparent-expression-wrappers@7.22.5: - resolution: {integrity: sha512-tK14r66JZKiC43p8Ki33yLBVJKlQDFoA8GYN67lWCDCqoL6EMMSuM9b+Iff2jHaM/RRFYl7K+iiru7hbRqNx8Q==} + /@babel/helper-skip-transparent-expression-wrappers@7.20.0: + resolution: {integrity: sha512-5y1JYeNKfvnT8sZcK9DVRtpTbGiomYIHviSP3OQWmDPU3DeH4a1ZlT/N2lyQ5P8egjcRaT/Y9aNqUxK0WsnIIg==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 dev: true - /@babel/helper-split-export-declaration@7.22.6: - resolution: {integrity: sha512-AsUnxuLhRYsisFiaJwvp1QF+I3KjD5FOxut14q/GzovUe6orHLesW2C7d754kRm53h5gqrz6sFl6sxc4BVtE/g==} + /@babel/helper-split-export-declaration@7.22.5: + resolution: {integrity: sha512-thqK5QFghPKWLhAV321lxF95yCg2K3Ob5yw+M3VHWfdia0IkPXUtoLH8x/6Fh486QUvzhb8YOWHChTVen2/PoQ==} engines: {node: '>=6.9.0'} dependencies: '@babel/types': 7.22.5 @@ -2557,24 +2763,34 @@ packages: resolution: {integrity: sha512-R3oB6xlIVKUnxNUxbmgq7pKjxpru24zlimpE8WK47fACIlM0II/Hm1RS8IaOI7NgCr6LNS+jl5l75m20npAziw==} engines: {node: '>=6.9.0'} - /@babel/helper-wrap-function@7.22.5: - resolution: {integrity: sha512-bYqLIBSEshYcYQyfks8ewYA8S30yaGSeRslcvKMvoUk6HHPySbxHq9YRi6ghhzEU+yhQv9bP/jXnygkStOcqZw==} + /@babel/helper-wrap-function@7.18.11: + resolution: {integrity: sha512-oBUlbv+rjZLh2Ks9SKi4aL7eKaAXBWleHzU89mP0G6BMUlRxSckk9tSIkgDGydhgFxHuGSlBQZfnaD47oBEB7w==} engines: {node: '>=6.9.0'} dependencies: '@babel/helper-function-name': 7.22.5 '@babel/template': 7.22.5 - '@babel/traverse': 7.22.8 + '@babel/traverse': 7.22.5 '@babel/types': 7.22.5 transitivePeerDependencies: - supports-color dev: true - /@babel/helpers@7.22.6: - resolution: {integrity: sha512-YjDs6y/fVOYFV8hAf1rxd1QvR9wJe1pDBZ2AREKq/SDayfPzgk0PBnVuTCE5X1acEpMMNOVUqoe+OwiZGJ+OaA==} + /@babel/helpers@7.18.9: + resolution: {integrity: sha512-Jf5a+rbrLoR4eNdUmnFu8cN5eNJT6qdTdOg5IHIzq87WwyRw9PwguLFOWYgktN/60IP4fgDUawJvs7PjQIzELQ==} + engines: {node: '>=6.9.0'} + dependencies: + '@babel/template': 7.22.5 + '@babel/traverse': 7.22.5 + '@babel/types': 7.22.5 + transitivePeerDependencies: + - supports-color + + /@babel/helpers@7.22.5: + resolution: {integrity: sha512-pSXRmfE1vzcUIDFQcSGA5Mr+GxBV9oiRKDuDxXvWQQBCh8HoIjs/2DlDB7H8smac1IVrB9/xdXj2N3Wol9Cr+Q==} engines: {node: '>=6.9.0'} dependencies: '@babel/template': 7.22.5 - '@babel/traverse': 7.22.8 + '@babel/traverse': 7.22.5 '@babel/types': 7.22.5 transitivePeerDependencies: - supports-color @@ -2587,1270 +2803,2108 @@ packages: chalk: 2.4.2 js-tokens: 4.0.0 - /@babel/parser@7.22.7: - resolution: {integrity: sha512-7NF8pOkHP5o2vpmGgNGcfAeCvOYhGLyA3Z4eBQkT1RJlWu47n63bCs93QfJ2hIAFCil7L5P2IWhs1oToVgrL0Q==} + /@babel/parser@7.18.13: + resolution: {integrity: sha512-dgXcIfMuQ0kgzLB2b9tRZs7TTFFaGM2AbtA4fJgUUYukzGH4jwsS7hzQHEGs67jdehpm22vkgKwvbU+aEflgwg==} engines: {node: '>=6.0.0'} hasBin: true dependencies: '@babel/types': 7.22.5 - /@babel/plugin-bugfix-safari-id-destructuring-collision-in-function-expression@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-NP1M5Rf+u2Gw9qfSO4ihjcTGW5zXTi36ITLd4/EoAcEhIZ0yjMqmftDNl3QC19CX7olhrjpyU454g/2W7X0jvQ==} - engines: {node: '>=6.9.0'} - peerDependencies: - '@babel/core': ^7.0.0 + /@babel/parser@7.22.5: + resolution: {integrity: sha512-DFZMC9LJUG9PLOclRC32G63UXwzqS2koQC8dkx+PLdmt1xSePYpbT/NbsrJy8Q/muXz7o/h/d4A7Fuyixm559Q==} + engines: {node: '>=6.0.0'} + hasBin: true dependencies: - '@babel/core': 7.22.8 - '@babel/helper-plugin-utils': 7.22.5 - dev: true + '@babel/types': 7.22.5 - /@babel/plugin-bugfix-v8-spread-parameters-in-optional-chaining@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-31Bb65aZaUwqCbWMnZPduIZxCBngHFlzyN6Dq6KAJjtx+lx6ohKHubc61OomYi7XwVD4Ol0XCVz4h+pYFR048g==} + /@babel/plugin-bugfix-safari-id-destructuring-collision-in-function-expression@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-Dgxsyg54Fx1d4Nge8UnvTrED63vrwOdPmyvPzlNN/boaliRP54pm3pGzZD1SJUwrBA+Cs/xdG8kXX6Mn/RfISQ==} engines: {node: '>=6.9.0'} peerDependencies: - '@babel/core': ^7.13.0 + '@babel/core': ^7.0.0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-skip-transparent-expression-wrappers': 7.22.5 - '@babel/plugin-transform-optional-chaining': 7.22.6(@babel/core@7.22.8) dev: true - /@babel/plugin-proposal-class-properties@7.18.6(@babel/core@7.22.8): - resolution: {integrity: sha512-cumfXOF0+nzZrrN8Rf0t7M+tF6sZc7vhQwYQck9q1/5w2OExlD+b4v4RpMJFaV1Z7WcDRgO6FqvxqxGlwo+RHQ==} + /@babel/plugin-bugfix-safari-id-destructuring-collision-in-function-expression@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-Dgxsyg54Fx1d4Nge8UnvTrED63vrwOdPmyvPzlNN/boaliRP54pm3pGzZD1SJUwrBA+Cs/xdG8kXX6Mn/RfISQ==} engines: {node: '>=6.9.0'} peerDependencies: - '@babel/core': ^7.0.0-0 + '@babel/core': ^7.0.0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-create-class-features-plugin': 7.22.6(@babel/core@7.22.8) + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 - transitivePeerDependencies: - - supports-color dev: true - /@babel/plugin-proposal-decorators@7.22.7(@babel/core@7.22.8): - resolution: {integrity: sha512-omXqPF7Onq4Bb7wHxXjM3jSMSJvUUbvDvmmds7KI5n9Cq6Ln5I05I1W2nRlRof1rGdiUxJrxwe285WF96XlBXQ==} + /@babel/plugin-bugfix-v8-spread-parameters-in-optional-chaining@7.18.9(@babel/core@7.18.13): + resolution: {integrity: sha512-AHrP9jadvH7qlOj6PINbgSuphjQUAK7AOT7DPjBo9EHoLhQTnnK5u45e1Hd4DbSQEO9nqPWtQ89r+XEOWFScKg==} engines: {node: '>=6.9.0'} peerDependencies: - '@babel/core': ^7.0.0-0 + '@babel/core': ^7.13.0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-create-class-features-plugin': 7.22.6(@babel/core@7.22.8) + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-replace-supers': 7.22.5 - '@babel/helper-split-export-declaration': 7.22.6 - '@babel/plugin-syntax-decorators': 7.22.5(@babel/core@7.22.8) - transitivePeerDependencies: - - supports-color + '@babel/helper-skip-transparent-expression-wrappers': 7.20.0 + '@babel/plugin-proposal-optional-chaining': 7.18.9(@babel/core@7.18.13) dev: true - /@babel/plugin-proposal-export-default-from@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-UCe1X/hplyv6A5g2WnQ90tnHRvYL29dabCWww92lO7VdfMVTVReBTRrhiMrKQejHD9oVkdnRdwYuzUZkBVQisg==} + /@babel/plugin-bugfix-v8-spread-parameters-in-optional-chaining@7.18.9(@babel/core@7.22.5): + resolution: {integrity: sha512-AHrP9jadvH7qlOj6PINbgSuphjQUAK7AOT7DPjBo9EHoLhQTnnK5u45e1Hd4DbSQEO9nqPWtQ89r+XEOWFScKg==} engines: {node: '>=6.9.0'} peerDependencies: - '@babel/core': ^7.0.0-0 + '@babel/core': ^7.13.0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-export-default-from': 7.22.5(@babel/core@7.22.8) + '@babel/helper-skip-transparent-expression-wrappers': 7.20.0 + '@babel/plugin-proposal-optional-chaining': 7.18.9(@babel/core@7.22.5) dev: true - /@babel/plugin-proposal-nullish-coalescing-operator@7.18.6(@babel/core@7.22.8): - resolution: {integrity: sha512-wQxQzxYeJqHcfppzBDnm1yAY0jSRkUXR2z8RePZYrKwMKgMlE8+Z6LUno+bd6LvbGh8Gltvy74+9pIYkr+XkKA==} + /@babel/plugin-proposal-async-generator-functions@7.18.10(@babel/core@7.18.13): + resolution: {integrity: sha512-1mFuY2TOsR1hxbjCo4QL+qlIjV07p4H4EUYw2J/WCqsvFV6V9X9z9YhXbWndc/4fw+hYGlDT7egYxliMp5O6Ew==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 + '@babel/helper-environment-visitor': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-nullish-coalescing-operator': 7.8.3(@babel/core@7.22.8) + '@babel/helper-remap-async-to-generator': 7.18.9(@babel/core@7.18.13) + '@babel/plugin-syntax-async-generators': 7.8.4(@babel/core@7.18.13) + transitivePeerDependencies: + - supports-color dev: true - /@babel/plugin-proposal-object-rest-spread@7.12.1(@babel/core@7.12.9): - resolution: {integrity: sha512-s6SowJIjzlhx8o7lsFx5zmY4At6CTtDvgNQDdPzkBQucle58A6b/TTeEBYtyDgmcXjUTM+vE8YOGHZzzbc/ioA==} + /@babel/plugin-proposal-async-generator-functions@7.18.10(@babel/core@7.22.5): + resolution: {integrity: sha512-1mFuY2TOsR1hxbjCo4QL+qlIjV07p4H4EUYw2J/WCqsvFV6V9X9z9YhXbWndc/4fw+hYGlDT7egYxliMp5O6Ew==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.12.9 + '@babel/core': 7.22.5 + '@babel/helper-environment-visitor': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-object-rest-spread': 7.8.3(@babel/core@7.12.9) - '@babel/plugin-transform-parameters': 7.22.5(@babel/core@7.12.9) + '@babel/helper-remap-async-to-generator': 7.18.9(@babel/core@7.22.5) + '@babel/plugin-syntax-async-generators': 7.8.4(@babel/core@7.22.5) + transitivePeerDependencies: + - supports-color dev: true - /@babel/plugin-proposal-object-rest-spread@7.20.7(@babel/core@7.22.8): - resolution: {integrity: sha512-d2S98yCiLxDVmBmE8UjGcfPvNEUbA1U5q5WxaWFUGRzJSVAZqm5W6MbPct0jxnegUZ0niLeNX+IOzEs7wYg9Dg==} + /@babel/plugin-proposal-class-properties@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-cumfXOF0+nzZrrN8Rf0t7M+tF6sZc7vhQwYQck9q1/5w2OExlD+b4v4RpMJFaV1Z7WcDRgO6FqvxqxGlwo+RHQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/compat-data': 7.22.6 - '@babel/core': 7.22.8 - '@babel/helper-compilation-targets': 7.22.6(@babel/core@7.22.8) + '@babel/core': 7.18.13 + '@babel/helper-create-class-features-plugin': 7.21.0(@babel/core@7.18.13) '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-object-rest-spread': 7.8.3(@babel/core@7.22.8) - '@babel/plugin-transform-parameters': 7.22.5(@babel/core@7.22.8) + transitivePeerDependencies: + - supports-color dev: true - /@babel/plugin-proposal-optional-chaining@7.21.0(@babel/core@7.22.8): - resolution: {integrity: sha512-p4zeefM72gpmEe2fkUr/OnOXpWEf8nAgk7ZYVqqfFiyIG7oFfVZcCrU64hWn5xp4tQ9LkV4bTIa5rD0KANpKNA==} + /@babel/plugin-proposal-class-properties@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-cumfXOF0+nzZrrN8Rf0t7M+tF6sZc7vhQwYQck9q1/5w2OExlD+b4v4RpMJFaV1Z7WcDRgO6FqvxqxGlwo+RHQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 + '@babel/helper-create-class-features-plugin': 7.21.0(@babel/core@7.22.5) '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-skip-transparent-expression-wrappers': 7.22.5 - '@babel/plugin-syntax-optional-chaining': 7.8.3(@babel/core@7.22.8) + transitivePeerDependencies: + - supports-color dev: true - /@babel/plugin-proposal-private-methods@7.18.6(@babel/core@7.22.8): - resolution: {integrity: sha512-nutsvktDItsNn4rpGItSNV2sz1XwS+nfU0Rg8aCx3W3NOKVzdMjJRu0O5OkgDp3ZGICSTbgRpxZoWsxoKRvbeA==} + /@babel/plugin-proposal-class-static-block@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-+I3oIiNxrCpup3Gi8n5IGMwj0gOCAjcJUSQEcotNnCCPMEnixawOQ+KeJPlgfjzx+FKQ1QSyZOWe7wmoJp7vhw==} engines: {node: '>=6.9.0'} peerDependencies: - '@babel/core': ^7.0.0-0 + '@babel/core': ^7.12.0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-create-class-features-plugin': 7.22.6(@babel/core@7.22.8) + '@babel/core': 7.18.13 + '@babel/helper-create-class-features-plugin': 7.21.0(@babel/core@7.18.13) '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-class-static-block': 7.14.5(@babel/core@7.18.13) transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-proposal-private-property-in-object@7.21.0-placeholder-for-preset-env.2(@babel/core@7.22.8): - resolution: {integrity: sha512-SOSkfJDddaM7mak6cPEpswyTRnuRltl429hMraQEglW+OkovnCzsiszTmsrlY//qLFjCpQDFRvjdm2wA5pPm9w==} + /@babel/plugin-proposal-class-static-block@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-+I3oIiNxrCpup3Gi8n5IGMwj0gOCAjcJUSQEcotNnCCPMEnixawOQ+KeJPlgfjzx+FKQ1QSyZOWe7wmoJp7vhw==} engines: {node: '>=6.9.0'} peerDependencies: - '@babel/core': ^7.0.0-0 + '@babel/core': ^7.12.0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 + '@babel/helper-create-class-features-plugin': 7.21.0(@babel/core@7.22.5) + '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-class-static-block': 7.14.5(@babel/core@7.22.5) + transitivePeerDependencies: + - supports-color dev: true - /@babel/plugin-proposal-private-property-in-object@7.21.11(@babel/core@7.22.8): - resolution: {integrity: sha512-0QZ8qP/3RLDVBwBFoWAwCtgcDZJVwA5LUJRZU8x2YFfKNuFq161wK3cuGrALu5yiPu+vzwTAg/sMWVNeWeNyaw==} + /@babel/plugin-proposal-decorators@7.18.10(@babel/core@7.22.5): + resolution: {integrity: sha512-wdGTwWF5QtpTY/gbBtQLAiCnoxfD4qMbN87NYZle1dOZ9Os8Y6zXcKrIaOU8W+TIvFUWVGG9tUgNww3CjXRVVw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-annotate-as-pure': 7.22.5 - '@babel/helper-create-class-features-plugin': 7.22.6(@babel/core@7.22.8) + '@babel/core': 7.22.5 + '@babel/helper-create-class-features-plugin': 7.21.0(@babel/core@7.22.5) '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-private-property-in-object': 7.14.5(@babel/core@7.22.8) + '@babel/helper-replace-supers': 7.20.7 + '@babel/helper-split-export-declaration': 7.22.5 + '@babel/plugin-syntax-decorators': 7.18.6(@babel/core@7.22.5) transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-proposal-unicode-property-regex@7.18.6(@babel/core@7.22.8): - resolution: {integrity: sha512-2BShG/d5yoZyXZfVePH91urL5wTG6ASZU9M4o03lKK8u8UW1y08OMttBSOADTcJrnPMpvDXRG3G8fyLh4ovs8w==} - engines: {node: '>=4'} + /@babel/plugin-proposal-dynamic-import@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-1auuwmK+Rz13SJj36R+jqFPMJWyKEDd7lLSdOj4oJK0UTgGueSAtkrCvz9ewmgyU/P941Rv2fQwZJN8s6QruXw==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-create-regexp-features-plugin': 7.22.6(@babel/core@7.22.8) + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-dynamic-import': 7.8.3(@babel/core@7.18.13) dev: true - /@babel/plugin-syntax-async-generators@7.8.4(@babel/core@7.22.8): - resolution: {integrity: sha512-tycmZxkGfZaxhMRbXlPXuVFpdWlXpir2W4AMhSJgRKzk/eDlIXOhb2LHWoLpDF7TEHylV5zNhykX6KAgHJmTNw==} + /@babel/plugin-proposal-dynamic-import@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-1auuwmK+Rz13SJj36R+jqFPMJWyKEDd7lLSdOj4oJK0UTgGueSAtkrCvz9ewmgyU/P941Rv2fQwZJN8s6QruXw==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-dynamic-import': 7.8.3(@babel/core@7.22.5) dev: true - /@babel/plugin-syntax-bigint@7.8.3(@babel/core@7.22.8): - resolution: {integrity: sha512-wnTnFlG+YxQm3vDxpGE57Pj0srRU4sHE/mDkt1qv2YJJSeUAec2ma4WLUnUPeKjyrfntVwe/N6dCXpU+zL3Npg==} + /@babel/plugin-proposal-export-default-from@7.18.10(@babel/core@7.22.5): + resolution: {integrity: sha512-5H2N3R2aQFxkV4PIBUR/i7PUSwgTZjouJKzI8eKswfIjT0PhvzkPn0t0wIS5zn6maQuvtT0t1oHtMUz61LOuow==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-export-default-from': 7.18.6(@babel/core@7.22.5) dev: true - /@babel/plugin-syntax-class-properties@7.12.13(@babel/core@7.22.8): - resolution: {integrity: sha512-fm4idjKla0YahUNgFNLCB0qySdsoPiZP3iQE3rky0mBUtMZ23yDJ9SJdg6dXTSDnulOVqiF3Hgr9nbXvXTQZYA==} + /@babel/plugin-proposal-export-namespace-from@7.18.9(@babel/core@7.18.13): + resolution: {integrity: sha512-k1NtHyOMvlDDFeb9G5PhUXuGj8m/wiwojgQVEhJ/fsVsMCpLyOP4h0uGEjYJKrRI+EVPlb5Jk+Gt9P97lOGwtA==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-export-namespace-from': 7.8.3(@babel/core@7.18.13) dev: true - /@babel/plugin-syntax-class-static-block@7.14.5(@babel/core@7.22.8): - resolution: {integrity: sha512-b+YyPmr6ldyNnM6sqYeMWE+bgJcJpO6yS4QD7ymxgH34GBPNDM/THBh8iunyvKIZztiwLH4CJZ0RxTk9emgpjw==} + /@babel/plugin-proposal-export-namespace-from@7.18.9(@babel/core@7.22.5): + resolution: {integrity: sha512-k1NtHyOMvlDDFeb9G5PhUXuGj8m/wiwojgQVEhJ/fsVsMCpLyOP4h0uGEjYJKrRI+EVPlb5Jk+Gt9P97lOGwtA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-export-namespace-from': 7.8.3(@babel/core@7.22.5) dev: true - /@babel/plugin-syntax-decorators@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-avpUOBS7IU6al8MmF1XpAyj9QYeLPuSDJI5D4pVMSMdL7xQokKqJPYQC67RCT0aCTashUXPiGwMJ0DEXXCEmMA==} + /@babel/plugin-proposal-json-strings@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-lr1peyn9kOdbYc0xr0OdHTZ5FMqS6Di+H0Fz2I/JwMzGmzJETNeOFq2pBySw6X/KFL5EWDjlJuMsUGRFb8fQgQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-json-strings': 7.8.3(@babel/core@7.18.13) dev: true - /@babel/plugin-syntax-dynamic-import@7.8.3(@babel/core@7.22.8): - resolution: {integrity: sha512-5gdGbFon+PszYzqs83S3E5mpi7/y/8M9eC90MRTZfduQOYW76ig6SOSPNe41IG5LoP3FGBn2N0RjVDSQiS94kQ==} + /@babel/plugin-proposal-json-strings@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-lr1peyn9kOdbYc0xr0OdHTZ5FMqS6Di+H0Fz2I/JwMzGmzJETNeOFq2pBySw6X/KFL5EWDjlJuMsUGRFb8fQgQ==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-json-strings': 7.8.3(@babel/core@7.22.5) dev: true - /@babel/plugin-syntax-export-default-from@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-ODAqWWXB/yReh/jVQDag/3/tl6lgBueQkk/TcfW/59Oykm4c8a55XloX0CTk2k2VJiFWMgHby9xNX29IbCv9dQ==} + /@babel/plugin-proposal-logical-assignment-operators@7.18.9(@babel/core@7.18.13): + resolution: {integrity: sha512-128YbMpjCrP35IOExw2Fq+x55LMP42DzhOhX2aNNIdI9avSWl2PI0yuBWarr3RYpZBSPtabfadkH2yeRiMD61Q==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-logical-assignment-operators': 7.10.4(@babel/core@7.18.13) dev: true - /@babel/plugin-syntax-export-namespace-from@7.8.3(@babel/core@7.22.8): - resolution: {integrity: sha512-MXf5laXo6c1IbEbegDmzGPwGNTsHZmEy6QGznu5Sh2UCWvueywb2ee+CCE4zQiZstxU9BMoQO9i6zUFSY0Kj0Q==} + /@babel/plugin-proposal-logical-assignment-operators@7.18.9(@babel/core@7.22.5): + resolution: {integrity: sha512-128YbMpjCrP35IOExw2Fq+x55LMP42DzhOhX2aNNIdI9avSWl2PI0yuBWarr3RYpZBSPtabfadkH2yeRiMD61Q==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-logical-assignment-operators': 7.10.4(@babel/core@7.22.5) dev: true - /@babel/plugin-syntax-flow@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-9RdCl0i+q0QExayk2nOS7853w08yLucnnPML6EN9S8fgMPVtdLDCdx/cOQ/i44Lb9UeQX9A35yaqBBOMMZxPxQ==} + /@babel/plugin-proposal-nullish-coalescing-operator@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-wQxQzxYeJqHcfppzBDnm1yAY0jSRkUXR2z8RePZYrKwMKgMlE8+Z6LUno+bd6LvbGh8Gltvy74+9pIYkr+XkKA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-nullish-coalescing-operator': 7.8.3(@babel/core@7.18.13) dev: true - /@babel/plugin-syntax-import-assertions@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-rdV97N7KqsRzeNGoWUOK6yUsWarLjE5Su/Snk9IYPU9CwkWHs4t+rTGOvffTR8XGkJMTAdLfO0xVnXm8wugIJg==} + /@babel/plugin-proposal-nullish-coalescing-operator@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-wQxQzxYeJqHcfppzBDnm1yAY0jSRkUXR2z8RePZYrKwMKgMlE8+Z6LUno+bd6LvbGh8Gltvy74+9pIYkr+XkKA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-nullish-coalescing-operator': 7.8.3(@babel/core@7.22.5) dev: true - /@babel/plugin-syntax-import-attributes@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-KwvoWDeNKPETmozyFE0P2rOLqh39EoQHNjqizrI5B8Vt0ZNS7M56s7dAiAqbYfiAYOuIzIh96z3iR2ktgu3tEg==} + /@babel/plugin-proposal-numeric-separator@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-ozlZFogPqoLm8WBr5Z8UckIoE4YQ5KESVcNudyXOR8uqIkliTEgJ3RoketfG6pmzLdeZF0H/wjE9/cCEitBl7Q==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-numeric-separator': 7.10.4(@babel/core@7.18.13) dev: true - /@babel/plugin-syntax-import-meta@7.10.4(@babel/core@7.22.8): - resolution: {integrity: sha512-Yqfm+XDx0+Prh3VSeEQCPU81yC+JWZ2pDPFSS4ZdpfZhp4MkFMaDC1UqseovEKwSUpnIL7+vK+Clp7bfh0iD7g==} + /@babel/plugin-proposal-numeric-separator@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-ozlZFogPqoLm8WBr5Z8UckIoE4YQ5KESVcNudyXOR8uqIkliTEgJ3RoketfG6pmzLdeZF0H/wjE9/cCEitBl7Q==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-numeric-separator': 7.10.4(@babel/core@7.22.5) dev: true - /@babel/plugin-syntax-json-strings@7.8.3(@babel/core@7.22.8): - resolution: {integrity: sha512-lY6kdGpWHvjoe2vk4WrAapEuBR69EMxZl+RoGRhrFGNYVK8mOPAW8VfbT/ZgrFbXlDNiiaxQnAtgVCZ6jv30EA==} + /@babel/plugin-proposal-object-rest-spread@7.12.1(@babel/core@7.12.9): + resolution: {integrity: sha512-s6SowJIjzlhx8o7lsFx5zmY4At6CTtDvgNQDdPzkBQucle58A6b/TTeEBYtyDgmcXjUTM+vE8YOGHZzzbc/ioA==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.12.9 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-object-rest-spread': 7.8.3(@babel/core@7.12.9) + '@babel/plugin-transform-parameters': 7.18.8(@babel/core@7.12.9) dev: true - /@babel/plugin-syntax-jsx@7.12.1(@babel/core@7.12.9): - resolution: {integrity: sha512-1yRi7yAtB0ETgxdY9ti/p2TivUxJkTdhu/ZbF9MshVGqOx1TdB3b7xCXs49Fupgg50N45KcAsRP/ZqWjs9SRjg==} + /@babel/plugin-proposal-object-rest-spread@7.18.9(@babel/core@7.18.13): + resolution: {integrity: sha512-kDDHQ5rflIeY5xl69CEqGEZ0KY369ehsCIEbTGb4siHG5BE9sga/T0r0OUwyZNLMmZE79E1kbsqAjwFCW4ds6Q==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.12.9 + '@babel/compat-data': 7.22.5 + '@babel/core': 7.18.13 + '@babel/helper-compilation-targets': 7.22.5(@babel/core@7.18.13) '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-object-rest-spread': 7.8.3(@babel/core@7.18.13) + '@babel/plugin-transform-parameters': 7.18.8(@babel/core@7.18.13) dev: true - /@babel/plugin-syntax-jsx@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-gvyP4hZrgrs/wWMaocvxZ44Hw0b3W8Pe+cMxc8V1ULQ07oh8VNbIRaoD1LRZVTvD+0nieDKjfgKg89sD7rrKrg==} + /@babel/plugin-proposal-object-rest-spread@7.18.9(@babel/core@7.22.5): + resolution: {integrity: sha512-kDDHQ5rflIeY5xl69CEqGEZ0KY369ehsCIEbTGb4siHG5BE9sga/T0r0OUwyZNLMmZE79E1kbsqAjwFCW4ds6Q==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/compat-data': 7.22.5 + '@babel/core': 7.22.5 + '@babel/helper-compilation-targets': 7.22.5(@babel/core@7.22.5) '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-object-rest-spread': 7.8.3(@babel/core@7.22.5) + '@babel/plugin-transform-parameters': 7.18.8(@babel/core@7.22.5) dev: true - /@babel/plugin-syntax-logical-assignment-operators@7.10.4(@babel/core@7.22.8): - resolution: {integrity: sha512-d8waShlpFDinQ5MtvGU9xDAOzKH47+FFoney2baFIoMr952hKOLp1HR7VszoZvOsV/4+RRszNY7D17ba0te0ig==} + /@babel/plugin-proposal-optional-catch-binding@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-Q40HEhs9DJQyaZfUjjn6vE8Cv4GmMHCYuMGIWUnlxH6400VGxOuwWsPt4FxXxJkC/5eOzgn0z21M9gMT4MOhbw==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-optional-catch-binding': 7.8.3(@babel/core@7.18.13) dev: true - /@babel/plugin-syntax-nullish-coalescing-operator@7.8.3(@babel/core@7.22.8): - resolution: {integrity: sha512-aSff4zPII1u2QD7y+F8oDsz19ew4IGEJg9SVW+bqwpwtfFleiQDMdzA/R+UlWDzfnHFCxxleFT0PMIrR36XLNQ==} + /@babel/plugin-proposal-optional-catch-binding@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-Q40HEhs9DJQyaZfUjjn6vE8Cv4GmMHCYuMGIWUnlxH6400VGxOuwWsPt4FxXxJkC/5eOzgn0z21M9gMT4MOhbw==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-optional-catch-binding': 7.8.3(@babel/core@7.22.5) dev: true - /@babel/plugin-syntax-numeric-separator@7.10.4(@babel/core@7.22.8): - resolution: {integrity: sha512-9H6YdfkcK/uOnY/K7/aA2xpzaAgkQn37yzWUMRK7OaPOqOpGS1+n0H5hxT9AUw9EsSjPW8SVyMJwYRtWs3X3ug==} + /@babel/plugin-proposal-optional-chaining@7.18.9(@babel/core@7.18.13): + resolution: {integrity: sha512-v5nwt4IqBXihxGsW2QmCWMDS3B3bzGIk/EQVZz2ei7f3NJl8NzAJVvUmpDW5q1CRNY+Beb/k58UAH1Km1N411w==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 + '@babel/helper-skip-transparent-expression-wrappers': 7.20.0 + '@babel/plugin-syntax-optional-chaining': 7.8.3(@babel/core@7.18.13) dev: true - /@babel/plugin-syntax-object-rest-spread@7.8.3(@babel/core@7.12.9): - resolution: {integrity: sha512-XoqMijGZb9y3y2XskN+P1wUGiVwWZ5JmoDRwx5+3GmEplNyVM2s2Dg8ILFQm8rWM48orGy5YpI5Bl8U1y7ydlA==} + /@babel/plugin-proposal-optional-chaining@7.18.9(@babel/core@7.22.5): + resolution: {integrity: sha512-v5nwt4IqBXihxGsW2QmCWMDS3B3bzGIk/EQVZz2ei7f3NJl8NzAJVvUmpDW5q1CRNY+Beb/k58UAH1Km1N411w==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.12.9 + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 + '@babel/helper-skip-transparent-expression-wrappers': 7.20.0 + '@babel/plugin-syntax-optional-chaining': 7.8.3(@babel/core@7.22.5) dev: true - /@babel/plugin-syntax-object-rest-spread@7.8.3(@babel/core@7.22.8): - resolution: {integrity: sha512-XoqMijGZb9y3y2XskN+P1wUGiVwWZ5JmoDRwx5+3GmEplNyVM2s2Dg8ILFQm8rWM48orGy5YpI5Bl8U1y7ydlA==} + /@babel/plugin-proposal-private-methods@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-nutsvktDItsNn4rpGItSNV2sz1XwS+nfU0Rg8aCx3W3NOKVzdMjJRu0O5OkgDp3ZGICSTbgRpxZoWsxoKRvbeA==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 + '@babel/helper-create-class-features-plugin': 7.21.0(@babel/core@7.18.13) '@babel/helper-plugin-utils': 7.22.5 + transitivePeerDependencies: + - supports-color dev: true - /@babel/plugin-syntax-optional-catch-binding@7.8.3(@babel/core@7.22.8): - resolution: {integrity: sha512-6VPD0Pc1lpTqw0aKoeRTMiB+kWhAoT24PA+ksWSBrFtl5SIRVpZlwN3NNPQjehA2E/91FV3RjLWoVTglWcSV3Q==} + /@babel/plugin-proposal-private-methods@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-nutsvktDItsNn4rpGItSNV2sz1XwS+nfU0Rg8aCx3W3NOKVzdMjJRu0O5OkgDp3ZGICSTbgRpxZoWsxoKRvbeA==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 + '@babel/helper-create-class-features-plugin': 7.21.0(@babel/core@7.22.5) '@babel/helper-plugin-utils': 7.22.5 + transitivePeerDependencies: + - supports-color dev: true - /@babel/plugin-syntax-optional-chaining@7.8.3(@babel/core@7.22.8): - resolution: {integrity: sha512-KoK9ErH1MBlCPxV0VANkXW2/dw4vlbGDrFgz8bmUsBGYkFRcbRwMh6cIJubdPrkxRwuGdtCk0v/wPTKbQgBjkg==} + /@babel/plugin-proposal-private-property-in-object@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-9Rysx7FOctvT5ouj5JODjAFAkgGoudQuLPamZb0v1TGLpapdNaftzifU8NTWQm0IRjqoYypdrSmyWgkocDQ8Dw==} + engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 + '@babel/helper-annotate-as-pure': 7.18.6 + '@babel/helper-create-class-features-plugin': 7.21.0(@babel/core@7.18.13) '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-private-property-in-object': 7.14.5(@babel/core@7.18.13) + transitivePeerDependencies: + - supports-color dev: true - /@babel/plugin-syntax-private-property-in-object@7.14.5(@babel/core@7.22.8): - resolution: {integrity: sha512-0wVnp9dxJ72ZUJDV27ZfbSj6iHLoytYZmh3rFcxNnvsJF3ktkzLDZPy/mA17HGsaQT3/DQsWYX1f1QGWkCoVUg==} + /@babel/plugin-proposal-private-property-in-object@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-9Rysx7FOctvT5ouj5JODjAFAkgGoudQuLPamZb0v1TGLpapdNaftzifU8NTWQm0IRjqoYypdrSmyWgkocDQ8Dw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 + '@babel/helper-annotate-as-pure': 7.18.6 + '@babel/helper-create-class-features-plugin': 7.21.0(@babel/core@7.22.5) '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-private-property-in-object': 7.14.5(@babel/core@7.22.5) + transitivePeerDependencies: + - supports-color dev: true - /@babel/plugin-syntax-top-level-await@7.14.5(@babel/core@7.22.8): - resolution: {integrity: sha512-hx++upLv5U1rgYfwe1xBQUhRmU41NEvpUvrp8jkrSCdvGSnM5/qdRMtylJ6PG5OFkBaHkbTAKTnd3/YyESRHFw==} - engines: {node: '>=6.9.0'} + /@babel/plugin-proposal-unicode-property-regex@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-2BShG/d5yoZyXZfVePH91urL5wTG6ASZU9M4o03lKK8u8UW1y08OMttBSOADTcJrnPMpvDXRG3G8fyLh4ovs8w==} + engines: {node: '>=4'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 + '@babel/helper-create-regexp-features-plugin': 7.18.6(@babel/core@7.18.13) '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-typescript@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-1mS2o03i7t1c6VzH6fdQ3OA8tcEIxwG18zIPRp+UY1Ihv6W+XZzBCVxExF9upussPXJ0xE9XRHwMoNs1ep/nRQ==} - engines: {node: '>=6.9.0'} + /@babel/plugin-proposal-unicode-property-regex@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-2BShG/d5yoZyXZfVePH91urL5wTG6ASZU9M4o03lKK8u8UW1y08OMttBSOADTcJrnPMpvDXRG3G8fyLh4ovs8w==} + engines: {node: '>=4'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 + '@babel/helper-create-regexp-features-plugin': 7.18.6(@babel/core@7.22.5) '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-syntax-unicode-sets-regex@7.18.6(@babel/core@7.22.8): - resolution: {integrity: sha512-727YkEAPwSIQTv5im8QHz3upqp92JTWhidIC81Tdx4VJYIte/VndKf1qKrfnnhPLiPghStWfvC/iFaMCQu7Nqg==} + /@babel/plugin-syntax-async-generators@7.8.4(@babel/core@7.18.13): + resolution: {integrity: sha512-tycmZxkGfZaxhMRbXlPXuVFpdWlXpir2W4AMhSJgRKzk/eDlIXOhb2LHWoLpDF7TEHylV5zNhykX6KAgHJmTNw==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-async-generators@7.8.4(@babel/core@7.22.5): + resolution: {integrity: sha512-tycmZxkGfZaxhMRbXlPXuVFpdWlXpir2W4AMhSJgRKzk/eDlIXOhb2LHWoLpDF7TEHylV5zNhykX6KAgHJmTNw==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-bigint@7.8.3(@babel/core@7.22.5): + resolution: {integrity: sha512-wnTnFlG+YxQm3vDxpGE57Pj0srRU4sHE/mDkt1qv2YJJSeUAec2ma4WLUnUPeKjyrfntVwe/N6dCXpU+zL3Npg==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-class-properties@7.12.13(@babel/core@7.18.13): + resolution: {integrity: sha512-fm4idjKla0YahUNgFNLCB0qySdsoPiZP3iQE3rky0mBUtMZ23yDJ9SJdg6dXTSDnulOVqiF3Hgr9nbXvXTQZYA==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-class-properties@7.12.13(@babel/core@7.22.5): + resolution: {integrity: sha512-fm4idjKla0YahUNgFNLCB0qySdsoPiZP3iQE3rky0mBUtMZ23yDJ9SJdg6dXTSDnulOVqiF3Hgr9nbXvXTQZYA==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-class-static-block@7.14.5(@babel/core@7.18.13): + resolution: {integrity: sha512-b+YyPmr6ldyNnM6sqYeMWE+bgJcJpO6yS4QD7ymxgH34GBPNDM/THBh8iunyvKIZztiwLH4CJZ0RxTk9emgpjw==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-class-static-block@7.14.5(@babel/core@7.22.5): + resolution: {integrity: sha512-b+YyPmr6ldyNnM6sqYeMWE+bgJcJpO6yS4QD7ymxgH34GBPNDM/THBh8iunyvKIZztiwLH4CJZ0RxTk9emgpjw==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-decorators@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-fqyLgjcxf/1yhyZ6A+yo1u9gJ7eleFQod2lkaUsF9DQ7sbbY3Ligym3L0+I2c0WmqNKDpoD9UTb1AKP3qRMOAQ==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-dynamic-import@7.8.3(@babel/core@7.18.13): + resolution: {integrity: sha512-5gdGbFon+PszYzqs83S3E5mpi7/y/8M9eC90MRTZfduQOYW76ig6SOSPNe41IG5LoP3FGBn2N0RjVDSQiS94kQ==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-dynamic-import@7.8.3(@babel/core@7.22.5): + resolution: {integrity: sha512-5gdGbFon+PszYzqs83S3E5mpi7/y/8M9eC90MRTZfduQOYW76ig6SOSPNe41IG5LoP3FGBn2N0RjVDSQiS94kQ==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-export-default-from@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-Kr//z3ujSVNx6E9z9ih5xXXMqK07VVTuqPmqGe6Mss/zW5XPeLZeSDZoP9ab/hT4wPKqAgjl2PnhPrcpk8Seew==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-export-namespace-from@7.8.3(@babel/core@7.18.13): + resolution: {integrity: sha512-MXf5laXo6c1IbEbegDmzGPwGNTsHZmEy6QGznu5Sh2UCWvueywb2ee+CCE4zQiZstxU9BMoQO9i6zUFSY0Kj0Q==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-export-namespace-from@7.8.3(@babel/core@7.22.5): + resolution: {integrity: sha512-MXf5laXo6c1IbEbegDmzGPwGNTsHZmEy6QGznu5Sh2UCWvueywb2ee+CCE4zQiZstxU9BMoQO9i6zUFSY0Kj0Q==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-flow@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-LUbR+KNTBWCUAqRG9ex5Gnzu2IOkt8jRJbHHXFT9q+L9zm7M/QQbEqXyw1n1pohYvOyWC8CjeyjrSaIwiYjK7A==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-import-assertions@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-/DU3RXad9+bZwrgWJQKbr39gYbJpLJHezqEzRzi/BHRlJ9zsQb4CK2CA/5apllXNomwA1qHwzvHl+AdEmC5krQ==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-import-assertions@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-/DU3RXad9+bZwrgWJQKbr39gYbJpLJHezqEzRzi/BHRlJ9zsQb4CK2CA/5apllXNomwA1qHwzvHl+AdEmC5krQ==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-import-meta@7.10.4(@babel/core@7.22.5): + resolution: {integrity: sha512-Yqfm+XDx0+Prh3VSeEQCPU81yC+JWZ2pDPFSS4ZdpfZhp4MkFMaDC1UqseovEKwSUpnIL7+vK+Clp7bfh0iD7g==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-json-strings@7.8.3(@babel/core@7.18.13): + resolution: {integrity: sha512-lY6kdGpWHvjoe2vk4WrAapEuBR69EMxZl+RoGRhrFGNYVK8mOPAW8VfbT/ZgrFbXlDNiiaxQnAtgVCZ6jv30EA==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-json-strings@7.8.3(@babel/core@7.22.5): + resolution: {integrity: sha512-lY6kdGpWHvjoe2vk4WrAapEuBR69EMxZl+RoGRhrFGNYVK8mOPAW8VfbT/ZgrFbXlDNiiaxQnAtgVCZ6jv30EA==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-jsx@7.12.1(@babel/core@7.12.9): + resolution: {integrity: sha512-1yRi7yAtB0ETgxdY9ti/p2TivUxJkTdhu/ZbF9MshVGqOx1TdB3b7xCXs49Fupgg50N45KcAsRP/ZqWjs9SRjg==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.12.9 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-jsx@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-6mmljtAedFGTWu2p/8WIORGwy+61PLgOMPOdazc7YoJ9ZCWUyFy3A6CpPkRKLKD1ToAesxX8KGEViAiLo9N+7Q==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-jsx@7.18.6(@babel/core@7.20.5): + resolution: {integrity: sha512-6mmljtAedFGTWu2p/8WIORGwy+61PLgOMPOdazc7YoJ9ZCWUyFy3A6CpPkRKLKD1ToAesxX8KGEViAiLo9N+7Q==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.20.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-jsx@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-6mmljtAedFGTWu2p/8WIORGwy+61PLgOMPOdazc7YoJ9ZCWUyFy3A6CpPkRKLKD1ToAesxX8KGEViAiLo9N+7Q==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + + /@babel/plugin-syntax-logical-assignment-operators@7.10.4(@babel/core@7.18.13): + resolution: {integrity: sha512-d8waShlpFDinQ5MtvGU9xDAOzKH47+FFoney2baFIoMr952hKOLp1HR7VszoZvOsV/4+RRszNY7D17ba0te0ig==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-logical-assignment-operators@7.10.4(@babel/core@7.22.5): + resolution: {integrity: sha512-d8waShlpFDinQ5MtvGU9xDAOzKH47+FFoney2baFIoMr952hKOLp1HR7VszoZvOsV/4+RRszNY7D17ba0te0ig==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-nullish-coalescing-operator@7.8.3(@babel/core@7.18.13): + resolution: {integrity: sha512-aSff4zPII1u2QD7y+F8oDsz19ew4IGEJg9SVW+bqwpwtfFleiQDMdzA/R+UlWDzfnHFCxxleFT0PMIrR36XLNQ==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-nullish-coalescing-operator@7.8.3(@babel/core@7.22.5): + resolution: {integrity: sha512-aSff4zPII1u2QD7y+F8oDsz19ew4IGEJg9SVW+bqwpwtfFleiQDMdzA/R+UlWDzfnHFCxxleFT0PMIrR36XLNQ==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-numeric-separator@7.10.4(@babel/core@7.18.13): + resolution: {integrity: sha512-9H6YdfkcK/uOnY/K7/aA2xpzaAgkQn37yzWUMRK7OaPOqOpGS1+n0H5hxT9AUw9EsSjPW8SVyMJwYRtWs3X3ug==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-numeric-separator@7.10.4(@babel/core@7.22.5): + resolution: {integrity: sha512-9H6YdfkcK/uOnY/K7/aA2xpzaAgkQn37yzWUMRK7OaPOqOpGS1+n0H5hxT9AUw9EsSjPW8SVyMJwYRtWs3X3ug==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-object-rest-spread@7.8.3(@babel/core@7.12.9): + resolution: {integrity: sha512-XoqMijGZb9y3y2XskN+P1wUGiVwWZ5JmoDRwx5+3GmEplNyVM2s2Dg8ILFQm8rWM48orGy5YpI5Bl8U1y7ydlA==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.12.9 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-object-rest-spread@7.8.3(@babel/core@7.18.13): + resolution: {integrity: sha512-XoqMijGZb9y3y2XskN+P1wUGiVwWZ5JmoDRwx5+3GmEplNyVM2s2Dg8ILFQm8rWM48orGy5YpI5Bl8U1y7ydlA==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-object-rest-spread@7.8.3(@babel/core@7.22.5): + resolution: {integrity: sha512-XoqMijGZb9y3y2XskN+P1wUGiVwWZ5JmoDRwx5+3GmEplNyVM2s2Dg8ILFQm8rWM48orGy5YpI5Bl8U1y7ydlA==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-optional-catch-binding@7.8.3(@babel/core@7.18.13): + resolution: {integrity: sha512-6VPD0Pc1lpTqw0aKoeRTMiB+kWhAoT24PA+ksWSBrFtl5SIRVpZlwN3NNPQjehA2E/91FV3RjLWoVTglWcSV3Q==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-optional-catch-binding@7.8.3(@babel/core@7.22.5): + resolution: {integrity: sha512-6VPD0Pc1lpTqw0aKoeRTMiB+kWhAoT24PA+ksWSBrFtl5SIRVpZlwN3NNPQjehA2E/91FV3RjLWoVTglWcSV3Q==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-optional-chaining@7.8.3(@babel/core@7.18.13): + resolution: {integrity: sha512-KoK9ErH1MBlCPxV0VANkXW2/dw4vlbGDrFgz8bmUsBGYkFRcbRwMh6cIJubdPrkxRwuGdtCk0v/wPTKbQgBjkg==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-optional-chaining@7.8.3(@babel/core@7.22.5): + resolution: {integrity: sha512-KoK9ErH1MBlCPxV0VANkXW2/dw4vlbGDrFgz8bmUsBGYkFRcbRwMh6cIJubdPrkxRwuGdtCk0v/wPTKbQgBjkg==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-private-property-in-object@7.14.5(@babel/core@7.18.13): + resolution: {integrity: sha512-0wVnp9dxJ72ZUJDV27ZfbSj6iHLoytYZmh3rFcxNnvsJF3ktkzLDZPy/mA17HGsaQT3/DQsWYX1f1QGWkCoVUg==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-private-property-in-object@7.14.5(@babel/core@7.22.5): + resolution: {integrity: sha512-0wVnp9dxJ72ZUJDV27ZfbSj6iHLoytYZmh3rFcxNnvsJF3ktkzLDZPy/mA17HGsaQT3/DQsWYX1f1QGWkCoVUg==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-top-level-await@7.14.5(@babel/core@7.18.13): + resolution: {integrity: sha512-hx++upLv5U1rgYfwe1xBQUhRmU41NEvpUvrp8jkrSCdvGSnM5/qdRMtylJ6PG5OFkBaHkbTAKTnd3/YyESRHFw==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-top-level-await@7.14.5(@babel/core@7.22.5): + resolution: {integrity: sha512-hx++upLv5U1rgYfwe1xBQUhRmU41NEvpUvrp8jkrSCdvGSnM5/qdRMtylJ6PG5OFkBaHkbTAKTnd3/YyESRHFw==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-typescript@7.20.0(@babel/core@7.20.5): + resolution: {integrity: sha512-rd9TkG+u1CExzS4SM1BlMEhMXwFLKVjOAFFCDx9PbX5ycJWDoWMcwdJH9RhkPu1dOgn5TrxLot/Gx6lWFuAUNQ==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.20.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-syntax-typescript@7.20.0(@babel/core@7.22.5): + resolution: {integrity: sha512-rd9TkG+u1CExzS4SM1BlMEhMXwFLKVjOAFFCDx9PbX5ycJWDoWMcwdJH9RhkPu1dOgn5TrxLot/Gx6lWFuAUNQ==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-transform-arrow-functions@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-9S9X9RUefzrsHZmKMbDXxweEH+YlE8JJEuat9FdvW9Qh1cw7W64jELCtWNkPBPX5En45uy28KGvA/AySqUh8CQ==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-transform-arrow-functions@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-9S9X9RUefzrsHZmKMbDXxweEH+YlE8JJEuat9FdvW9Qh1cw7W64jELCtWNkPBPX5En45uy28KGvA/AySqUh8CQ==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-transform-async-to-generator@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-ARE5wZLKnTgPW7/1ftQmSi1CmkqqHo2DNmtztFhvgtOWSDfq0Cq9/9L+KnZNYSNrydBekhW3rwShduf59RoXag==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-module-imports': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + '@babel/helper-remap-async-to-generator': 7.18.9(@babel/core@7.18.13) + transitivePeerDependencies: + - supports-color + dev: true + + /@babel/plugin-transform-async-to-generator@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-ARE5wZLKnTgPW7/1ftQmSi1CmkqqHo2DNmtztFhvgtOWSDfq0Cq9/9L+KnZNYSNrydBekhW3rwShduf59RoXag==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-module-imports': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + '@babel/helper-remap-async-to-generator': 7.18.9(@babel/core@7.22.5) + transitivePeerDependencies: + - supports-color + dev: true + + /@babel/plugin-transform-block-scoped-functions@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-ExUcOqpPWnliRcPqves5HJcJOvHvIIWfuS4sroBUenPuMdmW+SMHDakmtS7qOo13sVppmUijqeTv7qqGsvURpQ==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-transform-block-scoped-functions@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-ExUcOqpPWnliRcPqves5HJcJOvHvIIWfuS4sroBUenPuMdmW+SMHDakmtS7qOo13sVppmUijqeTv7qqGsvURpQ==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-transform-block-scoping@7.18.9(@babel/core@7.18.13): + resolution: {integrity: sha512-5sDIJRV1KtQVEbt/EIBwGy4T01uYIo4KRB3VUqzkhrAIOGx7AoctL9+Ux88btY0zXdDyPJ9mW+bg+v+XEkGmtw==} engines: {node: '>=6.9.0'} peerDependencies: - '@babel/core': ^7.0.0 + '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-create-regexp-features-plugin': 7.22.6(@babel/core@7.22.8) + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-arrow-functions@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-26lTNXoVRdAnsaDXPpvCNUq+OVWEVC6bx7Vvz9rC53F2bagUWW4u4ii2+h8Fejfh7RYqPxn+libeFBBck9muEw==} + /@babel/plugin-transform-block-scoping@7.18.9(@babel/core@7.22.5): + resolution: {integrity: sha512-5sDIJRV1KtQVEbt/EIBwGy4T01uYIo4KRB3VUqzkhrAIOGx7AoctL9+Ux88btY0zXdDyPJ9mW+bg+v+XEkGmtw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-async-generator-functions@7.22.7(@babel/core@7.22.8): - resolution: {integrity: sha512-7HmE7pk/Fmke45TODvxvkxRMV9RazV+ZZzhOL9AG8G29TLrr3jkjwF7uJfxZ30EoXpO+LJkq4oA8NjO2DTnEDg==} + /@babel/plugin-transform-classes@7.18.9(@babel/core@7.18.13): + resolution: {integrity: sha512-EkRQxsxoytpTlKJmSPYrsOMjCILacAjtSVkd4gChEe2kXjFCun3yohhW5I7plXJhCemM0gKsaGMcO8tinvCA5g==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 + '@babel/helper-annotate-as-pure': 7.18.6 '@babel/helper-environment-visitor': 7.22.5 + '@babel/helper-function-name': 7.22.5 + '@babel/helper-optimise-call-expression': 7.18.6 '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-remap-async-to-generator': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-syntax-async-generators': 7.8.4(@babel/core@7.22.8) + '@babel/helper-replace-supers': 7.20.7 + '@babel/helper-split-export-declaration': 7.22.5 + globals: 11.12.0 transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-transform-async-to-generator@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-b1A8D8ZzE/VhNDoV1MSJTnpKkCG5bJo+19R4o4oy03zM7ws8yEMK755j61Dc3EyvdysbqH5BOOTquJ7ZX9C6vQ==} + /@babel/plugin-transform-classes@7.18.9(@babel/core@7.22.5): + resolution: {integrity: sha512-EkRQxsxoytpTlKJmSPYrsOMjCILacAjtSVkd4gChEe2kXjFCun3yohhW5I7plXJhCemM0gKsaGMcO8tinvCA5g==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-module-imports': 7.22.5 + '@babel/core': 7.22.5 + '@babel/helper-annotate-as-pure': 7.18.6 + '@babel/helper-environment-visitor': 7.22.5 + '@babel/helper-function-name': 7.22.5 + '@babel/helper-optimise-call-expression': 7.18.6 '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-remap-async-to-generator': 7.22.5(@babel/core@7.22.8) + '@babel/helper-replace-supers': 7.20.7 + '@babel/helper-split-export-declaration': 7.22.5 + globals: 11.12.0 transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-transform-block-scoped-functions@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-tdXZ2UdknEKQWKJP1KMNmuF5Lx3MymtMN/pvA+p/VEkhK8jVcQ1fzSy8KM9qRYhAf2/lV33hoMPKI/xaI9sADA==} + /@babel/plugin-transform-computed-properties@7.18.9(@babel/core@7.18.13): + resolution: {integrity: sha512-+i0ZU1bCDymKakLxn5srGHrsAPRELC2WIbzwjLhHW9SIE1cPYkLCL0NlnXMZaM1vhfgA2+M7hySk42VBvrkBRw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-block-scoping@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-EcACl1i5fSQ6bt+YGuU/XGCeZKStLmyVGytWkpyhCLeQVA0eu6Wtiw92V+I1T/hnezUv7j74dA/Ro69gWcU+hg==} + /@babel/plugin-transform-computed-properties@7.18.9(@babel/core@7.22.5): + resolution: {integrity: sha512-+i0ZU1bCDymKakLxn5srGHrsAPRELC2WIbzwjLhHW9SIE1cPYkLCL0NlnXMZaM1vhfgA2+M7hySk42VBvrkBRw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-class-properties@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-nDkQ0NfkOhPTq8YCLiWNxp1+f9fCobEjCb0n8WdbNUBc4IB5V7P1QnX9IjpSoquKrXF5SKojHleVNs2vGeHCHQ==} + /@babel/plugin-transform-destructuring@7.18.13(@babel/core@7.18.13): + resolution: {integrity: sha512-TodpQ29XekIsex2A+YJPj5ax2plkGa8YYY6mFjCohk/IG9IY42Rtuj1FuDeemfg2ipxIFLzPeA83SIBnlhSIow==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-create-class-features-plugin': 7.22.6(@babel/core@7.22.8) + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 - transitivePeerDependencies: - - supports-color dev: true - /@babel/plugin-transform-class-static-block@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-SPToJ5eYZLxlnp1UzdARpOGeC2GbHvr9d/UV0EukuVx8atktg194oe+C5BqQ8jRTkgLRVOPYeXRSBg1IlMoVRA==} + /@babel/plugin-transform-destructuring@7.18.13(@babel/core@7.22.5): + resolution: {integrity: sha512-TodpQ29XekIsex2A+YJPj5ax2plkGa8YYY6mFjCohk/IG9IY42Rtuj1FuDeemfg2ipxIFLzPeA83SIBnlhSIow==} engines: {node: '>=6.9.0'} peerDependencies: - '@babel/core': ^7.12.0 + '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-create-class-features-plugin': 7.22.6(@babel/core@7.22.8) + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-class-static-block': 7.14.5(@babel/core@7.22.8) - transitivePeerDependencies: - - supports-color dev: true - /@babel/plugin-transform-classes@7.22.6(@babel/core@7.22.8): - resolution: {integrity: sha512-58EgM6nuPNG6Py4Z3zSuu0xWu2VfodiMi72Jt5Kj2FECmaYk1RrTXA45z6KBFsu9tRgwQDwIiY4FXTt+YsSFAQ==} + /@babel/plugin-transform-dotall-regex@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-6S3jpun1eEbAxq7TdjLotAsl4WpQI9DxfkycRcKrjhQYzU87qpXdknpBg/e+TdcMehqGnLFi7tnFUBR02Vq6wg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-annotate-as-pure': 7.22.5 - '@babel/helper-compilation-targets': 7.22.6(@babel/core@7.22.8) - '@babel/helper-environment-visitor': 7.22.5 - '@babel/helper-function-name': 7.22.5 - '@babel/helper-optimise-call-expression': 7.22.5 + '@babel/core': 7.18.13 + '@babel/helper-create-regexp-features-plugin': 7.18.6(@babel/core@7.18.13) '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-replace-supers': 7.22.5 - '@babel/helper-split-export-declaration': 7.22.6 - globals: 11.12.0 - transitivePeerDependencies: - - supports-color dev: true - /@babel/plugin-transform-computed-properties@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-4GHWBgRf0krxPX+AaPtgBAlTgTeZmqDynokHOX7aqqAB4tHs3U2Y02zH6ETFdLZGcg9UQSD1WCmkVrE9ErHeOg==} + /@babel/plugin-transform-dotall-regex@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-6S3jpun1eEbAxq7TdjLotAsl4WpQI9DxfkycRcKrjhQYzU87qpXdknpBg/e+TdcMehqGnLFi7tnFUBR02Vq6wg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 + '@babel/helper-create-regexp-features-plugin': 7.18.6(@babel/core@7.22.5) '@babel/helper-plugin-utils': 7.22.5 - '@babel/template': 7.22.5 dev: true - /@babel/plugin-transform-destructuring@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-GfqcFuGW8vnEqTUBM7UtPd5A4q797LTvvwKxXTgRsFjoqaJiEg9deBG6kWeQYkVEL569NpnmpC0Pkr/8BLKGnQ==} + /@babel/plugin-transform-duplicate-keys@7.18.9(@babel/core@7.18.13): + resolution: {integrity: sha512-d2bmXCtZXYc59/0SanQKbiWINadaJXqtvIQIzd4+hNwkWBgyCd5F/2t1kXoUdvPMrxzPvhK6EMQRROxsue+mfw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-dotall-regex@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-5/Yk9QxCQCl+sOIB1WelKnVRxTJDSAIxtJLL2/pqL14ZVlbH0fUQUZa/T5/UnQtBNgghR7mfB8ERBKyKPCi7Vw==} + /@babel/plugin-transform-duplicate-keys@7.18.9(@babel/core@7.22.5): + resolution: {integrity: sha512-d2bmXCtZXYc59/0SanQKbiWINadaJXqtvIQIzd4+hNwkWBgyCd5F/2t1kXoUdvPMrxzPvhK6EMQRROxsue+mfw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-create-regexp-features-plugin': 7.22.6(@babel/core@7.22.8) + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-duplicate-keys@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-dEnYD+9BBgld5VBXHnF/DbYGp3fqGMsyxKbtD1mDyIA7AkTSpKXFhCVuj/oQVOoALfBs77DudA0BE4d5mcpmqw==} + /@babel/plugin-transform-exponentiation-operator@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-wzEtc0+2c88FVR34aQmiz56dxEkxr2g8DQb/KfaFa1JYXOFVsbhvAonFN6PwVWj++fKmku8NP80plJ5Et4wqHw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 + '@babel/helper-builder-binary-assignment-operator-visitor': 7.18.9 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-dynamic-import@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-0MC3ppTB1AMxd8fXjSrbPa7LT9hrImt+/fcj+Pg5YMD7UQyWp/02+JWpdnCymmsXwIx5Z+sYn1bwCn4ZJNvhqQ==} + /@babel/plugin-transform-exponentiation-operator@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-wzEtc0+2c88FVR34aQmiz56dxEkxr2g8DQb/KfaFa1JYXOFVsbhvAonFN6PwVWj++fKmku8NP80plJ5Et4wqHw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 + '@babel/helper-builder-binary-assignment-operator-visitor': 7.18.9 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-dynamic-import': 7.8.3(@babel/core@7.22.8) dev: true - /@babel/plugin-transform-exponentiation-operator@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-vIpJFNM/FjZ4rh1myqIya9jXwrwwgFRHPjT3DkUA9ZLHuzox8jiXkOLvwm1H+PQIP3CqfC++WPKeuDi0Sjdj1g==} + /@babel/plugin-transform-flow-strip-types@7.18.9(@babel/core@7.18.13): + resolution: {integrity: sha512-+G6rp2zRuOAInY5wcggsx4+QVao1qPM0osC9fTUVlAV3zOrzTCnrMAFVnR6+a3T8wz1wFIH7KhYMcMB3u1n80A==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-builder-binary-assignment-operator-visitor': 7.22.5 + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-flow': 7.18.6(@babel/core@7.18.13) dev: true - /@babel/plugin-transform-export-namespace-from@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-X4hhm7FRnPgd4nDA4b/5V280xCx6oL7Oob5+9qVS5C13Zq4bh1qq7LU0GgRU6b5dBWBvhGaXYVB4AcN6+ol6vg==} + /@babel/plugin-transform-for-of@7.18.8(@babel/core@7.18.13): + resolution: {integrity: sha512-yEfTRnjuskWYo0k1mHUqrVWaZwrdq8AYbfrpqULOJOaucGSp4mNMVps+YtA8byoevxS/urwU75vyhQIxcCgiBQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-export-namespace-from': 7.8.3(@babel/core@7.22.8) dev: true - /@babel/plugin-transform-flow-strip-types@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-tujNbZdxdG0/54g/oua8ISToaXTFBf8EnSb5PgQSciIXWOWKX3S4+JR7ZE9ol8FZwf9kxitzkGQ+QWeov/mCiA==} + /@babel/plugin-transform-for-of@7.18.8(@babel/core@7.22.5): + resolution: {integrity: sha512-yEfTRnjuskWYo0k1mHUqrVWaZwrdq8AYbfrpqULOJOaucGSp4mNMVps+YtA8byoevxS/urwU75vyhQIxcCgiBQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-flow': 7.22.5(@babel/core@7.22.8) dev: true - /@babel/plugin-transform-for-of@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-3kxQjX1dU9uudwSshyLeEipvrLjBCVthCgeTp6CzE/9JYrlAIaeekVxRpCWsDDfYTfRZRoCeZatCQvwo+wvK8A==} + /@babel/plugin-transform-function-name@7.18.9(@babel/core@7.18.13): + resolution: {integrity: sha512-WvIBoRPaJQ5yVHzcnJFor7oS5Ls0PYixlTYE63lCj2RtdQEl15M68FXQlxnG6wdraJIXRdR7KI+hQ7q/9QjrCQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 + '@babel/helper-compilation-targets': 7.22.5(@babel/core@7.18.13) + '@babel/helper-function-name': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-function-name@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-UIzQNMS0p0HHiQm3oelztj+ECwFnj+ZRV4KnguvlsD2of1whUeM6o7wGNj6oLwcDoAXQ8gEqfgC24D+VdIcevg==} + /@babel/plugin-transform-function-name@7.18.9(@babel/core@7.22.5): + resolution: {integrity: sha512-WvIBoRPaJQ5yVHzcnJFor7oS5Ls0PYixlTYE63lCj2RtdQEl15M68FXQlxnG6wdraJIXRdR7KI+hQ7q/9QjrCQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-compilation-targets': 7.22.6(@babel/core@7.22.8) + '@babel/core': 7.22.5 + '@babel/helper-compilation-targets': 7.22.5(@babel/core@7.22.5) '@babel/helper-function-name': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-json-strings@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-DuCRB7fu8MyTLbEQd1ew3R85nx/88yMoqo2uPSjevMj3yoN7CDM8jkgrY0wmVxfJZyJ/B9fE1iq7EQppWQmR5A==} + /@babel/plugin-transform-literals@7.18.9(@babel/core@7.18.13): + resolution: {integrity: sha512-IFQDSRoTPnrAIrI5zoZv73IFeZu2dhu6irxQjY9rNjTT53VmKg9fenjvoiOWOkJ6mm4jKVPtdMzBY98Fp4Z4cg==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-transform-literals@7.18.9(@babel/core@7.22.5): + resolution: {integrity: sha512-IFQDSRoTPnrAIrI5zoZv73IFeZu2dhu6irxQjY9rNjTT53VmKg9fenjvoiOWOkJ6mm4jKVPtdMzBY98Fp4Z4cg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-json-strings': 7.8.3(@babel/core@7.22.8) dev: true - /@babel/plugin-transform-literals@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-fTLj4D79M+mepcw3dgFBTIDYpbcB9Sm0bpm4ppXPaO+U+PKFFyV9MGRvS0gvGw62sd10kT5lRMKXAADb9pWy8g==} + /@babel/plugin-transform-member-expression-literals@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-qSF1ihLGO3q+/g48k85tUjD033C29TNTVB2paCwZPVmOsjn9pClvYYrM2VeJpBY2bcNkuny0YUyTNRyRxJ54KA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-logical-assignment-operators@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-MQQOUW1KL8X0cDWfbwYP+TbVbZm16QmQXJQ+vndPtH/BoO0lOKpVoEDMI7+PskYxH+IiE0tS8xZye0qr1lGzSA==} + /@babel/plugin-transform-member-expression-literals@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-qSF1ihLGO3q+/g48k85tUjD033C29TNTVB2paCwZPVmOsjn9pClvYYrM2VeJpBY2bcNkuny0YUyTNRyRxJ54KA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-logical-assignment-operators': 7.10.4(@babel/core@7.22.8) dev: true - /@babel/plugin-transform-member-expression-literals@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-RZEdkNtzzYCFl9SE9ATaUMTj2hqMb4StarOJLrZRbqqU4HSBE7UlBw9WBWQiDzrJZJdUWiMTVDI6Gv/8DPvfew==} + /@babel/plugin-transform-modules-amd@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-Pra5aXsmTsOnjM3IajS8rTaLCy++nGM4v3YR4esk5PCsyg9z8NA5oQLwxzMUtDBd8F+UmVza3VxoAaWCbzH1rg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 + '@babel/helper-module-transforms': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + babel-plugin-dynamic-import-node: 2.3.3 + transitivePeerDependencies: + - supports-color + dev: true + + /@babel/plugin-transform-modules-amd@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-Pra5aXsmTsOnjM3IajS8rTaLCy++nGM4v3YR4esk5PCsyg9z8NA5oQLwxzMUtDBd8F+UmVza3VxoAaWCbzH1rg==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-module-transforms': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 + babel-plugin-dynamic-import-node: 2.3.3 + transitivePeerDependencies: + - supports-color dev: true - /@babel/plugin-transform-modules-amd@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-R+PTfLTcYEmb1+kK7FNkhQ1gP4KgjpSO6HfH9+f8/yfp2Nt3ggBjiVpRwmwTlfqZLafYKJACy36yDXlEmI9HjQ==} + /@babel/plugin-transform-modules-commonjs@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-Qfv2ZOWikpvmedXQJDSbxNqy7Xr/j2Y8/KfijM0iJyKkBTmWuvCA1yeH1yDM7NJhBW/2aXxeucLj6i80/LAJ/Q==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 '@babel/helper-module-transforms': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 + '@babel/helper-simple-access': 7.22.5 + babel-plugin-dynamic-import-node: 2.3.3 transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-transform-modules-commonjs@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-B4pzOXj+ONRmuaQTg05b3y/4DuFz3WcCNAXPLb2Q0GT0TrGKGxNKV4jwsXts+StaM0LQczZbOpj8o1DLPDJIiA==} + /@babel/plugin-transform-modules-commonjs@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-Qfv2ZOWikpvmedXQJDSbxNqy7Xr/j2Y8/KfijM0iJyKkBTmWuvCA1yeH1yDM7NJhBW/2aXxeucLj6i80/LAJ/Q==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-module-transforms': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 '@babel/helper-simple-access': 7.22.5 + babel-plugin-dynamic-import-node: 2.3.3 transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-transform-modules-systemjs@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-emtEpoaTMsOs6Tzz+nbmcePl6AKVtS1yC4YNAeMun9U8YCsgadPNxnOPQ8GhHFB2qdx+LZu9LgoC0Lthuu05DQ==} + /@babel/plugin-transform-modules-systemjs@7.18.9(@babel/core@7.18.13): + resolution: {integrity: sha512-zY/VSIbbqtoRoJKo2cDTewL364jSlZGvn0LKOf9ntbfxOvjfmyrdtEEOAdswOswhZEb8UH3jDkCKHd1sPgsS0A==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 '@babel/helper-hoist-variables': 7.22.5 '@babel/helper-module-transforms': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 '@babel/helper-validator-identifier': 7.22.5 + babel-plugin-dynamic-import-node: 2.3.3 transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-transform-modules-umd@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-+S6kzefN/E1vkSsKx8kmQuqeQsvCKCd1fraCM7zXm4SFoggI099Tr4G8U81+5gtMdUeMQ4ipdQffbKLX0/7dBQ==} + /@babel/plugin-transform-modules-systemjs@7.18.9(@babel/core@7.22.5): + resolution: {integrity: sha512-zY/VSIbbqtoRoJKo2cDTewL364jSlZGvn0LKOf9ntbfxOvjfmyrdtEEOAdswOswhZEb8UH3jDkCKHd1sPgsS0A==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 + '@babel/helper-hoist-variables': 7.22.5 '@babel/helper-module-transforms': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 + '@babel/helper-validator-identifier': 7.22.5 + babel-plugin-dynamic-import-node: 2.3.3 transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-transform-named-capturing-groups-regex@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-YgLLKmS3aUBhHaxp5hi1WJTgOUb/NCuDHzGT9z9WTt3YG+CPRhJs6nprbStx6DnWM4dh6gt7SU3sZodbZ08adQ==} + /@babel/plugin-transform-modules-umd@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-dcegErExVeXcRqNtkRU/z8WlBLnvD4MRnHgNs3MytRO1Mn1sHRyhbcpYbVMGclAqOjdW+9cfkdZno9dFdfKLfQ==} engines: {node: '>=6.9.0'} peerDependencies: - '@babel/core': ^7.0.0 + '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-create-regexp-features-plugin': 7.22.6(@babel/core@7.22.8) + '@babel/core': 7.18.13 + '@babel/helper-module-transforms': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 + transitivePeerDependencies: + - supports-color dev: true - /@babel/plugin-transform-new-target@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-AsF7K0Fx/cNKVyk3a+DW0JLo+Ua598/NxMRvxDnkpCIGFh43+h/v2xyhRUYf6oD8gE4QtL83C7zZVghMjHd+iw==} + /@babel/plugin-transform-modules-umd@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-dcegErExVeXcRqNtkRU/z8WlBLnvD4MRnHgNs3MytRO1Mn1sHRyhbcpYbVMGclAqOjdW+9cfkdZno9dFdfKLfQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 + '@babel/helper-module-transforms': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + transitivePeerDependencies: + - supports-color + dev: true + + /@babel/plugin-transform-named-capturing-groups-regex@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-UmEOGF8XgaIqD74bC8g7iV3RYj8lMf0Bw7NJzvnS9qQhM4mg+1WHKotUIdjxgD2RGrgFLZZPCFPFj3P/kVDYhg==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-create-regexp-features-plugin': 7.18.6(@babel/core@7.18.13) '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-nullish-coalescing-operator@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-6CF8g6z1dNYZ/VXok5uYkkBBICHZPiGEl7oDnAx2Mt1hlHVHOSIKWJaXHjQJA5VB43KZnXZDIexMchY4y2PGdA==} + /@babel/plugin-transform-named-capturing-groups-regex@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-UmEOGF8XgaIqD74bC8g7iV3RYj8lMf0Bw7NJzvnS9qQhM4mg+1WHKotUIdjxgD2RGrgFLZZPCFPFj3P/kVDYhg==} engines: {node: '>=6.9.0'} peerDependencies: - '@babel/core': ^7.0.0-0 + '@babel/core': ^7.0.0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 + '@babel/helper-create-regexp-features-plugin': 7.18.6(@babel/core@7.22.5) '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-nullish-coalescing-operator': 7.8.3(@babel/core@7.22.8) dev: true - /@babel/plugin-transform-numeric-separator@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-NbslED1/6M+sXiwwtcAB/nieypGw02Ejf4KtDeMkCEpP6gWFMX1wI9WKYua+4oBneCCEmulOkRpwywypVZzs/g==} + /@babel/plugin-transform-new-target@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-DjwFA/9Iu3Z+vrAn+8pBUGcjhxKguSMlsFqeCKbhb9BAV756v0krzVK04CRDi/4aqmk8BsHb4a/gFcaA5joXRw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-numeric-separator': 7.10.4(@babel/core@7.22.8) dev: true - /@babel/plugin-transform-object-rest-spread@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-Kk3lyDmEslH9DnvCDA1s1kkd3YWQITiBOHngOtDL9Pt6BZjzqb6hiOlb8VfjiiQJ2unmegBqZu0rx5RxJb5vmQ==} + /@babel/plugin-transform-new-target@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-DjwFA/9Iu3Z+vrAn+8pBUGcjhxKguSMlsFqeCKbhb9BAV756v0krzVK04CRDi/4aqmk8BsHb4a/gFcaA5joXRw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/compat-data': 7.22.6 - '@babel/core': 7.22.8 - '@babel/helper-compilation-targets': 7.22.6(@babel/core@7.22.8) + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-object-rest-spread': 7.8.3(@babel/core@7.22.8) - '@babel/plugin-transform-parameters': 7.22.5(@babel/core@7.22.8) dev: true - /@babel/plugin-transform-object-super@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-klXqyaT9trSjIUrcsYIfETAzmOEZL3cBYqOYLJxBHfMFFggmXOv+NYSX/Jbs9mzMVESw/WycLFPRx8ba/b2Ipw==} + /@babel/plugin-transform-object-super@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-uvGz6zk+pZoS1aTZrOvrbj6Pp/kK2mp45t2B+bTDre2UgsZZ8EZLSJtUg7m/no0zOJUWgFONpB7Zv9W2tSaFlA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-replace-supers': 7.22.5 + '@babel/helper-replace-supers': 7.20.7 transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-transform-optional-catch-binding@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-pH8orJahy+hzZje5b8e2QIlBWQvGpelS76C63Z+jhZKsmzfNaPQ+LaW6dcJ9bxTpo1mtXbgHwy765Ro3jftmUg==} + /@babel/plugin-transform-object-super@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-uvGz6zk+pZoS1aTZrOvrbj6Pp/kK2mp45t2B+bTDre2UgsZZ8EZLSJtUg7m/no0zOJUWgFONpB7Zv9W2tSaFlA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-optional-catch-binding': 7.8.3(@babel/core@7.22.8) + '@babel/helper-replace-supers': 7.20.7 + transitivePeerDependencies: + - supports-color dev: true - /@babel/plugin-transform-optional-chaining@7.22.6(@babel/core@7.22.8): - resolution: {integrity: sha512-Vd5HiWml0mDVtcLHIoEU5sw6HOUW/Zk0acLs/SAeuLzkGNOPc9DB4nkUajemhCmTIz3eiaKREZn2hQQqF79YTg==} + /@babel/plugin-transform-parameters@7.18.8(@babel/core@7.12.9): + resolution: {integrity: sha512-ivfbE3X2Ss+Fj8nnXvKJS6sjRG4gzwPMsP+taZC+ZzEGjAYlvENixmt1sZ5Ca6tWls+BlKSGKPJ6OOXvXCbkFg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.12.9 '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-skip-transparent-expression-wrappers': 7.22.5 - '@babel/plugin-syntax-optional-chaining': 7.8.3(@babel/core@7.22.8) dev: true - /@babel/plugin-transform-parameters@7.22.5(@babel/core@7.12.9): - resolution: {integrity: sha512-AVkFUBurORBREOmHRKo06FjHYgjrabpdqRSwq6+C7R5iTCZOsM4QbcB27St0a4U6fffyAOqh3s/qEfybAhfivg==} + /@babel/plugin-transform-parameters@7.18.8(@babel/core@7.18.13): + resolution: {integrity: sha512-ivfbE3X2Ss+Fj8nnXvKJS6sjRG4gzwPMsP+taZC+ZzEGjAYlvENixmt1sZ5Ca6tWls+BlKSGKPJ6OOXvXCbkFg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.12.9 + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-parameters@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-AVkFUBurORBREOmHRKo06FjHYgjrabpdqRSwq6+C7R5iTCZOsM4QbcB27St0a4U6fffyAOqh3s/qEfybAhfivg==} + /@babel/plugin-transform-parameters@7.18.8(@babel/core@7.22.5): + resolution: {integrity: sha512-ivfbE3X2Ss+Fj8nnXvKJS6sjRG4gzwPMsP+taZC+ZzEGjAYlvENixmt1sZ5Ca6tWls+BlKSGKPJ6OOXvXCbkFg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-private-methods@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-PPjh4gyrQnGe97JTalgRGMuU4icsZFnWkzicB/fUtzlKUqvsWBKEpPPfr5a2JiyirZkHxnAqkQMO5Z5B2kK3fA==} + /@babel/plugin-transform-property-literals@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-cYcs6qlgafTud3PAzrrRNbQtfpQ8+y/+M5tKmksS9+M1ckbH6kzY8MrexEM9mcA6JDsukE19iIRvAyYl463sMg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-create-class-features-plugin': 7.22.6(@babel/core@7.22.8) + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 - transitivePeerDependencies: - - supports-color dev: true - /@babel/plugin-transform-private-property-in-object@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-/9xnaTTJcVoBtSSmrVyhtSvO3kbqS2ODoh2juEU72c3aYonNF0OMGiaz2gjukyKM2wBBYJP38S4JiE0Wfb5VMQ==} + /@babel/plugin-transform-property-literals@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-cYcs6qlgafTud3PAzrrRNbQtfpQ8+y/+M5tKmksS9+M1ckbH6kzY8MrexEM9mcA6JDsukE19iIRvAyYl463sMg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-annotate-as-pure': 7.22.5 - '@babel/helper-create-class-features-plugin': 7.22.6(@babel/core@7.22.8) + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-private-property-in-object': 7.14.5(@babel/core@7.22.8) - transitivePeerDependencies: - - supports-color dev: true - /@babel/plugin-transform-property-literals@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-TiOArgddK3mK/x1Qwf5hay2pxI6wCZnvQqrFSqbtg1GLl2JcNMitVH/YnqjP+M31pLUeTfzY1HAXFDnUBV30rQ==} + /@babel/plugin-transform-react-display-name@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-TV4sQ+T013n61uMoygyMRm+xf04Bd5oqFpv2jAEQwSZ8NwQA7zeRPg1LMVg2PWi3zWBz+CLKD+v5bcpZ/BS0aA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-react-display-name@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-PVk3WPYudRF5z4GKMEYUrLjPl38fJSKNaEOkFuoprioowGuWN6w2RKznuFNSlJx7pzzXXStPUnNSOEO0jL5EVw==} + /@babel/plugin-transform-react-display-name@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-TV4sQ+T013n61uMoygyMRm+xf04Bd5oqFpv2jAEQwSZ8NwQA7zeRPg1LMVg2PWi3zWBz+CLKD+v5bcpZ/BS0aA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-react-jsx-development@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-bDhuzwWMuInwCYeDeMzyi7TaBgRQei6DqxhbyniL7/VG4RSS7HtSL2QbY4eESy1KJqlWt8g3xeEBGPuo+XqC8A==} + /@babel/plugin-transform-react-jsx-development@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-SA6HEjwYFKF7WDjWcMcMGUimmw/nhNRDWxr+KaLSCrkD/LMDBvWRmHAYgE1HDeF8KUuI8OAu+RT6EOtKxSW2qA==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/plugin-transform-react-jsx': 7.19.0(@babel/core@7.18.13) + dev: true + + /@babel/plugin-transform-react-jsx-development@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-SA6HEjwYFKF7WDjWcMcMGUimmw/nhNRDWxr+KaLSCrkD/LMDBvWRmHAYgE1HDeF8KUuI8OAu+RT6EOtKxSW2qA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 - '@babel/plugin-transform-react-jsx': 7.22.5(@babel/core@7.22.8) + '@babel/core': 7.22.5 + '@babel/plugin-transform-react-jsx': 7.19.0(@babel/core@7.22.5) dev: true - /@babel/plugin-transform-react-jsx-self@7.22.5(@babel/core@7.22.8): + /@babel/plugin-transform-react-jsx-self@7.22.5(@babel/core@7.22.5): resolution: {integrity: sha512-nTh2ogNUtxbiSbxaT4Ds6aXnXEipHweN9YRgOX/oNXdf0cCrGn/+2LozFa3lnPV5D90MkjhgckCPBrsoSc1a7g==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-react-jsx-source@7.22.5(@babel/core@7.22.8): + /@babel/plugin-transform-react-jsx-source@7.22.5(@babel/core@7.22.5): resolution: {integrity: sha512-yIiRO6yobeEIaI0RTbIr8iAK9FcBHLtZq0S89ZPjDLQXBA4xvghaKqI0etp/tF3htTM0sazJKKLz9oEiGRtu7w==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-transform-react-jsx@7.18.10(@babel/core@7.22.5): + resolution: {integrity: sha512-gCy7Iikrpu3IZjYZolFE4M1Sm+nrh1/6za2Ewj77Z+XirT4TsbJcvOFOyF+fRPwU6AKKK136CZxx6L8AbSFG6A==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-annotate-as-pure': 7.18.6 + '@babel/helper-module-imports': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-jsx': 7.18.6(@babel/core@7.22.5) + '@babel/types': 7.22.5 + dev: true + + /@babel/plugin-transform-react-jsx@7.19.0(@babel/core@7.18.13): + resolution: {integrity: sha512-UVEvX3tXie3Szm3emi1+G63jyw1w5IcMY0FSKM+CRnKRI5Mr1YbCNgsSTwoTwKphQEG9P+QqmuRFneJPZuHNhg==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-annotate-as-pure': 7.18.6 + '@babel/helper-module-imports': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-jsx': 7.18.6(@babel/core@7.18.13) + '@babel/types': 7.22.5 dev: true - /@babel/plugin-transform-react-jsx@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-rog5gZaVbUip5iWDMTYbVM15XQq+RkUKhET/IHR6oizR+JEoN6CAfTTuHcK4vwUyzca30qqHqEpzBOnaRMWYMA==} + /@babel/plugin-transform-react-jsx@7.19.0(@babel/core@7.22.5): + resolution: {integrity: sha512-UVEvX3tXie3Szm3emi1+G63jyw1w5IcMY0FSKM+CRnKRI5Mr1YbCNgsSTwoTwKphQEG9P+QqmuRFneJPZuHNhg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-annotate-as-pure': 7.22.5 + '@babel/core': 7.22.5 + '@babel/helper-annotate-as-pure': 7.18.6 '@babel/helper-module-imports': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-jsx': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-syntax-jsx': 7.18.6(@babel/core@7.22.5) '@babel/types': 7.22.5 dev: true - /@babel/plugin-transform-react-pure-annotations@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-gP4k85wx09q+brArVinTXhWiyzLl9UpmGva0+mWyKxk6JZequ05x3eUcIUE+FyttPKJFRRVtAvQaJ6YF9h1ZpA==} + /@babel/plugin-transform-react-pure-annotations@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-I8VfEPg9r2TRDdvnHgPepTKvuRomzA8+u+nhY7qSI1fR2hRNebasZEETLyM5mAUr0Ku56OkXJ0I7NHJnO6cJiQ==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-annotate-as-pure': 7.18.6 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-transform-react-pure-annotations@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-I8VfEPg9r2TRDdvnHgPepTKvuRomzA8+u+nhY7qSI1fR2hRNebasZEETLyM5mAUr0Ku56OkXJ0I7NHJnO6cJiQ==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-annotate-as-pure': 7.18.6 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-transform-regenerator@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-poqRI2+qiSdeldcz4wTSTXBRryoq3Gc70ye7m7UD5Ww0nE29IXqMl6r7Nd15WBgRd74vloEMlShtH6CKxVzfmQ==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + regenerator-transform: 0.15.0 + dev: true + + /@babel/plugin-transform-regenerator@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-poqRI2+qiSdeldcz4wTSTXBRryoq3Gc70ye7m7UD5Ww0nE29IXqMl6r7Nd15WBgRd74vloEMlShtH6CKxVzfmQ==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + regenerator-transform: 0.15.0 + dev: true + + /@babel/plugin-transform-reserved-words@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-oX/4MyMoypzHjFrT1CdivfKZ+XvIPMFXwwxHp/r0Ddy2Vuomt4HDFGmft1TAY2yiTKiNSsh3kjBAzcM8kSdsjA==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-transform-reserved-words@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-oX/4MyMoypzHjFrT1CdivfKZ+XvIPMFXwwxHp/r0Ddy2Vuomt4HDFGmft1TAY2yiTKiNSsh3kjBAzcM8kSdsjA==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-transform-shorthand-properties@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-eCLXXJqv8okzg86ywZJbRn19YJHU4XUa55oz2wbHhaQVn/MM+XhukiT7SYqp/7o00dg52Rj51Ny+Ecw4oyoygw==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-transform-shorthand-properties@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-eCLXXJqv8okzg86ywZJbRn19YJHU4XUa55oz2wbHhaQVn/MM+XhukiT7SYqp/7o00dg52Rj51Ny+Ecw4oyoygw==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-transform-spread@7.18.9(@babel/core@7.18.13): + resolution: {integrity: sha512-39Q814wyoOPtIB/qGopNIL9xDChOE1pNU0ZY5dO0owhiVt/5kFm4li+/bBtwc7QotG0u5EPzqhZdjMtmqBqyQA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-annotate-as-pure': 7.22.5 + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 + '@babel/helper-skip-transparent-expression-wrappers': 7.20.0 dev: true - /@babel/plugin-transform-regenerator@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-rR7KePOE7gfEtNTh9Qw+iO3Q/e4DEsoQ+hdvM6QUDH7JRJ5qxq5AA52ZzBWbI5i9lfNuvySgOGP8ZN7LAmaiPw==} + /@babel/plugin-transform-spread@7.18.9(@babel/core@7.22.5): + resolution: {integrity: sha512-39Q814wyoOPtIB/qGopNIL9xDChOE1pNU0ZY5dO0owhiVt/5kFm4li+/bBtwc7QotG0u5EPzqhZdjMtmqBqyQA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 - regenerator-transform: 0.15.1 + '@babel/helper-skip-transparent-expression-wrappers': 7.20.0 dev: true - /@babel/plugin-transform-reserved-words@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-DTtGKFRQUDm8svigJzZHzb/2xatPc6TzNvAIJ5GqOKDsGFYgAskjRulbR/vGsPKq3OPqtexnz327qYpP57RFyA==} + /@babel/plugin-transform-sticky-regex@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-kfiDrDQ+PBsQDO85yj1icueWMfGfJFKN1KCkndygtu/C9+XUfydLC8Iv5UYJqRwy4zk8EcplRxEOeLyjq1gm6Q==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-shorthand-properties@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-vM4fq9IXHscXVKzDv5itkO1X52SmdFBFcMIBZ2FRn2nqVYqw6dBexUgMvAjHW+KXpPPViD/Yo3GrDEBaRC0QYA==} + /@babel/plugin-transform-sticky-regex@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-kfiDrDQ+PBsQDO85yj1icueWMfGfJFKN1KCkndygtu/C9+XUfydLC8Iv5UYJqRwy4zk8EcplRxEOeLyjq1gm6Q==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-spread@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-5ZzDQIGyvN4w8+dMmpohL6MBo+l2G7tfC/O2Dg7/hjpgeWvUx8FzfeOKxGog9IimPa4YekaQ9PlDqTLOljkcxg==} + /@babel/plugin-transform-template-literals@7.18.9(@babel/core@7.18.13): + resolution: {integrity: sha512-S8cOWfT82gTezpYOiVaGHrCbhlHgKhQt8XH5ES46P2XWmX92yisoZywf5km75wv5sYcXDUCLMmMxOLCtthDgMA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 - '@babel/helper-skip-transparent-expression-wrappers': 7.22.5 dev: true - /@babel/plugin-transform-sticky-regex@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-zf7LuNpHG0iEeiyCNwX4j3gDg1jgt1k3ZdXBKbZSoA3BbGQGvMiSvfbZRR3Dr3aeJe3ooWFZxOOG3IRStYp2Bw==} + /@babel/plugin-transform-template-literals@7.18.9(@babel/core@7.22.5): + resolution: {integrity: sha512-S8cOWfT82gTezpYOiVaGHrCbhlHgKhQt8XH5ES46P2XWmX92yisoZywf5km75wv5sYcXDUCLMmMxOLCtthDgMA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-template-literals@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-5ciOehRNf+EyUeewo8NkbQiUs4d6ZxiHo6BcBcnFlgiJfu16q0bQUw9Jvo0b0gBKFG1SMhDSjeKXSYuJLeFSMA==} + /@babel/plugin-transform-typeof-symbol@7.18.9(@babel/core@7.18.13): + resolution: {integrity: sha512-SRfwTtF11G2aemAZWivL7PD+C9z52v9EvMqH9BuYbabyPuKUvSWks3oCg6041pT925L4zVFqaVBeECwsmlguEw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-typeof-symbol@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-bYkI5lMzL4kPii4HHEEChkD0rkc+nvnlR6+o/qdqR6zrm0Sv/nodmyLhlq2DO0YKLUNd2VePmPRjJXSBh9OIdA==} + /@babel/plugin-transform-typeof-symbol@7.18.9(@babel/core@7.22.5): + resolution: {integrity: sha512-SRfwTtF11G2aemAZWivL7PD+C9z52v9EvMqH9BuYbabyPuKUvSWks3oCg6041pT925L4zVFqaVBeECwsmlguEw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-typescript@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-SMubA9S7Cb5sGSFFUlqxyClTA9zWJ8qGQrppNUm05LtFuN1ELRFNndkix4zUJrC9F+YivWwa1dHMSyo0e0N9dA==} + /@babel/plugin-transform-typescript@7.21.3(@babel/core@7.20.5): + resolution: {integrity: sha512-RQxPz6Iqt8T0uw/WsJNReuBpWpBqs/n7mNo18sKLoTbMp+UrEekhH+pKSVC7gWz+DNjo9gryfV8YzCiT45RgMw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-annotate-as-pure': 7.22.5 - '@babel/helper-create-class-features-plugin': 7.22.6(@babel/core@7.22.8) + '@babel/core': 7.20.5 + '@babel/helper-annotate-as-pure': 7.18.6 + '@babel/helper-create-class-features-plugin': 7.21.0(@babel/core@7.20.5) '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-syntax-typescript': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-syntax-typescript': 7.20.0(@babel/core@7.20.5) transitivePeerDependencies: - supports-color dev: true - /@babel/plugin-transform-unicode-escapes@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-biEmVg1IYB/raUO5wT1tgfacCef15Fbzhkx493D3urBI++6hpJ+RFG4SrWMn0NEZLfvilqKf3QDrRVZHo08FYg==} + /@babel/plugin-transform-typescript@7.21.3(@babel/core@7.22.5): + resolution: {integrity: sha512-RQxPz6Iqt8T0uw/WsJNReuBpWpBqs/n7mNo18sKLoTbMp+UrEekhH+pKSVC7gWz+DNjo9gryfV8YzCiT45RgMw==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 + '@babel/helper-annotate-as-pure': 7.18.6 + '@babel/helper-create-class-features-plugin': 7.21.0(@babel/core@7.22.5) '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-syntax-typescript': 7.20.0(@babel/core@7.22.5) + transitivePeerDependencies: + - supports-color dev: true - /@babel/plugin-transform-unicode-property-regex@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-HCCIb+CbJIAE6sXn5CjFQXMwkCClcOfPCzTlilJ8cUatfzwHlWQkbtV0zD338u9dZskwvuOYTuuaMaA8J5EI5A==} + /@babel/plugin-transform-unicode-escapes@7.18.10(@babel/core@7.18.13): + resolution: {integrity: sha512-kKAdAI+YzPgGY/ftStBFXTI1LZFju38rYThnfMykS+IXy8BVx+res7s2fxf1l8I35DV2T97ezo6+SGrXz6B3iQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-create-regexp-features-plugin': 7.22.6(@babel/core@7.22.8) + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-unicode-regex@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-028laaOKptN5vHJf9/Arr/HiJekMd41hOEZYvNsrsXqJ7YPYuX2bQxh31fkZzGmq3YqHRJzYFFAVYvKfMPKqyg==} + /@babel/plugin-transform-unicode-escapes@7.18.10(@babel/core@7.22.5): + resolution: {integrity: sha512-kKAdAI+YzPgGY/ftStBFXTI1LZFju38rYThnfMykS+IXy8BVx+res7s2fxf1l8I35DV2T97ezo6+SGrXz6B3iQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-create-regexp-features-plugin': 7.22.6(@babel/core@7.22.8) + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 dev: true - /@babel/plugin-transform-unicode-sets-regex@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-lhMfi4FC15j13eKrh3DnYHjpGj6UKQHtNKTbtc1igvAhRy4+kLhV07OpLcsN0VgDEw/MjAvJO4BdMJsHwMhzCg==} + /@babel/plugin-transform-unicode-regex@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-gE7A6Lt7YLnNOL3Pb9BNeZvi+d8l7tcRrG4+pwJjK9hD2xX4mEvjlQW60G9EEmfXVYRPv9VRQcyegIVHCql/AA==} engines: {node: '>=6.9.0'} peerDependencies: - '@babel/core': ^7.0.0 + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-create-regexp-features-plugin': 7.18.6(@babel/core@7.18.13) + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/plugin-transform-unicode-regex@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-gE7A6Lt7YLnNOL3Pb9BNeZvi+d8l7tcRrG4+pwJjK9hD2xX4mEvjlQW60G9EEmfXVYRPv9VRQcyegIVHCql/AA==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-create-regexp-features-plugin': 7.18.6(@babel/core@7.22.5) + '@babel/helper-plugin-utils': 7.22.5 + dev: true + + /@babel/preset-env@7.18.10(@babel/core@7.18.13): + resolution: {integrity: sha512-wVxs1yjFdW3Z/XkNfXKoblxoHgbtUF7/l3PvvP4m02Qz9TZ6uZGxRVYjSQeR87oQmHco9zWitW5J82DJ7sCjvA==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-create-regexp-features-plugin': 7.22.6(@babel/core@7.22.8) + '@babel/compat-data': 7.22.5 + '@babel/core': 7.18.13 + '@babel/helper-compilation-targets': 7.22.5(@babel/core@7.18.13) '@babel/helper-plugin-utils': 7.22.5 + '@babel/helper-validator-option': 7.22.5 + '@babel/plugin-bugfix-safari-id-destructuring-collision-in-function-expression': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-bugfix-v8-spread-parameters-in-optional-chaining': 7.18.9(@babel/core@7.18.13) + '@babel/plugin-proposal-async-generator-functions': 7.18.10(@babel/core@7.18.13) + '@babel/plugin-proposal-class-properties': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-proposal-class-static-block': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-proposal-dynamic-import': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-proposal-export-namespace-from': 7.18.9(@babel/core@7.18.13) + '@babel/plugin-proposal-json-strings': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-proposal-logical-assignment-operators': 7.18.9(@babel/core@7.18.13) + '@babel/plugin-proposal-nullish-coalescing-operator': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-proposal-numeric-separator': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-proposal-object-rest-spread': 7.18.9(@babel/core@7.18.13) + '@babel/plugin-proposal-optional-catch-binding': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-proposal-optional-chaining': 7.18.9(@babel/core@7.18.13) + '@babel/plugin-proposal-private-methods': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-proposal-private-property-in-object': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-proposal-unicode-property-regex': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-syntax-async-generators': 7.8.4(@babel/core@7.18.13) + '@babel/plugin-syntax-class-properties': 7.12.13(@babel/core@7.18.13) + '@babel/plugin-syntax-class-static-block': 7.14.5(@babel/core@7.18.13) + '@babel/plugin-syntax-dynamic-import': 7.8.3(@babel/core@7.18.13) + '@babel/plugin-syntax-export-namespace-from': 7.8.3(@babel/core@7.18.13) + '@babel/plugin-syntax-import-assertions': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-syntax-json-strings': 7.8.3(@babel/core@7.18.13) + '@babel/plugin-syntax-logical-assignment-operators': 7.10.4(@babel/core@7.18.13) + '@babel/plugin-syntax-nullish-coalescing-operator': 7.8.3(@babel/core@7.18.13) + '@babel/plugin-syntax-numeric-separator': 7.10.4(@babel/core@7.18.13) + '@babel/plugin-syntax-object-rest-spread': 7.8.3(@babel/core@7.18.13) + '@babel/plugin-syntax-optional-catch-binding': 7.8.3(@babel/core@7.18.13) + '@babel/plugin-syntax-optional-chaining': 7.8.3(@babel/core@7.18.13) + '@babel/plugin-syntax-private-property-in-object': 7.14.5(@babel/core@7.18.13) + '@babel/plugin-syntax-top-level-await': 7.14.5(@babel/core@7.18.13) + '@babel/plugin-transform-arrow-functions': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-transform-async-to-generator': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-transform-block-scoped-functions': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-transform-block-scoping': 7.18.9(@babel/core@7.18.13) + '@babel/plugin-transform-classes': 7.18.9(@babel/core@7.18.13) + '@babel/plugin-transform-computed-properties': 7.18.9(@babel/core@7.18.13) + '@babel/plugin-transform-destructuring': 7.18.13(@babel/core@7.18.13) + '@babel/plugin-transform-dotall-regex': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-transform-duplicate-keys': 7.18.9(@babel/core@7.18.13) + '@babel/plugin-transform-exponentiation-operator': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-transform-for-of': 7.18.8(@babel/core@7.18.13) + '@babel/plugin-transform-function-name': 7.18.9(@babel/core@7.18.13) + '@babel/plugin-transform-literals': 7.18.9(@babel/core@7.18.13) + '@babel/plugin-transform-member-expression-literals': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-transform-modules-amd': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-transform-modules-commonjs': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-transform-modules-systemjs': 7.18.9(@babel/core@7.18.13) + '@babel/plugin-transform-modules-umd': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-transform-named-capturing-groups-regex': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-transform-new-target': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-transform-object-super': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-transform-parameters': 7.18.8(@babel/core@7.18.13) + '@babel/plugin-transform-property-literals': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-transform-regenerator': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-transform-reserved-words': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-transform-shorthand-properties': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-transform-spread': 7.18.9(@babel/core@7.18.13) + '@babel/plugin-transform-sticky-regex': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-transform-template-literals': 7.18.9(@babel/core@7.18.13) + '@babel/plugin-transform-typeof-symbol': 7.18.9(@babel/core@7.18.13) + '@babel/plugin-transform-unicode-escapes': 7.18.10(@babel/core@7.18.13) + '@babel/plugin-transform-unicode-regex': 7.18.6(@babel/core@7.18.13) + '@babel/preset-modules': 0.1.5(@babel/core@7.18.13) + '@babel/types': 7.22.5 + babel-plugin-polyfill-corejs2: 0.3.2(@babel/core@7.18.13) + babel-plugin-polyfill-corejs3: 0.5.3(@babel/core@7.18.13) + babel-plugin-polyfill-regenerator: 0.4.0(@babel/core@7.18.13) + core-js-compat: 3.25.0 + semver: 6.3.0 + transitivePeerDependencies: + - supports-color dev: true - /@babel/preset-env@7.22.7(@babel/core@7.22.8): - resolution: {integrity: sha512-1whfDtW+CzhETuzYXfcgZAh8/GFMeEbz0V5dVgya8YeJyCU6Y/P2Gnx4Qb3MylK68Zu9UiwUvbPMPTpFAOJ+sQ==} + /@babel/preset-env@7.18.10(@babel/core@7.22.5): + resolution: {integrity: sha512-wVxs1yjFdW3Z/XkNfXKoblxoHgbtUF7/l3PvvP4m02Qz9TZ6uZGxRVYjSQeR87oQmHco9zWitW5J82DJ7sCjvA==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/compat-data': 7.22.6 - '@babel/core': 7.22.8 - '@babel/helper-compilation-targets': 7.22.6(@babel/core@7.22.8) + '@babel/compat-data': 7.22.5 + '@babel/core': 7.22.5 + '@babel/helper-compilation-targets': 7.22.5(@babel/core@7.22.5) '@babel/helper-plugin-utils': 7.22.5 '@babel/helper-validator-option': 7.22.5 - '@babel/plugin-bugfix-safari-id-destructuring-collision-in-function-expression': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-bugfix-v8-spread-parameters-in-optional-chaining': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-proposal-private-property-in-object': 7.21.0-placeholder-for-preset-env.2(@babel/core@7.22.8) - '@babel/plugin-syntax-async-generators': 7.8.4(@babel/core@7.22.8) - '@babel/plugin-syntax-class-properties': 7.12.13(@babel/core@7.22.8) - '@babel/plugin-syntax-class-static-block': 7.14.5(@babel/core@7.22.8) - '@babel/plugin-syntax-dynamic-import': 7.8.3(@babel/core@7.22.8) - '@babel/plugin-syntax-export-namespace-from': 7.8.3(@babel/core@7.22.8) - '@babel/plugin-syntax-import-assertions': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-syntax-import-attributes': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-syntax-import-meta': 7.10.4(@babel/core@7.22.8) - '@babel/plugin-syntax-json-strings': 7.8.3(@babel/core@7.22.8) - '@babel/plugin-syntax-logical-assignment-operators': 7.10.4(@babel/core@7.22.8) - '@babel/plugin-syntax-nullish-coalescing-operator': 7.8.3(@babel/core@7.22.8) - '@babel/plugin-syntax-numeric-separator': 7.10.4(@babel/core@7.22.8) - '@babel/plugin-syntax-object-rest-spread': 7.8.3(@babel/core@7.22.8) - '@babel/plugin-syntax-optional-catch-binding': 7.8.3(@babel/core@7.22.8) - '@babel/plugin-syntax-optional-chaining': 7.8.3(@babel/core@7.22.8) - '@babel/plugin-syntax-private-property-in-object': 7.14.5(@babel/core@7.22.8) - '@babel/plugin-syntax-top-level-await': 7.14.5(@babel/core@7.22.8) - '@babel/plugin-syntax-unicode-sets-regex': 7.18.6(@babel/core@7.22.8) - '@babel/plugin-transform-arrow-functions': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-async-generator-functions': 7.22.7(@babel/core@7.22.8) - '@babel/plugin-transform-async-to-generator': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-block-scoped-functions': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-block-scoping': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-class-properties': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-class-static-block': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-classes': 7.22.6(@babel/core@7.22.8) - '@babel/plugin-transform-computed-properties': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-destructuring': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-dotall-regex': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-duplicate-keys': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-dynamic-import': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-exponentiation-operator': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-export-namespace-from': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-for-of': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-function-name': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-json-strings': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-literals': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-logical-assignment-operators': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-member-expression-literals': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-modules-amd': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-modules-commonjs': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-modules-systemjs': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-modules-umd': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-named-capturing-groups-regex': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-new-target': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-nullish-coalescing-operator': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-numeric-separator': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-object-rest-spread': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-object-super': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-optional-catch-binding': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-optional-chaining': 7.22.6(@babel/core@7.22.8) - '@babel/plugin-transform-parameters': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-private-methods': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-private-property-in-object': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-property-literals': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-regenerator': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-reserved-words': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-shorthand-properties': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-spread': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-sticky-regex': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-template-literals': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-typeof-symbol': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-unicode-escapes': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-unicode-property-regex': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-unicode-regex': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-unicode-sets-regex': 7.22.5(@babel/core@7.22.8) - '@babel/preset-modules': 0.1.5(@babel/core@7.22.8) + '@babel/plugin-bugfix-safari-id-destructuring-collision-in-function-expression': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-bugfix-v8-spread-parameters-in-optional-chaining': 7.18.9(@babel/core@7.22.5) + '@babel/plugin-proposal-async-generator-functions': 7.18.10(@babel/core@7.22.5) + '@babel/plugin-proposal-class-properties': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-proposal-class-static-block': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-proposal-dynamic-import': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-proposal-export-namespace-from': 7.18.9(@babel/core@7.22.5) + '@babel/plugin-proposal-json-strings': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-proposal-logical-assignment-operators': 7.18.9(@babel/core@7.22.5) + '@babel/plugin-proposal-nullish-coalescing-operator': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-proposal-numeric-separator': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-proposal-object-rest-spread': 7.18.9(@babel/core@7.22.5) + '@babel/plugin-proposal-optional-catch-binding': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-proposal-optional-chaining': 7.18.9(@babel/core@7.22.5) + '@babel/plugin-proposal-private-methods': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-proposal-private-property-in-object': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-proposal-unicode-property-regex': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-syntax-async-generators': 7.8.4(@babel/core@7.22.5) + '@babel/plugin-syntax-class-properties': 7.12.13(@babel/core@7.22.5) + '@babel/plugin-syntax-class-static-block': 7.14.5(@babel/core@7.22.5) + '@babel/plugin-syntax-dynamic-import': 7.8.3(@babel/core@7.22.5) + '@babel/plugin-syntax-export-namespace-from': 7.8.3(@babel/core@7.22.5) + '@babel/plugin-syntax-import-assertions': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-syntax-json-strings': 7.8.3(@babel/core@7.22.5) + '@babel/plugin-syntax-logical-assignment-operators': 7.10.4(@babel/core@7.22.5) + '@babel/plugin-syntax-nullish-coalescing-operator': 7.8.3(@babel/core@7.22.5) + '@babel/plugin-syntax-numeric-separator': 7.10.4(@babel/core@7.22.5) + '@babel/plugin-syntax-object-rest-spread': 7.8.3(@babel/core@7.22.5) + '@babel/plugin-syntax-optional-catch-binding': 7.8.3(@babel/core@7.22.5) + '@babel/plugin-syntax-optional-chaining': 7.8.3(@babel/core@7.22.5) + '@babel/plugin-syntax-private-property-in-object': 7.14.5(@babel/core@7.22.5) + '@babel/plugin-syntax-top-level-await': 7.14.5(@babel/core@7.22.5) + '@babel/plugin-transform-arrow-functions': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-transform-async-to-generator': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-transform-block-scoped-functions': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-transform-block-scoping': 7.18.9(@babel/core@7.22.5) + '@babel/plugin-transform-classes': 7.18.9(@babel/core@7.22.5) + '@babel/plugin-transform-computed-properties': 7.18.9(@babel/core@7.22.5) + '@babel/plugin-transform-destructuring': 7.18.13(@babel/core@7.22.5) + '@babel/plugin-transform-dotall-regex': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-transform-duplicate-keys': 7.18.9(@babel/core@7.22.5) + '@babel/plugin-transform-exponentiation-operator': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-transform-for-of': 7.18.8(@babel/core@7.22.5) + '@babel/plugin-transform-function-name': 7.18.9(@babel/core@7.22.5) + '@babel/plugin-transform-literals': 7.18.9(@babel/core@7.22.5) + '@babel/plugin-transform-member-expression-literals': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-transform-modules-amd': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-transform-modules-commonjs': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-transform-modules-systemjs': 7.18.9(@babel/core@7.22.5) + '@babel/plugin-transform-modules-umd': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-transform-named-capturing-groups-regex': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-transform-new-target': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-transform-object-super': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-transform-parameters': 7.18.8(@babel/core@7.22.5) + '@babel/plugin-transform-property-literals': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-transform-regenerator': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-transform-reserved-words': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-transform-shorthand-properties': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-transform-spread': 7.18.9(@babel/core@7.22.5) + '@babel/plugin-transform-sticky-regex': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-transform-template-literals': 7.18.9(@babel/core@7.22.5) + '@babel/plugin-transform-typeof-symbol': 7.18.9(@babel/core@7.22.5) + '@babel/plugin-transform-unicode-escapes': 7.18.10(@babel/core@7.22.5) + '@babel/plugin-transform-unicode-regex': 7.18.6(@babel/core@7.22.5) + '@babel/preset-modules': 0.1.5(@babel/core@7.22.5) '@babel/types': 7.22.5 - '@nicolo-ribaudo/semver-v6': 6.3.3 - babel-plugin-polyfill-corejs2: 0.4.4(@babel/core@7.22.8) - babel-plugin-polyfill-corejs3: 0.8.2(@babel/core@7.22.8) - babel-plugin-polyfill-regenerator: 0.5.1(@babel/core@7.22.8) - core-js-compat: 3.31.1 + babel-plugin-polyfill-corejs2: 0.3.2(@babel/core@7.22.5) + babel-plugin-polyfill-corejs3: 0.5.3(@babel/core@7.22.5) + babel-plugin-polyfill-regenerator: 0.4.0(@babel/core@7.22.5) + core-js-compat: 3.25.0 + semver: 6.3.0 transitivePeerDependencies: - supports-color dev: true - /@babel/preset-flow@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-ta2qZ+LSiGCrP5pgcGt8xMnnkXQrq8Sa4Ulhy06BOlF5QbLw9q5hIx7bn5MrsvyTGAfh6kTOo07Q+Pfld/8Y5Q==} + /@babel/preset-flow@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-E7BDhL64W6OUqpuyHnSroLnqyRTcG6ZdOBl1OKI/QK/HJfplqK/S3sq1Cckx7oTodJ5yOXyfw7rEADJ6UjoQDQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 '@babel/helper-plugin-utils': 7.22.5 '@babel/helper-validator-option': 7.22.5 - '@babel/plugin-transform-flow-strip-types': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-flow-strip-types': 7.18.9(@babel/core@7.18.13) + dev: true + + /@babel/preset-modules@0.1.5(@babel/core@7.18.13): + resolution: {integrity: sha512-A57th6YRG7oR3cq/yt/Y84MvGgE0eJG2F1JLhKuyG+jFxEgrd/HAMJatiFtmOiZurz+0DkrvbheCLaV5f2JfjA==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + '@babel/plugin-proposal-unicode-property-regex': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-transform-dotall-regex': 7.18.6(@babel/core@7.18.13) + '@babel/types': 7.22.5 + esutils: 2.0.3 dev: true - /@babel/preset-modules@0.1.5(@babel/core@7.22.8): + /@babel/preset-modules@0.1.5(@babel/core@7.22.5): resolution: {integrity: sha512-A57th6YRG7oR3cq/yt/Y84MvGgE0eJG2F1JLhKuyG+jFxEgrd/HAMJatiFtmOiZurz+0DkrvbheCLaV5f2JfjA==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 - '@babel/plugin-proposal-unicode-property-regex': 7.18.6(@babel/core@7.22.8) - '@babel/plugin-transform-dotall-regex': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-proposal-unicode-property-regex': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-transform-dotall-regex': 7.18.6(@babel/core@7.22.5) '@babel/types': 7.22.5 esutils: 2.0.3 dev: true - /@babel/preset-react@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-M+Is3WikOpEJHgR385HbuCITPTaPRaNkibTEa9oiofmJvIsrceb4yp9RL9Kb+TE8LznmeyZqpP+Lopwcx59xPQ==} + /@babel/preset-react@7.18.6(@babel/core@7.18.13): + resolution: {integrity: sha512-zXr6atUmyYdiWRVLOZahakYmOBHtWc2WGCkP8PYTgZi0iJXDY2CN180TdrIW4OGOAdLc7TifzDIvtx6izaRIzg==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-plugin-utils': 7.22.5 + '@babel/helper-validator-option': 7.22.5 + '@babel/plugin-transform-react-display-name': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-transform-react-jsx': 7.19.0(@babel/core@7.18.13) + '@babel/plugin-transform-react-jsx-development': 7.18.6(@babel/core@7.18.13) + '@babel/plugin-transform-react-pure-annotations': 7.18.6(@babel/core@7.18.13) + dev: true + + /@babel/preset-react@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-zXr6atUmyYdiWRVLOZahakYmOBHtWc2WGCkP8PYTgZi0iJXDY2CN180TdrIW4OGOAdLc7TifzDIvtx6izaRIzg==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-plugin-utils': 7.22.5 '@babel/helper-validator-option': 7.22.5 - '@babel/plugin-transform-react-display-name': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-react-jsx': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-react-jsx-development': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-react-pure-annotations': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-react-display-name': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-transform-react-jsx': 7.19.0(@babel/core@7.22.5) + '@babel/plugin-transform-react-jsx-development': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-transform-react-pure-annotations': 7.18.6(@babel/core@7.22.5) dev: true - /@babel/preset-typescript@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-YbPaal9LxztSGhmndR46FmAbkJ/1fAsw293tSU+I5E5h+cnJ3d4GTwyUgGYmOXJYdGA+uNePle4qbaRzj2NISQ==} + /@babel/preset-typescript@7.18.6(@babel/core@7.20.5): + resolution: {integrity: sha512-s9ik86kXBAnD760aybBucdpnLsAt0jK1xqJn2juOn9lkOvSHV60os5hxoVJsPzMQxvnUJFAlkont2DvvaYEBtQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.20.5 '@babel/helper-plugin-utils': 7.22.5 '@babel/helper-validator-option': 7.22.5 - '@babel/plugin-syntax-jsx': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-modules-commonjs': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-typescript': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-transform-typescript': 7.21.3(@babel/core@7.20.5) transitivePeerDependencies: - supports-color dev: true - /@babel/register@7.22.5(@babel/core@7.22.8): - resolution: {integrity: sha512-vV6pm/4CijSQ8Y47RH5SopXzursN35RQINfGJkmOlcpAtGuf94miFvIPhCKGQN7WGIcsgG1BHEX2KVdTYwTwUQ==} + /@babel/preset-typescript@7.18.6(@babel/core@7.22.5): + resolution: {integrity: sha512-s9ik86kXBAnD760aybBucdpnLsAt0jK1xqJn2juOn9lkOvSHV60os5hxoVJsPzMQxvnUJFAlkont2DvvaYEBtQ==} engines: {node: '>=6.9.0'} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 + '@babel/helper-plugin-utils': 7.22.5 + '@babel/helper-validator-option': 7.22.5 + '@babel/plugin-transform-typescript': 7.21.3(@babel/core@7.22.5) + transitivePeerDependencies: + - supports-color + dev: true + + /@babel/register@7.18.9(@babel/core@7.22.5): + resolution: {integrity: sha512-ZlbnXDcNYHMR25ITwwNKT88JiaukkdVj/nG7r3wnuXkOTHc60Uy05PwMCPre0hSkY68E6zK3xz+vUJSP2jWmcw==} + engines: {node: '>=6.9.0'} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 clone-deep: 4.0.1 find-cache-dir: 2.1.0 make-dir: 2.1.0 - pirates: 4.0.6 + pirates: 4.0.5 source-map-support: 0.5.21 dev: true - /@babel/regjsgen@0.8.0: - resolution: {integrity: sha512-x/rqGMdzj+fWZvCOYForTghzbtqPDZ5gPwaoNGHdgDfF2QA/XZbCBp4Moo5scrkAMPhB7z26XM/AaHuIJdgauA==} - dev: true - - /@babel/runtime@7.22.6: - resolution: {integrity: sha512-wDb5pWm4WDdF6LFUde3Jl8WzPA+3ZbxYqkC6xAXuD3irdEHN1k0NfTRrJD8ZD378SJ61miMLCqIOXYhd8x+AJQ==} + /@babel/runtime@7.18.9: + resolution: {integrity: sha512-lkqXDcvlFT5rvEjiu6+QYO+1GXrEHRo2LOtS7E4GtX5ESIZOgepqsZBVIj6Pv+a6zqsya9VCgiK1KAK4BvJDAw==} engines: {node: '>=6.9.0'} dependencies: regenerator-runtime: 0.13.11 + /@babel/template@7.18.10: + resolution: {integrity: sha512-TI+rCtooWHr3QJ27kJxfjutghu44DLnasDMwpDqCXVTal9RLp3RSYNh4NdBrRP2cQAoG9A8juOQl6P6oZG4JxA==} + engines: {node: '>=6.9.0'} + dependencies: + '@babel/code-frame': 7.22.5 + '@babel/parser': 7.22.5 + '@babel/types': 7.22.5 + /@babel/template@7.22.5: resolution: {integrity: sha512-X7yV7eiwAxdj9k94NEylvbVHLiVG1nvzCV2EAowhxLTwODV1jl9UzZ48leOC0sH7OnuHrIkllaBgneUykIcZaw==} engines: {node: '>=6.9.0'} dependencies: '@babel/code-frame': 7.22.5 - '@babel/parser': 7.22.7 + '@babel/parser': 7.22.5 + '@babel/types': 7.22.5 + + /@babel/traverse@7.18.13: + resolution: {integrity: sha512-N6kt9X1jRMLPxxxPYWi7tgvJRH/rtoU+dbKAPDM44RFHiMH8igdsaSBgFeskhSl/kLWLDUvIh1RXCrTmg0/zvA==} + engines: {node: '>=6.9.0'} + dependencies: + '@babel/code-frame': 7.22.5 + '@babel/generator': 7.22.5 + '@babel/helper-environment-visitor': 7.22.5 + '@babel/helper-function-name': 7.22.5 + '@babel/helper-hoist-variables': 7.22.5 + '@babel/helper-split-export-declaration': 7.22.5 + '@babel/parser': 7.22.5 '@babel/types': 7.22.5 + debug: 4.3.4(supports-color@8.1.1) + globals: 11.12.0 + transitivePeerDependencies: + - supports-color - /@babel/traverse@7.22.8: - resolution: {integrity: sha512-y6LPR+wpM2I3qJrsheCTwhIinzkETbplIgPBbwvqPKc+uljeA5gP+3nP8irdYt1mjQaDnlIcG+dw8OjAco4GXw==} + /@babel/traverse@7.22.5: + resolution: {integrity: sha512-7DuIjPgERaNo6r+PZwItpjCZEa5vyw4eJGufeLxrPdBXBoLcCJCIasvK6pK/9DVNrLZTLFhUGqaC6X/PA007TQ==} engines: {node: '>=6.9.0'} dependencies: '@babel/code-frame': 7.22.5 - '@babel/generator': 7.22.7 + '@babel/generator': 7.22.5 '@babel/helper-environment-visitor': 7.22.5 '@babel/helper-function-name': 7.22.5 '@babel/helper-hoist-variables': 7.22.5 - '@babel/helper-split-export-declaration': 7.22.6 - '@babel/parser': 7.22.7 + '@babel/helper-split-export-declaration': 7.22.5 + '@babel/parser': 7.22.5 '@babel/types': 7.22.5 debug: 4.3.4(supports-color@8.1.1) globals: 11.12.0 transitivePeerDependencies: - supports-color + /@babel/types@7.18.13: + resolution: {integrity: sha512-ePqfTihzW0W6XAU+aMw2ykilisStJfDnsejDCXRchCcMJ4O0+8DhPXf2YUbZ6wjBlsEmZwLK/sPweWtu8hcJYQ==} + engines: {node: '>=6.9.0'} + dependencies: + '@babel/helper-string-parser': 7.22.5 + '@babel/helper-validator-identifier': 7.22.5 + to-fast-properties: 2.0.0 + /@babel/types@7.22.5: resolution: {integrity: sha512-zo3MIHGOkPOfoRXitsgHLjEXmlDaD/5KU1Uzuc9GNiZPhSqVxVRtxuPaSBZDsYZ9qV88AjtMtWW7ww98loJ9KA==} engines: {node: '>=6.9.0'} @@ -3893,12 +4947,12 @@ packages: '@jridgewell/trace-mapping': 0.3.9 dev: true - /@cypress/request@2.88.11: - resolution: {integrity: sha512-M83/wfQ1EkspjkE2lNWNV5ui2Cv7UCv1swW1DqljahbzLVWltcsexQh8jYtuS/vzFXP+HySntGM83ZXA9fn17w==} + /@cypress/request@2.88.10: + resolution: {integrity: sha512-Zp7F+R93N0yZyG34GutyTNr+okam7s/Fzc1+i3kcqOP8vk6OuajuE9qZJ6Rs+10/1JFtXFYMdyarnU1rZuJesg==} engines: {node: '>= 6'} dependencies: aws-sign2: 0.7.0 - aws4: 1.12.0 + aws4: 1.11.0 caseless: 0.12.0 combined-stream: 1.0.8 extend: 3.0.2 @@ -3910,7 +4964,7 @@ packages: json-stringify-safe: 5.0.1 mime-types: 2.1.35 performance-now: 2.1.0 - qs: 6.10.4 + qs: 6.5.3 safe-buffer: 5.2.1 tough-cookie: 2.5.0 tunnel-agent: 0.6.0 @@ -3926,53 +4980,53 @@ packages: - supports-color dev: true - /@date-io/core@2.16.0: - resolution: {integrity: sha512-DYmSzkr+jToahwWrsiRA2/pzMEtz9Bq1euJwoOuYwuwIYXnZFtHajY2E6a1VNVDc9jP8YUXK1BvnZH9mmT19Zg==} + /@date-io/core@2.15.0: + resolution: {integrity: sha512-3CRvQUEK7aF87NUOwcTtmJ2Rc1kN0D4jFQUfRoanuAnE4o5HzHx4E2YenjaKjSPWeZYiWG6ZhDomx5hp1AaCJA==} dev: false - /@date-io/date-fns@2.16.0(date-fns@2.30.0): - resolution: {integrity: sha512-bfm5FJjucqlrnQcXDVU5RD+nlGmL3iWgkHTq3uAZWVIuBu6dDmGa3m8a6zo2VQQpu8ambq9H22UyUpn7590joA==} + /@date-io/date-fns@2.15.0(date-fns@2.29.2): + resolution: {integrity: sha512-hkVeLm0jijHS2F9YVQcf0LSlD55w9xPvvIfuxDE0XWNXOTcRAAhqw2aqOxyeGbmHxc5U4HqyPZaqs9tfeTsomQ==} peerDependencies: date-fns: ^2.0.0 peerDependenciesMeta: date-fns: optional: true dependencies: - '@date-io/core': 2.16.0 - date-fns: 2.30.0 + '@date-io/core': 2.15.0 + date-fns: 2.29.2 dev: false - /@date-io/dayjs@2.16.0: - resolution: {integrity: sha512-y5qKyX2j/HG3zMvIxTobYZRGnd1FUW2olZLS0vTj7bEkBQkjd2RO7/FEwDY03Z1geVGlXKnzIATEVBVaGzV4Iw==} + /@date-io/dayjs@2.15.0: + resolution: {integrity: sha512-wgYzwaXr9KxkHNYxrOb1t8fYLfAdjIf0Q86qdVCwANObcvyGcPBm0uFtpPK7ApeE4DJUlbuG0IX75TtO+uITwQ==} peerDependencies: dayjs: ^1.8.17 peerDependenciesMeta: dayjs: optional: true dependencies: - '@date-io/core': 2.16.0 + '@date-io/core': 2.15.0 dev: false - /@date-io/luxon@2.16.1: - resolution: {integrity: sha512-aeYp5K9PSHV28946pC+9UKUi/xMMYoaGelrpDibZSgHu2VWHXrr7zWLEr+pMPThSs5vt8Ei365PO+84pCm37WQ==} + /@date-io/luxon@2.15.0: + resolution: {integrity: sha512-CxTRCo5AM96ainnYaTpe1NS9GiA78SIgXBScgeAresCS20AvMcOd5XKerDj+y/KLhbSQbU6WUDqG9QcsrImXyQ==} peerDependencies: - luxon: ^1.21.3 || ^2.x || ^3.x + luxon: ^1.21.3 || ^2.x peerDependenciesMeta: luxon: optional: true dependencies: - '@date-io/core': 2.16.0 + '@date-io/core': 2.15.0 dev: false - /@date-io/moment@2.16.1: - resolution: {integrity: sha512-JkxldQxUqZBfZtsaCcCMkm/dmytdyq5pS1RxshCQ4fHhsvP5A7gSqPD22QbVXMcJydi3d3v1Y8BQdUKEuGACZQ==} + /@date-io/moment@2.15.0: + resolution: {integrity: sha512-AcYBjl3EnEGsByaM5ir644CKbhgJsgc1iWFa9EXfdb4fQexxOC8oCdPAurK2ZDTwg62odyyKa/05YE7ElYh5ag==} peerDependencies: moment: ^2.24.0 peerDependenciesMeta: moment: optional: true dependencies: - '@date-io/core': 2.16.0 + '@date-io/core': 2.15.0 dev: false /@discoveryjs/json-ext@0.5.7: @@ -3984,11 +5038,11 @@ packages: resolution: {integrity: sha512-2Pu9HDg/uP/IT10rbQ+4OrTQuxIWdKVUEdcw9/w7kZJv9NeHS6skJx1xuRiFyoGKwAzcHXnLp7csE99sj+O1YA==} dev: true - /@docsearch/js@3.5.1(search-insights@2.7.0): + /@docsearch/js@3.5.1(search-insights@2.6.0): resolution: {integrity: sha512-EXi8de5njxgP6TV3N9ytnGRLG9zmBNTEZjR4VzwPcpPLbZxxTLG2gaFyJyKiFVQxHW/DPlMrDJA3qoRRGEkgZw==} dependencies: - '@docsearch/react': 3.5.1(search-insights@2.7.0) - preact: 10.16.0 + '@docsearch/react': 3.5.1(search-insights@2.6.0) + preact: 10.10.6 transitivePeerDependencies: - '@algolia/client-search' - '@types/react' @@ -3997,7 +5051,7 @@ packages: - search-insights dev: true - /@docsearch/react@3.5.1(search-insights@2.7.0): + /@docsearch/react@3.5.1(search-insights@2.6.0): resolution: {integrity: sha512-t5mEODdLzZq4PTFAm/dvqcvZFdPDMdfPE5rJS5SC8OUq9mPzxEy6b+9THIqNM9P0ocCb4UC5jqBrxKclnuIbzQ==} peerDependencies: '@types/react': '>= 16.8.0 < 19.0.0' @@ -4011,17 +5065,17 @@ packages: react-dom: optional: true dependencies: - '@algolia/autocomplete-core': 1.9.3(algoliasearch@4.18.0)(search-insights@2.7.0) - '@algolia/autocomplete-preset-algolia': 1.9.3(algoliasearch@4.18.0) + '@algolia/autocomplete-core': 1.9.3(algoliasearch@4.14.2)(search-insights@2.6.0) + '@algolia/autocomplete-preset-algolia': 1.9.3(algoliasearch@4.14.2) '@docsearch/css': 3.5.1 - algoliasearch: 4.18.0 + algoliasearch: 4.14.2 transitivePeerDependencies: - '@algolia/client-search' - search-insights dev: true - /@edge-runtime/primitives@1.1.0: - resolution: {integrity: sha512-MpL5fKlOs9mz5DMRuFchLe3Il84t7XpfbPq4qtaEK37uNMCRx1MzA3d7A4aTsR/guXSZvV/AtEbKVqBWjuSThA==} + /@edge-runtime/primitives@1.1.0-beta.31: + resolution: {integrity: sha512-OO1x32aJoxgME1k77RVxVNsazs5NY/SNwYEN8ptlZ6DKUXn0eesXftDsmlypX/OU0ZeJc61/xNVUuoeyDGJDVA==} dev: true /@edge-runtime/primitives@3.0.3: @@ -4032,7 +5086,7 @@ packages: /@edge-runtime/vm@1.1.0-beta.26: resolution: {integrity: sha512-hxWtmuO13zgNkM3zHvRENfMeavM+PAKSoHhvzt+sHjSothxGlA06XXN38t/NT6LD4ND8p8FmPJ70+fTptL4a/A==} dependencies: - '@edge-runtime/primitives': 1.1.0 + '@edge-runtime/primitives': 1.1.0-beta.31 dev: true /@edge-runtime/vm@3.0.3: @@ -4042,148 +5096,180 @@ packages: '@edge-runtime/primitives': 3.0.3 dev: true - /@emotion/babel-plugin@11.11.0: - resolution: {integrity: sha512-m4HEDZleaaCH+XgDDsPF15Ht6wTLsgDTeR3WYj9Q/k76JtWhrJjcP4+/XlG8LGT/Rol9qUfOIztXeA84ATpqPQ==} + /@emotion/babel-plugin@11.10.2(@babel/core@7.22.5): + resolution: {integrity: sha512-xNQ57njWTFVfPAc3cjfuaPdsgLp5QOSuRsj9MA6ndEhH/AzuZM86qIQzt6rq+aGBwj3n5/TkLmU5lhAfdRmogA==} + peerDependencies: + '@babel/core': ^7.0.0 dependencies: + '@babel/core': 7.22.5 '@babel/helper-module-imports': 7.22.5 - '@babel/runtime': 7.22.6 - '@emotion/hash': 0.9.1 - '@emotion/memoize': 0.8.1 - '@emotion/serialize': 1.1.2 + '@babel/plugin-syntax-jsx': 7.18.6(@babel/core@7.22.5) + '@babel/runtime': 7.18.9 + '@emotion/hash': 0.9.0 + '@emotion/memoize': 0.8.0 + '@emotion/serialize': 1.1.0 babel-plugin-macros: 3.1.0 convert-source-map: 1.9.0 escape-string-regexp: 4.0.0 find-root: 1.1.0 source-map: 0.5.7 - stylis: 4.2.0 + stylis: 4.0.13 dev: false - /@emotion/cache@11.11.0: - resolution: {integrity: sha512-P34z9ssTCBi3e9EI1ZsWpNHcfY1r09ZO0rZbRO2ob3ZQMnFI35jB536qoXbkdesr5EUhYi22anuEJuyxifaqAQ==} + /@emotion/cache@11.10.3: + resolution: {integrity: sha512-Psmp/7ovAa8appWh3g51goxu/z3iVms7JXOreq136D8Bbn6dYraPnmL6mdM8GThEx9vwSn92Fz+mGSjBzN8UPQ==} dependencies: - '@emotion/memoize': 0.8.1 - '@emotion/sheet': 1.2.2 - '@emotion/utils': 1.2.1 - '@emotion/weak-memoize': 0.3.1 - stylis: 4.2.0 + '@emotion/memoize': 0.8.0 + '@emotion/sheet': 1.2.0 + '@emotion/utils': 1.2.0 + '@emotion/weak-memoize': 0.3.0 + stylis: 4.0.13 dev: false - /@emotion/hash@0.9.1: - resolution: {integrity: sha512-gJB6HLm5rYwSLI6PQa+X1t5CFGrv1J1TWG+sOyMCeKz2ojaj6Fnl/rZEspogG+cvqbt4AE/2eIyD2QfLKTBNlQ==} + /@emotion/hash@0.9.0: + resolution: {integrity: sha512-14FtKiHhy2QoPIzdTcvh//8OyBlknNs2nXRwIhG904opCby3l+9Xaf/wuPvICBF0rc1ZCNBd3nKe9cd2mecVkQ==} dev: false - /@emotion/is-prop-valid@1.2.1: - resolution: {integrity: sha512-61Mf7Ufx4aDxx1xlDeOm8aFFigGHE4z+0sKCa+IHCeZKiyP9RLD0Mmx7m8b9/Cf37f7NAvQOOJAbQQGVr5uERw==} + /@emotion/is-prop-valid@1.2.0: + resolution: {integrity: sha512-3aDpDprjM0AwaxGE09bOPkNxHpBd+kA6jty3RnaEXdweX1DF1U3VQpPYb0g1IStAuK7SVQ1cy+bNBBKp4W3Fjg==} dependencies: - '@emotion/memoize': 0.8.1 + '@emotion/memoize': 0.8.0 dev: false - /@emotion/memoize@0.8.1: - resolution: {integrity: sha512-W2P2c/VRW1/1tLox0mVUalvnWXxavmv/Oum2aPsRcoDJuob75FC3Y8FbpfLwUegRcxINtGUMPq0tFCvYNTBXNA==} + /@emotion/memoize@0.8.0: + resolution: {integrity: sha512-G/YwXTkv7Den9mXDO7AhLWkE3q+I92B+VqAE+dYG4NGPaHZGvt3G8Q0p9vmE+sq7rTGphUbAvmQ9YpbfMQGGlA==} dev: false - /@emotion/react@11.11.1(react@18.2.0): - resolution: {integrity: sha512-5mlW1DquU5HaxjLkfkGN1GA/fvVGdyHURRiX/0FHl2cfIfRxSOfmxEH5YS43edp0OldZrZ+dkBKbngxcNCdZvA==} + /@emotion/react@11.10.4(@babel/core@7.22.5)(react@18.2.0): + resolution: {integrity: sha512-j0AkMpr6BL8gldJZ6XQsQ8DnS9TxEQu1R+OGmDZiWjBAJtCcbt0tS3I/YffoqHXxH6MjgI7KdMbYKw3MEiU9eA==} peerDependencies: + '@babel/core': ^7.0.0 '@types/react': '*' react: '>=16.8.0' peerDependenciesMeta: + '@babel/core': + optional: true '@types/react': optional: true dependencies: - '@babel/runtime': 7.22.6 - '@emotion/babel-plugin': 11.11.0 - '@emotion/cache': 11.11.0 - '@emotion/serialize': 1.1.2 - '@emotion/use-insertion-effect-with-fallbacks': 1.0.1(react@18.2.0) - '@emotion/utils': 1.2.1 - '@emotion/weak-memoize': 0.3.1 + '@babel/core': 7.22.5 + '@babel/runtime': 7.18.9 + '@emotion/babel-plugin': 11.10.2(@babel/core@7.22.5) + '@emotion/cache': 11.10.3 + '@emotion/serialize': 1.1.0 + '@emotion/use-insertion-effect-with-fallbacks': 1.0.0(react@18.2.0) + '@emotion/utils': 1.2.0 + '@emotion/weak-memoize': 0.3.0 hoist-non-react-statics: 3.3.2 react: 18.2.0 dev: false - /@emotion/serialize@1.1.2: - resolution: {integrity: sha512-zR6a/fkFP4EAcCMQtLOhIgpprZOwNmCldtpaISpvz348+DP4Mz8ZoKaGGCQpbzepNIUWbq4w6hNZkwDyKoS+HA==} + /@emotion/serialize@1.1.0: + resolution: {integrity: sha512-F1ZZZW51T/fx+wKbVlwsfchr5q97iW8brAnXmsskz4d0hVB4O3M/SiA3SaeH06x02lSNzkkQv+n3AX3kCXKSFA==} dependencies: - '@emotion/hash': 0.9.1 - '@emotion/memoize': 0.8.1 - '@emotion/unitless': 0.8.1 - '@emotion/utils': 1.2.1 + '@emotion/hash': 0.9.0 + '@emotion/memoize': 0.8.0 + '@emotion/unitless': 0.8.0 + '@emotion/utils': 1.2.0 csstype: 3.1.2 dev: false - /@emotion/sheet@1.2.2: - resolution: {integrity: sha512-0QBtGvaqtWi+nx6doRwDdBIzhNdZrXUppvTM4dtZZWEGTXL/XE/yJxLMGlDT1Gt+UHH5IX1n+jkXyytE/av7OA==} + /@emotion/sheet@1.2.0: + resolution: {integrity: sha512-OiTkRgpxescko+M51tZsMq7Puu/KP55wMT8BgpcXVG2hqXc0Vo0mfymJ/Uj24Hp0i083ji/o0aLddh08UEjq8w==} dev: false - /@emotion/styled@11.11.0(@emotion/react@11.11.1)(react@18.2.0): - resolution: {integrity: sha512-hM5Nnvu9P3midq5aaXj4I+lnSfNi7Pmd4EWk1fOZ3pxookaQTNew6bp4JaCBYM4HVFZF9g7UjJmsUmC2JlxOng==} + /@emotion/styled@11.10.4(@babel/core@7.22.5)(@emotion/react@11.10.4)(react@18.2.0): + resolution: {integrity: sha512-pRl4R8Ez3UXvOPfc2bzIoV8u9P97UedgHS4FPX594ntwEuAMA114wlaHvOK24HB48uqfXiGlYIZYCxVJ1R1ttQ==} peerDependencies: + '@babel/core': ^7.0.0 '@emotion/react': ^11.0.0-rc.0 '@types/react': '*' react: '>=16.8.0' peerDependenciesMeta: + '@babel/core': + optional: true '@types/react': optional: true dependencies: - '@babel/runtime': 7.22.6 - '@emotion/babel-plugin': 11.11.0 - '@emotion/is-prop-valid': 1.2.1 - '@emotion/react': 11.11.1(react@18.2.0) - '@emotion/serialize': 1.1.2 - '@emotion/use-insertion-effect-with-fallbacks': 1.0.1(react@18.2.0) - '@emotion/utils': 1.2.1 + '@babel/core': 7.22.5 + '@babel/runtime': 7.18.9 + '@emotion/babel-plugin': 11.10.2(@babel/core@7.22.5) + '@emotion/is-prop-valid': 1.2.0 + '@emotion/react': 11.10.4(@babel/core@7.22.5)(react@18.2.0) + '@emotion/serialize': 1.1.0 + '@emotion/use-insertion-effect-with-fallbacks': 1.0.0(react@18.2.0) + '@emotion/utils': 1.2.0 react: 18.2.0 dev: false - /@emotion/unitless@0.8.1: - resolution: {integrity: sha512-KOEGMu6dmJZtpadb476IsZBclKvILjopjUii3V+7MnXIQCYh8W3NgNcgwo21n9LXZX6EDIKvqfjYxXebDwxKmQ==} + /@emotion/unitless@0.8.0: + resolution: {integrity: sha512-VINS5vEYAscRl2ZUDiT3uMPlrFQupiKgHz5AA4bCH1miKBg4qtwkim1qPmJj/4WG6TreYMY111rEFsjupcOKHw==} dev: false - /@emotion/use-insertion-effect-with-fallbacks@1.0.1(react@18.2.0): - resolution: {integrity: sha512-jT/qyKZ9rzLErtrjGgdkMBn2OP8wl0G3sQlBb3YPryvKHsjvINUhVaPFfP+fpBcOkmrVOVEEHQFJ7nbj2TH2gw==} + /@emotion/use-insertion-effect-with-fallbacks@1.0.0(react@18.2.0): + resolution: {integrity: sha512-1eEgUGmkaljiBnRMTdksDV1W4kUnmwgp7X9G8B++9GYwl1lUdqSndSriIrTJ0N7LQaoauY9JJ2yhiOYK5+NI4A==} peerDependencies: react: '>=16.8.0' dependencies: react: 18.2.0 dev: false - /@emotion/utils@1.2.1: - resolution: {integrity: sha512-Y2tGf3I+XVnajdItskUCn6LX+VUDmP6lTL4fcqsXAv43dnlbZiuW4MWQW38rW/BVWSE7Q/7+XQocmpnRYILUmg==} + /@emotion/utils@1.2.0: + resolution: {integrity: sha512-sn3WH53Kzpw8oQ5mgMmIzzyAaH2ZqFEbozVVBSYp538E06OSE6ytOp7pRAjNQR+Q/orwqdQYJSe2m3hCOeznkw==} dev: false - /@emotion/weak-memoize@0.3.1: - resolution: {integrity: sha512-EsBwpc7hBUJWAsNPBmJy4hxWx12v6bshQsldrVmjxJoc3isbxhOrF2IcCpaXxfvq03NwkI7sbsOLXbYuqF/8Ww==} + /@emotion/weak-memoize@0.3.0: + resolution: {integrity: sha512-AHPmaAx+RYfZz0eYu6Gviiagpmiyw98ySSlQvCUhVGDRtDFe4DBS0x1bSjdF3gqUDYOczB+yYvBTtEylYSdRhg==} dev: false - /@esbuild-kit/cjs-loader@2.4.2: - resolution: {integrity: sha512-BDXFbYOJzT/NBEtp71cvsrGPwGAMGRB/349rwKuoxNSiKjPraNNnlK6MIIabViCjqZugu6j+xeMDlEkWdHHJSg==} + /@esbuild-kit/cjs-loader@2.3.3: + resolution: {integrity: sha512-Rt4O1mXlPEDVxvjsHLgbtHVdUXYK9C1/6ThpQnt7FaXIjUOsI6qhHYMgALhNnlIMZffag44lXd6Dqgx3xALbpQ==} + dependencies: + '@esbuild-kit/core-utils': 2.3.0 + get-tsconfig: 4.6.2 + dev: true + + /@esbuild-kit/cjs-loader@2.4.0: + resolution: {integrity: sha512-DBBCiHPgL2B/elUpvCDhNHXnlZQ9sfO2uyt1OJyAXKT41beQEFY4OxZ6gwS+ZesRCbZ6JV8M7GEyOPkjv8kdIw==} dependencies: - '@esbuild-kit/core-utils': 3.1.0 + '@esbuild-kit/core-utils': 3.0.0 get-tsconfig: 4.6.2 dev: true - /@esbuild-kit/core-utils@3.1.0: - resolution: {integrity: sha512-Uuk8RpCg/7fdHSceR1M6XbSZFSuMrxcePFuGgyvsBn+u339dk5OeL4jv2EojwTN2st/unJGsVm4qHWjWNmJ/tw==} + /@esbuild-kit/core-utils@2.3.0: + resolution: {integrity: sha512-JL73zt/LN/qqziHuod4/bM2xBNNofDZu1cbwT6KIn6B11lA4cgDXkoSHOfNCbZMZOnh0Aqf0vW/gNQC+Z18hKQ==} + dependencies: + esbuild: 0.15.18 + source-map-support: 0.5.21 + dev: true + + /@esbuild-kit/core-utils@3.0.0: + resolution: {integrity: sha512-TXmwH9EFS3DC2sI2YJWJBgHGhlteK0Xyu1VabwetMULfm3oYhbrsWV5yaSr2NTWZIgDGVLHbRf0inxbjXqAcmQ==} dependencies: - esbuild: 0.17.19 + esbuild: 0.15.18 source-map-support: 0.5.21 dev: true - /@esbuild-kit/esm-loader@2.5.5: - resolution: {integrity: sha512-Qwfvj/qoPbClxCRNuac1Du01r9gvNOT+pMYtJDapfB1eoGN1YlJ1BixLyL9WVENRx5RXgNLdfYdx/CuswlGhMw==} + /@esbuild-kit/esm-loader@2.4.2: + resolution: {integrity: sha512-N9dPKAj8WOx6djVnStgILWXip4fjDcBk9L7azO0/uQDpu8Ee0eaL78mkN4Acid9BzvNAKWwdYXFJZnsVahNEew==} + dependencies: + '@esbuild-kit/core-utils': 2.3.0 + get-tsconfig: 4.6.2 + dev: true + + /@esbuild-kit/esm-loader@2.5.0: + resolution: {integrity: sha512-ySs0qOsiwj+hsgZM9/MniGdvfa9/WzqfFuIia8/5gSUPeIQIX2/tG91QakxPFOR35VFiwTB7wCiHtiS6dc6SkA==} dependencies: - '@esbuild-kit/core-utils': 3.1.0 + '@esbuild-kit/core-utils': 3.0.0 get-tsconfig: 4.6.2 dev: true - /@esbuild/android-arm64@0.17.19: - resolution: {integrity: sha512-KBMWvEZooR7+kzY0BtbTQn0OAYY7CsiydT63pVEaPtVYF0hXbUaOyZog37DKxK7NF3XacBJOpYT4adIJh+avxA==} + /@esbuild/android-arm64@0.17.18: + resolution: {integrity: sha512-/iq0aK0eeHgSC3z55ucMAHO05OIqmQehiGay8eP5l/5l+iEr4EIbh4/MI8xD9qRFjqzgkc0JkX0LculNC9mXBw==} engines: {node: '>=12'} cpu: [arm64] os: [android] requiresBuild: true - dev: true optional: true /@esbuild/android-arm64@0.18.11: @@ -4192,15 +5278,24 @@ packages: cpu: [arm64] os: [android] requiresBuild: true + dev: true + optional: true + + /@esbuild/android-arm@0.15.18: + resolution: {integrity: sha512-5GT+kcs2WVGjVs7+boataCkO5Fg0y4kCjzkB5bAip7H4jfnOS3dA6KPiww9W1OEKTKeAcUVhdZGvgI65OXmUnw==} + engines: {node: '>=12'} + cpu: [arm] + os: [android] + requiresBuild: true + dev: true optional: true - /@esbuild/android-arm@0.17.19: - resolution: {integrity: sha512-rIKddzqhmav7MSmoFCmDIb6e2W57geRsM94gV2l38fzhXMwq7hZoClug9USI2pFRGL06f4IOPHHpFNOkWieR8A==} + /@esbuild/android-arm@0.17.18: + resolution: {integrity: sha512-EmwL+vUBZJ7mhFCs5lA4ZimpUH3WMAoqvOIYhVQwdIgSpHC8ImHdsRyhHAVxpDYUSm0lWvd63z0XH1IlImS2Qw==} engines: {node: '>=12'} cpu: [arm] os: [android] requiresBuild: true - dev: true optional: true /@esbuild/android-arm@0.18.11: @@ -4209,15 +5304,15 @@ packages: cpu: [arm] os: [android] requiresBuild: true + dev: true optional: true - /@esbuild/android-x64@0.17.19: - resolution: {integrity: sha512-uUTTc4xGNDT7YSArp/zbtmbhO0uEEK9/ETW29Wk1thYUJBz3IVnvgEiEwEa9IeLyvnpKrWK64Utw2bgUmDveww==} + /@esbuild/android-x64@0.17.18: + resolution: {integrity: sha512-x+0efYNBF3NPW2Xc5bFOSFW7tTXdAcpfEg2nXmxegm4mJuVeS+i109m/7HMiOQ6M12aVGGFlqJX3RhNdYM2lWg==} engines: {node: '>=12'} cpu: [x64] os: [android] requiresBuild: true - dev: true optional: true /@esbuild/android-x64@0.18.11: @@ -4226,15 +5321,15 @@ packages: cpu: [x64] os: [android] requiresBuild: true + dev: true optional: true - /@esbuild/darwin-arm64@0.17.19: - resolution: {integrity: sha512-80wEoCfF/hFKM6WE1FyBHc9SfUblloAWx6FJkFWTWiCoht9Mc0ARGEM47e67W9rI09YoUxJL68WHfDRYEAvOhg==} + /@esbuild/darwin-arm64@0.17.18: + resolution: {integrity: sha512-6tY+djEAdF48M1ONWnQb1C+6LiXrKjmqjzPNPWXhu/GzOHTHX2nh8Mo2ZAmBFg0kIodHhciEgUBtcYCAIjGbjQ==} engines: {node: '>=12'} cpu: [arm64] os: [darwin] requiresBuild: true - dev: true optional: true /@esbuild/darwin-arm64@0.18.11: @@ -4243,15 +5338,15 @@ packages: cpu: [arm64] os: [darwin] requiresBuild: true + dev: true optional: true - /@esbuild/darwin-x64@0.17.19: - resolution: {integrity: sha512-IJM4JJsLhRYr9xdtLytPLSH9k/oxR3boaUIYiHkAawtwNOXKE8KoU8tMvryogdcT8AU+Bflmh81Xn6Q0vTZbQw==} + /@esbuild/darwin-x64@0.17.18: + resolution: {integrity: sha512-Qq84ykvLvya3dO49wVC9FFCNUfSrQJLbxhoQk/TE1r6MjHo3sFF2tlJCwMjhkBVq3/ahUisj7+EpRSz0/+8+9A==} engines: {node: '>=12'} cpu: [x64] os: [darwin] requiresBuild: true - dev: true optional: true /@esbuild/darwin-x64@0.18.11: @@ -4260,15 +5355,15 @@ packages: cpu: [x64] os: [darwin] requiresBuild: true + dev: true optional: true - /@esbuild/freebsd-arm64@0.17.19: - resolution: {integrity: sha512-pBwbc7DufluUeGdjSU5Si+P3SoMF5DQ/F/UmTSb8HXO80ZEAJmrykPyzo1IfNbAoaqw48YRpv8shwd1NoI0jcQ==} + /@esbuild/freebsd-arm64@0.17.18: + resolution: {integrity: sha512-fw/ZfxfAzuHfaQeMDhbzxp9mc+mHn1Y94VDHFHjGvt2Uxl10mT4CDavHm+/L9KG441t1QdABqkVYwakMUeyLRA==} engines: {node: '>=12'} cpu: [arm64] os: [freebsd] requiresBuild: true - dev: true optional: true /@esbuild/freebsd-arm64@0.18.11: @@ -4277,15 +5372,15 @@ packages: cpu: [arm64] os: [freebsd] requiresBuild: true + dev: true optional: true - /@esbuild/freebsd-x64@0.17.19: - resolution: {integrity: sha512-4lu+n8Wk0XlajEhbEffdy2xy53dpR06SlzvhGByyg36qJw6Kpfk7cp45DR/62aPH9mtJRmIyrXAS5UWBrJT6TQ==} + /@esbuild/freebsd-x64@0.17.18: + resolution: {integrity: sha512-FQFbRtTaEi8ZBi/A6kxOC0V0E9B/97vPdYjY9NdawyLd4Qk5VD5g2pbWN2VR1c0xhzcJm74HWpObPszWC+qTew==} engines: {node: '>=12'} cpu: [x64] os: [freebsd] requiresBuild: true - dev: true optional: true /@esbuild/freebsd-x64@0.18.11: @@ -4294,15 +5389,15 @@ packages: cpu: [x64] os: [freebsd] requiresBuild: true + dev: true optional: true - /@esbuild/linux-arm64@0.17.19: - resolution: {integrity: sha512-ct1Tg3WGwd3P+oZYqic+YZF4snNl2bsnMKRkb3ozHmnM0dGWuxcPTTntAF6bOP0Sp4x0PjSF+4uHQ1xvxfRKqg==} + /@esbuild/linux-arm64@0.17.18: + resolution: {integrity: sha512-R7pZvQZFOY2sxUG8P6A21eq6q+eBv7JPQYIybHVf1XkQYC+lT7nDBdC7wWKTrbvMXKRaGudp/dzZCwL/863mZQ==} engines: {node: '>=12'} cpu: [arm64] os: [linux] requiresBuild: true - dev: true optional: true /@esbuild/linux-arm64@0.18.11: @@ -4311,15 +5406,15 @@ packages: cpu: [arm64] os: [linux] requiresBuild: true + dev: true optional: true - /@esbuild/linux-arm@0.17.19: - resolution: {integrity: sha512-cdmT3KxjlOQ/gZ2cjfrQOtmhG4HJs6hhvm3mWSRDPtZ/lP5oe8FWceS10JaSJC13GBd4eH/haHnqf7hhGNLerA==} + /@esbuild/linux-arm@0.17.18: + resolution: {integrity: sha512-jW+UCM40LzHcouIaqv3e/oRs0JM76JfhHjCavPxMUti7VAPh8CaGSlS7cmyrdpzSk7A+8f0hiedHqr/LMnfijg==} engines: {node: '>=12'} cpu: [arm] os: [linux] requiresBuild: true - dev: true optional: true /@esbuild/linux-arm@0.18.11: @@ -4328,15 +5423,15 @@ packages: cpu: [arm] os: [linux] requiresBuild: true + dev: true optional: true - /@esbuild/linux-ia32@0.17.19: - resolution: {integrity: sha512-w4IRhSy1VbsNxHRQpeGCHEmibqdTUx61Vc38APcsRbuVgK0OPEnQ0YD39Brymn96mOx48Y2laBQGqgZ0j9w6SQ==} + /@esbuild/linux-ia32@0.17.18: + resolution: {integrity: sha512-ygIMc3I7wxgXIxk6j3V00VlABIjq260i967Cp9BNAk5pOOpIXmd1RFQJQX9Io7KRsthDrQYrtcx7QCof4o3ZoQ==} engines: {node: '>=12'} cpu: [ia32] os: [linux] requiresBuild: true - dev: true optional: true /@esbuild/linux-ia32@0.18.11: @@ -4345,6 +5440,7 @@ packages: cpu: [ia32] os: [linux] requiresBuild: true + dev: true optional: true /@esbuild/linux-loong64@0.14.54: @@ -4356,8 +5452,8 @@ packages: dev: false optional: true - /@esbuild/linux-loong64@0.17.19: - resolution: {integrity: sha512-2iAngUbBPMq439a+z//gE+9WBldoMp1s5GWsUSgqHLzLJ9WoZLZhpwWuym0u0u/4XmZ3gpHmzV84PonE+9IIdQ==} + /@esbuild/linux-loong64@0.15.18: + resolution: {integrity: sha512-L4jVKS82XVhw2nvzLg/19ClLWg0y27ulRwuP7lcyL6AbUWB5aPglXY3M21mauDQMDfRLs8cQmeT03r/+X3cZYQ==} engines: {node: '>=12'} cpu: [loong64] os: [linux] @@ -4365,21 +5461,29 @@ packages: dev: true optional: true + /@esbuild/linux-loong64@0.17.18: + resolution: {integrity: sha512-bvPG+MyFs5ZlwYclCG1D744oHk1Pv7j8psF5TfYx7otCVmcJsEXgFEhQkbhNW8otDHL1a2KDINW20cfCgnzgMQ==} + engines: {node: '>=12'} + cpu: [loong64] + os: [linux] + requiresBuild: true + optional: true + /@esbuild/linux-loong64@0.18.11: resolution: {integrity: sha512-MRESANOoObQINBA+RMZW+Z0TJWpibtE7cPFnahzyQHDCA9X9LOmGh68MVimZlM9J8n5Ia8lU773te6O3ILW8kw==} engines: {node: '>=12'} cpu: [loong64] os: [linux] requiresBuild: true + dev: true optional: true - /@esbuild/linux-mips64el@0.17.19: - resolution: {integrity: sha512-LKJltc4LVdMKHsrFe4MGNPp0hqDFA1Wpt3jE1gEyM3nKUvOiO//9PheZZHfYRfYl6AwdTH4aTcXSqBerX0ml4A==} + /@esbuild/linux-mips64el@0.17.18: + resolution: {integrity: sha512-oVqckATOAGuiUOa6wr8TXaVPSa+6IwVJrGidmNZS1cZVx0HqkTMkqFGD2HIx9H1RvOwFeWYdaYbdY6B89KUMxA==} engines: {node: '>=12'} cpu: [mips64el] os: [linux] requiresBuild: true - dev: true optional: true /@esbuild/linux-mips64el@0.18.11: @@ -4388,15 +5492,15 @@ packages: cpu: [mips64el] os: [linux] requiresBuild: true + dev: true optional: true - /@esbuild/linux-ppc64@0.17.19: - resolution: {integrity: sha512-/c/DGybs95WXNS8y3Ti/ytqETiW7EU44MEKuCAcpPto3YjQbyK3IQVKfF6nbghD7EcLUGl0NbiL5Rt5DMhn5tg==} + /@esbuild/linux-ppc64@0.17.18: + resolution: {integrity: sha512-3dLlQO+b/LnQNxgH4l9rqa2/IwRJVN9u/bK63FhOPB4xqiRqlQAU0qDU3JJuf0BmaH0yytTBdoSBHrb2jqc5qQ==} engines: {node: '>=12'} cpu: [ppc64] os: [linux] requiresBuild: true - dev: true optional: true /@esbuild/linux-ppc64@0.18.11: @@ -4405,15 +5509,15 @@ packages: cpu: [ppc64] os: [linux] requiresBuild: true + dev: true optional: true - /@esbuild/linux-riscv64@0.17.19: - resolution: {integrity: sha512-FC3nUAWhvFoutlhAkgHf8f5HwFWUL6bYdvLc/TTuxKlvLi3+pPzdZiFKSWz/PF30TB1K19SuCxDTI5KcqASJqA==} + /@esbuild/linux-riscv64@0.17.18: + resolution: {integrity: sha512-/x7leOyDPjZV3TcsdfrSI107zItVnsX1q2nho7hbbQoKnmoeUWjs+08rKKt4AUXju7+3aRZSsKrJtaRmsdL1xA==} engines: {node: '>=12'} cpu: [riscv64] os: [linux] requiresBuild: true - dev: true optional: true /@esbuild/linux-riscv64@0.18.11: @@ -4422,15 +5526,15 @@ packages: cpu: [riscv64] os: [linux] requiresBuild: true + dev: true optional: true - /@esbuild/linux-s390x@0.17.19: - resolution: {integrity: sha512-IbFsFbxMWLuKEbH+7sTkKzL6NJmG2vRyy6K7JJo55w+8xDk7RElYn6xvXtDW8HCfoKBFK69f3pgBJSUSQPr+4Q==} + /@esbuild/linux-s390x@0.17.18: + resolution: {integrity: sha512-cX0I8Q9xQkL/6F5zWdYmVf5JSQt+ZfZD2bJudZrWD+4mnUvoZ3TDDXtDX2mUaq6upMFv9FlfIh4Gfun0tbGzuw==} engines: {node: '>=12'} cpu: [s390x] os: [linux] requiresBuild: true - dev: true optional: true /@esbuild/linux-s390x@0.18.11: @@ -4439,15 +5543,15 @@ packages: cpu: [s390x] os: [linux] requiresBuild: true + dev: true optional: true - /@esbuild/linux-x64@0.17.19: - resolution: {integrity: sha512-68ngA9lg2H6zkZcyp22tsVt38mlhWde8l3eJLWkyLrp4HwMUr3c1s/M2t7+kHIhvMjglIBrFpncX1SzMckomGw==} + /@esbuild/linux-x64@0.17.18: + resolution: {integrity: sha512-66RmRsPlYy4jFl0vG80GcNRdirx4nVWAzJmXkevgphP1qf4dsLQCpSKGM3DUQCojwU1hnepI63gNZdrr02wHUA==} engines: {node: '>=12'} cpu: [x64] os: [linux] requiresBuild: true - dev: true optional: true /@esbuild/linux-x64@0.18.11: @@ -4456,15 +5560,15 @@ packages: cpu: [x64] os: [linux] requiresBuild: true + dev: true optional: true - /@esbuild/netbsd-x64@0.17.19: - resolution: {integrity: sha512-CwFq42rXCR8TYIjIfpXCbRX0rp1jo6cPIUPSaWwzbVI4aOfX96OXY8M6KNmtPcg7QjYeDmN+DD0Wp3LaBOLf4Q==} + /@esbuild/netbsd-x64@0.17.18: + resolution: {integrity: sha512-95IRY7mI2yrkLlTLb1gpDxdC5WLC5mZDi+kA9dmM5XAGxCME0F8i4bYH4jZreaJ6lIZ0B8hTrweqG1fUyW7jbg==} engines: {node: '>=12'} cpu: [x64] os: [netbsd] requiresBuild: true - dev: true optional: true /@esbuild/netbsd-x64@0.18.11: @@ -4473,15 +5577,15 @@ packages: cpu: [x64] os: [netbsd] requiresBuild: true + dev: true optional: true - /@esbuild/openbsd-x64@0.17.19: - resolution: {integrity: sha512-cnq5brJYrSZ2CF6c35eCmviIN3k3RczmHz8eYaVlNasVqsNY+JKohZU5MKmaOI+KkllCdzOKKdPs762VCPC20g==} + /@esbuild/openbsd-x64@0.17.18: + resolution: {integrity: sha512-WevVOgcng+8hSZ4Q3BKL3n1xTv5H6Nb53cBrtzzEjDbbnOmucEVcZeGCsCOi9bAOcDYEeBZbD2SJNBxlfP3qiA==} engines: {node: '>=12'} cpu: [x64] os: [openbsd] requiresBuild: true - dev: true optional: true /@esbuild/openbsd-x64@0.18.11: @@ -4490,15 +5594,15 @@ packages: cpu: [x64] os: [openbsd] requiresBuild: true + dev: true optional: true - /@esbuild/sunos-x64@0.17.19: - resolution: {integrity: sha512-vCRT7yP3zX+bKWFeP/zdS6SqdWB8OIpaRq/mbXQxTGHnIxspRtigpkUcDMlSCOejlHowLqII7K2JKevwyRP2rg==} + /@esbuild/sunos-x64@0.17.18: + resolution: {integrity: sha512-Rzf4QfQagnwhQXVBS3BYUlxmEbcV7MY+BH5vfDZekU5eYpcffHSyjU8T0xucKVuOcdCsMo+Ur5wmgQJH2GfNrg==} engines: {node: '>=12'} cpu: [x64] os: [sunos] requiresBuild: true - dev: true optional: true /@esbuild/sunos-x64@0.18.11: @@ -4507,15 +5611,15 @@ packages: cpu: [x64] os: [sunos] requiresBuild: true + dev: true optional: true - /@esbuild/win32-arm64@0.17.19: - resolution: {integrity: sha512-yYx+8jwowUstVdorcMdNlzklLYhPxjniHWFKgRqH7IFlUEa0Umu3KuYplf1HUZZ422e3NU9F4LGb+4O0Kdcaag==} + /@esbuild/win32-arm64@0.17.18: + resolution: {integrity: sha512-Kb3Ko/KKaWhjeAm2YoT/cNZaHaD1Yk/pa3FTsmqo9uFh1D1Rfco7BBLIPdDOozrObj2sahslFuAQGvWbgWldAg==} engines: {node: '>=12'} cpu: [arm64] os: [win32] requiresBuild: true - dev: true optional: true /@esbuild/win32-arm64@0.18.11: @@ -4524,15 +5628,15 @@ packages: cpu: [arm64] os: [win32] requiresBuild: true + dev: true optional: true - /@esbuild/win32-ia32@0.17.19: - resolution: {integrity: sha512-eggDKanJszUtCdlVs0RB+h35wNlb5v4TWEkq4vZcmVt5u/HiDZrTXe2bWFQUez3RgNHwx/x4sk5++4NSSicKkw==} + /@esbuild/win32-ia32@0.17.18: + resolution: {integrity: sha512-0/xUMIdkVHwkvxfbd5+lfG7mHOf2FRrxNbPiKWg9C4fFrB8H0guClmaM3BFiRUYrznVoyxTIyC/Ou2B7QQSwmw==} engines: {node: '>=12'} cpu: [ia32] os: [win32] requiresBuild: true - dev: true optional: true /@esbuild/win32-ia32@0.18.11: @@ -4541,15 +5645,15 @@ packages: cpu: [ia32] os: [win32] requiresBuild: true + dev: true optional: true - /@esbuild/win32-x64@0.17.19: - resolution: {integrity: sha512-lAhycmKnVOuRYNtRtatQR1LPQf2oYCkRGkSFnseDAKPl8lu5SOsK/e1sXe5a0Pc5kHIHe6P2I/ilntNv2xf3cA==} + /@esbuild/win32-x64@0.17.18: + resolution: {integrity: sha512-qU25Ma1I3NqTSHJUOKi9sAH1/Mzuvlke0ioMJRthLXKm7JiSKVwFghlGbDLOO2sARECGhja4xYfRAZNPAkooYg==} engines: {node: '>=12'} cpu: [x64] os: [win32] requiresBuild: true - dev: true optional: true /@esbuild/win32-x64@0.18.11: @@ -4558,6 +5662,7 @@ packages: cpu: [x64] os: [win32] requiresBuild: true + dev: true optional: true /@eslint-community/eslint-utils@4.4.0(eslint@8.44.0): @@ -4570,8 +5675,8 @@ packages: eslint-visitor-keys: 3.4.1 dev: true - /@eslint-community/regexpp@4.5.1: - resolution: {integrity: sha512-Z5ba73P98O1KUYCCJTUeVpja9RcGoMdncZ6T49FCUl2lN38JtCJ+3WgIDBv0AuY4WChU5PmtJmOCTlN6FZTFKQ==} + /@eslint-community/regexpp@4.5.0: + resolution: {integrity: sha512-vITaYzIcNmjn5tF5uxcZ/ft7/RXGrMUIS9HalWckEOF6ESiwXKoMzAQf2UW0aVd6rnOeExTJVd5hmWXucBKGXQ==} engines: {node: ^12.0.0 || ^14.0.0 || >=16.0.0} dev: true @@ -4581,9 +5686,9 @@ packages: dependencies: ajv: 6.12.6 debug: 4.3.4(supports-color@8.1.1) - espree: 9.6.0 - globals: 13.20.0 - ignore: 5.2.4 + espree: 9.5.2 + globals: 13.19.0 + ignore: 5.2.0 import-fresh: 3.3.0 js-yaml: 4.1.0 minimatch: 3.1.2 @@ -4599,8 +5704,8 @@ packages: ajv: 6.12.6 debug: 4.3.4(supports-color@8.1.1) espree: 9.6.0 - globals: 13.20.0 - ignore: 5.2.4 + globals: 13.19.0 + ignore: 5.2.0 import-fresh: 3.3.0 js-yaml: 4.1.0 minimatch: 3.1.2 @@ -4619,26 +5724,26 @@ packages: engines: {node: ^14.17.0 || ^16.13.0 || >=18.0.0, npm: '>=6.14.13'} dev: true - /@fastify/ajv-compiler@3.5.0: - resolution: {integrity: sha512-ebbEtlI7dxXF5ziNdr05mOY8NnDiPB1XvAlLHctRt/Rc+C3LCOVW5imUVX+mhvUhnNzmPBHewUkOFgGlCxgdAA==} + /@fastify/ajv-compiler@3.2.0: + resolution: {integrity: sha512-JrqgKmZoh1AJojDZk699DupQ9+tz5gSy7/w+5DrkXy5whM5IcqdV3SjG5qnOqgVJT1nPtUMDY0xYus2j6vwJiw==} dependencies: - ajv: 8.12.0 - ajv-formats: 2.1.1(ajv@8.12.0) - fast-uri: 2.2.0 + ajv: 8.11.0 + ajv-formats: 2.1.1(ajv@8.11.0) + fast-uri: 2.1.0 dev: true - /@fastify/deepmerge@1.3.0: - resolution: {integrity: sha512-J8TOSBq3SoZbDhM9+R/u77hP93gz/rajSA+K2kGyijPpORPWUXHUpTaleoj+92As0S9uPRP7Oi8IqMf0u+ro6A==} + /@fastify/deepmerge@1.1.0: + resolution: {integrity: sha512-E8Hfdvs1bG6u0N4vN5Nty6JONUfTdOciyD5rn8KnEsLKIenvOVcr210BQR9t34PRkNyjqnMLGk3e0BsaxRdL+g==} dev: true - /@fastify/error@3.3.0: - resolution: {integrity: sha512-dj7vjIn1Ar8sVXj2yAXiMNCJDmS9MQ9XMlIecX2dIzzhjSHCyKo4DdXjXMs7wKW2kj6yvVRSpuQjOZ3YLrh56w==} + /@fastify/error@3.0.0: + resolution: {integrity: sha512-dPRyT40GiHRzSCll3/Jn2nPe25+E1VXc9tDwRAIKwFCxd5Np5wzgz1tmooWG3sV0qKgrBibihVoCna2ru4SEFg==} dev: true - /@fastify/fast-json-stringify-compiler@4.3.0: - resolution: {integrity: sha512-aZAXGYo6m22Fk1zZzEUKBvut/CIIQe/BapEORnxiD5Qr0kPHqqI69NtEMCme74h+at72sPhbkb4ZrLd1W3KRLA==} + /@fastify/fast-json-stringify-compiler@4.1.0: + resolution: {integrity: sha512-cTKBV2J9+u6VaKDhX7HepSfPSzw+F+TSd+k0wzifj4rG+4E5PjSFJCk19P8R6tr/72cuzgGd+mbB3jFT6lvAgw==} dependencies: - fast-json-stringify: 5.7.0 + fast-json-stringify: 5.2.0 dev: true /@floating-ui/core@0.3.1: @@ -4655,12 +5760,12 @@ packages: resolution: {integrity: sha512-k2Ty1JcVojjJFwrg/ThKi2ujJ7XNLYaFGNB/bWT9wGR+oSMJHMa5w+CUq6p/pVrKeNNgA7pCqEcjSnHVoqJQFw==} dev: true - /@graphql-typed-document-node/core@3.2.0(graphql@16.7.1): - resolution: {integrity: sha512-mB9oAsNCm9aM3/SOv4YtBMqZbYj10R7dkq8byBqxGY/ncFwhf2oQzMV+LCRlWoDSEBJ3COiR1yeDvMtsoOsuFQ==} + /@graphql-typed-document-node/core@3.1.1(graphql@16.6.0): + resolution: {integrity: sha512-NQ17ii0rK1b34VZonlmT2QMJFI70m0TRwbknO/ihlbatXyaktDhN/98vBiUU6kNBPljqGqyIrl2T4nY2RpFANg==} peerDependencies: - graphql: ^0.8.0 || ^0.9.0 || ^0.10.0 || ^0.11.0 || ^0.12.0 || ^0.13.0 || ^14.0.0 || ^15.0.0 || ^16.0.0 || ^17.0.0 + graphql: ^0.8.0 || ^0.9.0 || ^0.10.0 || ^0.11.0 || ^0.12.0 || ^0.13.0 || ^14.0.0 || ^15.0.0 || ^16.0.0 dependencies: - graphql: 16.7.1 + graphql: 16.6.0 dev: false /@humanwhocodes/config-array@0.11.10: @@ -4717,18 +5822,6 @@ packages: - supports-color dev: true - /@isaacs/cliui@8.0.2: - resolution: {integrity: sha512-O8jcjabXaleOG9DQ0+ARXWZBTfnP4WNAqzuiJK7ll44AmxGKv/J2M4TPjxjY3znBCfvBXFzucm1twdyFybFqEA==} - engines: {node: '>=12'} - dependencies: - string-width: 5.1.2 - string-width-cjs: /string-width@4.2.3 - strip-ansi: 7.1.0 - strip-ansi-cjs: /strip-ansi@6.0.1 - wrap-ansi: 8.1.0 - wrap-ansi-cjs: /wrap-ansi@7.0.0 - dev: true - /@istanbuljs/load-nyc-config@1.1.0: resolution: {integrity: sha512-VjeHSlIzpv/NyD3N0YuHfXOPDIixcA1q2ZV98wsMqcYlPmv2n3Yb2lYP9XMElnaFVXg5A7YLTeLu6V84uQDjmQ==} engines: {node: '>=8'} @@ -4775,7 +5868,7 @@ packages: chalk: 4.1.2 emittery: 0.8.1 exit: 0.1.2 - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 jest-changed-files: 27.5.1 jest-config: 27.5.1(ts-node@10.9.1) jest-haste-map: 27.5.1 @@ -4811,11 +5904,11 @@ packages: jest-mock: 27.5.1 dev: true - /@jest/expect-utils@29.6.1: - resolution: {integrity: sha512-o319vIf5pEMx0LmzSxxkYYxo4wrRLKHq9dP1yJU7FoPTB0LfAKSz8SWD6D/6U3v/O52t9cF5t+MeJiRsfk7zMw==} + /@jest/expect-utils@29.0.1: + resolution: {integrity: sha512-Tw5kUUOKmXGQDmQ9TSgTraFFS7HMC1HG/B7y0AN2G2UzjdAXz9BzK2rmNpCSDl7g7y0Gf/VLBm//blonvhtOTQ==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: - jest-get-type: 29.4.3 + jest-get-type: 29.0.0 dev: true /@jest/fake-timers@27.5.1: @@ -4855,10 +5948,10 @@ packages: '@jest/types': 27.5.1 '@types/node': 20.4.1 chalk: 4.1.2 - collect-v8-coverage: 1.0.2 + collect-v8-coverage: 1.0.1 exit: 0.1.2 glob: 7.2.3 - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 istanbul-lib-coverage: 3.2.0 istanbul-lib-instrument: 5.2.1 istanbul-lib-report: 3.0.0 @@ -4877,18 +5970,18 @@ packages: - supports-color dev: true - /@jest/schemas@29.6.0: - resolution: {integrity: sha512-rxLjXyJBTL4LQeJW3aKo0M/+GkCOXsO+8i9Iu7eDb6KwtP65ayoDsitrdPBtujxQ88k4wI2FNYfa6TOGwSn6cQ==} + /@jest/schemas@29.4.3: + resolution: {integrity: sha512-VLYKXQmtmuEz6IxJsrZwzG9NvtkQsWNnWMsKxqWNu3+CnfzJQhp0WDDKWLVV9hLKr0l3SLLFRqcYHjhtyuDVxg==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: - '@sinclair/typebox': 0.27.8 + '@sinclair/typebox': 0.25.24 /@jest/source-map@27.5.1: resolution: {integrity: sha512-y9NIHUYF3PJRlHk98NdC/N1gl88BL08aQQgu4k4ZopQkCw9t9cV8mtl3TV8b/YCB8XaVTFrmUTAJvjsntDireg==} engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: callsites: 3.1.0 - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 source-map: 0.6.1 dev: true @@ -4899,7 +5992,7 @@ packages: '@jest/console': 27.5.1 '@jest/types': 27.5.1 '@types/istanbul-lib-coverage': 2.0.4 - collect-v8-coverage: 1.0.2 + collect-v8-coverage: 1.0.1 dev: true /@jest/test-sequencer@27.5.1: @@ -4907,7 +6000,7 @@ packages: engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: '@jest/test-result': 27.5.1 - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 jest-haste-map: 27.5.1 jest-runtime: 27.5.1 transitivePeerDependencies: @@ -4918,18 +6011,18 @@ packages: resolution: {integrity: sha512-E9JjhUgNzvuQ+vVAL21vlyfy12gP0GhazGgJC4h6qUt1jSdUXGWJ1wfu/X7Sd8etSgxV4ovT1pb9v5D6QW4XgA==} engines: {node: '>= 10.14.2'} dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@jest/types': 26.6.2 babel-plugin-istanbul: 6.1.1 chalk: 4.1.2 convert-source-map: 1.9.0 fast-json-stable-stringify: 2.1.0 - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 jest-haste-map: 26.6.2 jest-regex-util: 26.0.0 jest-util: 26.6.2 micromatch: 4.0.5 - pirates: 4.0.6 + pirates: 4.0.5 slash: 3.0.0 source-map: 0.6.1 write-file-atomic: 3.0.3 @@ -4941,18 +6034,18 @@ packages: resolution: {integrity: sha512-ipON6WtYgl/1329g5AIJVbUuEh0wZVbdpGwC99Jw4LwuoBNS95MVphU6zOeD9pDkon+LLbFL7lOQRapbB8SCHw==} engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@jest/types': 27.5.1 babel-plugin-istanbul: 6.1.1 chalk: 4.1.2 convert-source-map: 1.9.0 fast-json-stable-stringify: 2.1.0 - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 jest-haste-map: 27.5.1 jest-regex-util: 27.5.1 jest-util: 27.5.1 micromatch: 4.0.5 - pirates: 4.0.6 + pirates: 4.0.5 slash: 3.0.0 source-map: 0.6.1 write-file-atomic: 3.0.3 @@ -4967,7 +6060,7 @@ packages: '@types/istanbul-lib-coverage': 2.0.4 '@types/istanbul-reports': 3.0.1 '@types/node': 20.4.1 - '@types/yargs': 15.0.15 + '@types/yargs': 15.0.14 chalk: 4.1.2 dev: true @@ -4982,19 +6075,19 @@ packages: chalk: 4.1.2 dev: true - /@jest/types@29.6.1: - resolution: {integrity: sha512-tPKQNMPuXgvdOn2/Lg9HNfUvjYVGolt04Hp03f5hAk878uwOLikN+JzeLY0HcVgKgFl9Hs3EIqpu3WX27XNhnw==} + /@jest/types@29.0.1: + resolution: {integrity: sha512-ft01rxzVsbh9qZPJ6EFgAIj3PT9FCRfBF9Xljo2/33VDOUjLZr0ZJ2oKANqh9S/K0/GERCsHDAQlBwj7RxA+9g==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: - '@jest/schemas': 29.6.0 + '@jest/schemas': 29.4.3 '@types/istanbul-lib-coverage': 2.0.4 '@types/istanbul-reports': 3.0.1 '@types/node': 20.4.1 - '@types/yargs': 17.0.24 + '@types/yargs': 17.0.12 chalk: 4.1.2 dev: true - /@joshwooding/vite-plugin-react-docgen-typescript@0.0.4(typescript@4.9.5)(vite@4.4.3): + /@joshwooding/vite-plugin-react-docgen-typescript@0.0.4(typescript@4.8.4)(vite@4.3.9): resolution: {integrity: sha512-ezL7SU//1OV4Oyt/zQ3CsX8uLujVEYUHuULkqgcW6wOuQfRnvgkn99HZtLWwS257GmZVwszGQzhL7VE3PbMAYw==} peerDependencies: typescript: '>= 4.3.x' @@ -5003,13 +6096,20 @@ packages: glob: 7.2.3 glob-promise: 4.2.2(glob@7.2.3) magic-string: 0.26.7 - react-docgen-typescript: 2.2.2(typescript@4.9.5) - typescript: 4.9.5 - vite: 4.4.3(@types/node@18.16.19) + react-docgen-typescript: 2.2.2(typescript@4.8.4) + typescript: 4.8.4 + vite: 4.3.9(@types/node@18.16.19) dev: true - /@jridgewell/gen-mapping@0.3.3: - resolution: {integrity: sha512-HLhSWOLRi875zjjMG/r+Nv0oCW8umGb0BgEhyX3dDX3egwZtB8PqLnjz3yedt8R5StBrzcg4aBpnh8UA9D1BoQ==} + /@jridgewell/gen-mapping@0.1.1: + resolution: {integrity: sha512-sQXCasFk+U8lWYEe66WxRDOE9PjVz4vSM51fTu3Hw+ClTpUSQb718772vH3pyS5pShp6lvQM7SxgIDXXXmOX7w==} + engines: {node: '>=6.0.0'} + dependencies: + '@jridgewell/set-array': 1.1.2 + '@jridgewell/sourcemap-codec': 1.4.15 + + /@jridgewell/gen-mapping@0.3.2: + resolution: {integrity: sha512-mh65xKQAzI6iBcFzwv28KVWSmCkdRBWoOh+bYQGW3+6OZvbbN3TqMGo5hqYxQniRcH9F2VZIoJCm4pa3BPDK/A==} engines: {node: '>=6.0.0'} dependencies: '@jridgewell/set-array': 1.1.2 @@ -5020,19 +6120,14 @@ packages: resolution: {integrity: sha512-F2msla3tad+Mfht5cJq7LSXcdudKTWCVYUgw6pLFOOHSTtZlj6SWNYAp+AhuqLmWdBO2X5hPrLcu8cVP8fy28w==} engines: {node: '>=6.0.0'} - /@jridgewell/resolve-uri@3.1.1: - resolution: {integrity: sha512-dSYZh7HhCDtCKm4QakX0xFpsRDqjjtZf/kjI/v3T3Nwt5r8/qz/M19F9ySyOqU94SXBmeG9ttTul+YnR4LOxFA==} - engines: {node: '>=6.0.0'} - dev: true - /@jridgewell/set-array@1.1.2: resolution: {integrity: sha512-xnkseuNADM0gt2bs+BvhO0p78Mk762YnZdsuzFV018NoG1Sj1SCQvpSqa7XUaTam5vAGasABV9qXASMKnFMwMw==} engines: {node: '>=6.0.0'} - /@jridgewell/source-map@0.3.5: - resolution: {integrity: sha512-UTYAUj/wviwdsMfzoSJspJxbkH5o1snzwX0//0ENX1u/55kkZZkcTZP6u9bwKGkv+dkk9at4m1Cpt0uY80kcpQ==} + /@jridgewell/source-map@0.3.2: + resolution: {integrity: sha512-m7O9o2uR8k2ObDysZYzdfhb08VuEml5oWGiosa1VdaPZ/A6QyPkAJuwN0Q1lhULOf6B7MtQmHENS743hWtCrgw==} dependencies: - '@jridgewell/gen-mapping': 0.3.3 + '@jridgewell/gen-mapping': 0.3.2 '@jridgewell/trace-mapping': 0.3.18 dev: true @@ -5051,7 +6146,7 @@ packages: /@jridgewell/trace-mapping@0.3.9: resolution: {integrity: sha512-3Belt6tdc8bPgAtbcmdtNJlirVoTmEb5e2gC94PnkwEW9jI6CAHUeoG85tjWP5WquqfavoMtMwiG4P926ZKKuQ==} dependencies: - '@jridgewell/resolve-uri': 3.1.1 + '@jridgewell/resolve-uri': 3.1.0 '@jridgewell/sourcemap-codec': 1.4.15 dev: true @@ -5061,7 +6156,7 @@ packages: dependencies: call-me-maybe: 1.0.2 cross-spawn: 7.0.3 - string-argv: 0.3.2 + string-argv: 0.3.1 type-detect: 4.0.8 dev: true @@ -5069,14 +6164,8 @@ packages: resolution: {integrity: sha512-a4Bo/80Z6CoJNor5ldgs6002utmmbttP4JYd/FJ0Ob2fVdf6O6ha5SORBCqrnDnBvMc1TlrHY7dCfat5+H0a6A==} dev: false - /@lit-labs/ssr-dom-shim@1.1.1: - resolution: {integrity: sha512-kXOeFbfCm4fFf2A3WwVEeQj55tMZa8c8/f9AKHMobQMkzNUfUj+antR3fRPaZJawsa1aZiP/Da3ndpZrwEe4rQ==} - dev: false - - /@lit/reactive-element@1.6.2: - resolution: {integrity: sha512-rDfl+QnCYjuIGf5xI2sVJWdYIi56CTCwWa+nidKYX6oIuBYwUbT/vX4qbUDlHiZKJ/3FRNQ/tWJui44p6/stSA==} - dependencies: - '@lit-labs/ssr-dom-shim': 1.1.1 + /@lit/reactive-element@1.4.1: + resolution: {integrity: sha512-qDv4851VFSaBWzpS02cXHclo40jsbAjRXnebNXpm0uVg32kCneZPo9RYVQtrTNICtZ+1wAYHu1ZtxWSWMbKrBw==} dev: false /@mdx-js/mdx@1.6.22: @@ -5130,27 +6219,27 @@ packages: engines: {node: '>=14'} dependencies: '@types/set-cookie-parser': 2.4.2 - set-cookie-parser: 2.6.0 + set-cookie-parser: 2.5.1 dev: true - /@mswjs/interceptors@0.17.9: - resolution: {integrity: sha512-4LVGt03RobMH/7ZrbHqRxQrS9cc2uh+iNKSj8UWr8M26A2i793ju+csaB5zaqYltqJmA2jUq4VeYfKmVqvsXQg==} + /@mswjs/interceptors@0.17.6: + resolution: {integrity: sha512-201pBIWehTURb6q8Gheu4Zhvd3Ox1U4BJq5KiOQsYzkWyfiOG4pwcz5hPZIEryztgrf8/sdwABpvY757xMmfrQ==} engines: {node: '>=14'} dependencies: '@open-draft/until': 1.0.3 '@types/debug': 4.1.8 - '@xmldom/xmldom': 0.8.8 + '@xmldom/xmldom': 0.8.6 debug: 4.3.4(supports-color@8.1.1) headers-polyfill: 3.1.2 - outvariant: 1.4.0 + outvariant: 1.3.0 strict-event-emitter: 0.2.8 web-encoding: 1.1.5 transitivePeerDependencies: - supports-color dev: true - /@mui/base@5.0.0-beta.7(react-dom@18.2.0)(react@18.2.0): - resolution: {integrity: sha512-Pjbwm6gjiS96kOMF7E5fjEJsenc0tZBesrLQ4rrdi3eT/c/yhSWnPbCUkHSz8bnS0l3/VQ8bA+oERSGSV2PK6A==} + /@mui/base@5.0.0-alpha.95(react-dom@18.2.0)(react@18.2.0): + resolution: {integrity: sha512-fcxnDeO7rBwzP0buVdI5fn0aA7NQ/AeUV5RzIIH0kOXVVT21HB4JFf41Qhwd0PIq63PXxmc6Fs2mdlzMYuPo9g==} engines: {node: '>=12.0.0'} peerDependencies: '@types/react': ^17.0.0 || ^18.0.0 @@ -5160,11 +6249,11 @@ packages: '@types/react': optional: true dependencies: - '@babel/runtime': 7.22.6 - '@emotion/is-prop-valid': 1.2.1 - '@mui/types': 7.2.4 - '@mui/utils': 5.13.7(react@18.2.0) - '@popperjs/core': 2.11.8 + '@babel/runtime': 7.18.9 + '@emotion/is-prop-valid': 1.2.0 + '@mui/types': 7.2.0 + '@mui/utils': 5.10.3(react@18.2.0) + '@popperjs/core': 2.11.6 clsx: 1.2.1 prop-types: 15.8.1 react: 18.2.0 @@ -5172,12 +6261,12 @@ packages: react-is: 18.2.0 dev: false - /@mui/core-downloads-tracker@5.14.0: - resolution: {integrity: sha512-SYBOVCatVDUf/lbrLGah09bHhX5WfUXg7kSskfLILr6SvKRni0NLp0aonxQ0SMALVVK3Qwa6cW4CdWuwS0gC1w==} + /@mui/core-downloads-tracker@5.10.3: + resolution: {integrity: sha512-mX2S0d1oboKBbWQqWIgRmyALAEzh37yiknpD3mKx8bcoMKbp1VtqzIt0aeHP16Uhsd0eValDFILxLNHWi0oddQ==} dev: false - /@mui/material@5.14.0(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(react-dom@18.2.0)(react@18.2.0): - resolution: {integrity: sha512-HP7CP71NhMkui2HUIEKl2/JfuHMuoarSUWAKlNw6s17bl/Num9rN61EM6uUzc2A2zHjj/00A66GnvDnmixEJEw==} + /@mui/material@5.10.3(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(react-dom@18.2.0)(react@18.2.0): + resolution: {integrity: sha512-g0lzHcqWHYeOEAxTzcwpM1I7b+wyiRTeXkEdRsspnOpZtb0H/1xg386tMFRGbxBJ4zfVGT+TWublofw7pyQkqw==} engines: {node: '>=12.0.0'} peerDependencies: '@emotion/react': ^11.5.0 @@ -5193,17 +6282,17 @@ packages: '@types/react': optional: true dependencies: - '@babel/runtime': 7.22.6 - '@emotion/react': 11.11.1(react@18.2.0) - '@emotion/styled': 11.11.0(@emotion/react@11.11.1)(react@18.2.0) - '@mui/base': 5.0.0-beta.7(react-dom@18.2.0)(react@18.2.0) - '@mui/core-downloads-tracker': 5.14.0 - '@mui/system': 5.14.0(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(react@18.2.0) - '@mui/types': 7.2.4 - '@mui/utils': 5.13.7(react@18.2.0) - '@types/react-transition-group': 4.4.6 + '@babel/runtime': 7.18.9 + '@emotion/react': 11.10.4(@babel/core@7.22.5)(react@18.2.0) + '@emotion/styled': 11.10.4(@babel/core@7.22.5)(@emotion/react@11.10.4)(react@18.2.0) + '@mui/base': 5.0.0-alpha.95(react-dom@18.2.0)(react@18.2.0) + '@mui/core-downloads-tracker': 5.10.3 + '@mui/system': 5.10.3(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(react@18.2.0) + '@mui/types': 7.2.0 + '@mui/utils': 5.10.3(react@18.2.0) + '@types/react-transition-group': 4.4.5 clsx: 1.2.1 - csstype: 3.1.2 + csstype: 3.1.0 prop-types: 15.8.1 react: 18.2.0 react-dom: 18.2.0(react@18.2.0) @@ -5211,8 +6300,8 @@ packages: react-transition-group: 4.4.5(react-dom@18.2.0)(react@18.2.0) dev: false - /@mui/private-theming@5.13.7(react@18.2.0): - resolution: {integrity: sha512-qbSr+udcij5F9dKhGX7fEdx2drXchq7htLNr2Qg2Ma+WJ6q0ERlEqGSBiPiVDJkptcjeVL4DGmcf1wl5+vD4EA==} + /@mui/private-theming@5.10.3(react@18.2.0): + resolution: {integrity: sha512-LCYIKlkGz2BTSng2BFzzwSJBRZbChIUri2x2Nh8ryk2B1Ho7zpvE7ex6y39LlStG2Frf92NFC/V4YQbmMAjD5A==} engines: {node: '>=12.0.0'} peerDependencies: '@types/react': ^17.0.0 || ^18.0.0 @@ -5221,14 +6310,14 @@ packages: '@types/react': optional: true dependencies: - '@babel/runtime': 7.22.6 - '@mui/utils': 5.13.7(react@18.2.0) + '@babel/runtime': 7.18.9 + '@mui/utils': 5.10.3(react@18.2.0) prop-types: 15.8.1 react: 18.2.0 dev: false - /@mui/styled-engine@5.13.2(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(react@18.2.0): - resolution: {integrity: sha512-VCYCU6xVtXOrIN8lcbuPmoG+u7FYuOERG++fpY74hPpEWkyFQG97F+/XfTQVYzlR2m7nPjnwVUgATcTCMEaMvw==} + /@mui/styled-engine@5.10.3(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(react@18.2.0): + resolution: {integrity: sha512-9Uz7eB8xXoiDvpJ9qBxZ/2xGO8xKfA2T23dw4AsQ69SQtGatrOLAapzP2lNr0tfB9xvKucclPFhRO5aLhDFOVQ==} engines: {node: '>=12.0.0'} peerDependencies: '@emotion/react': ^11.4.1 @@ -5240,17 +6329,17 @@ packages: '@emotion/styled': optional: true dependencies: - '@babel/runtime': 7.22.6 - '@emotion/cache': 11.11.0 - '@emotion/react': 11.11.1(react@18.2.0) - '@emotion/styled': 11.11.0(@emotion/react@11.11.1)(react@18.2.0) + '@babel/runtime': 7.18.9 + '@emotion/cache': 11.10.3 + '@emotion/react': 11.10.4(@babel/core@7.22.5)(react@18.2.0) + '@emotion/styled': 11.10.4(@babel/core@7.22.5)(@emotion/react@11.10.4)(react@18.2.0) csstype: 3.1.2 prop-types: 15.8.1 react: 18.2.0 dev: false - /@mui/system@5.14.0(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(react@18.2.0): - resolution: {integrity: sha512-0HZGkX8miJbiNw+rjlZ9l0Cfkz1bSqfSHQH0EH9J+nx0aAm5cBleg9piOlLdCNIWGgecCqsw4x62erGrGjjcJg==} + /@mui/system@5.10.3(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(react@18.2.0): + resolution: {integrity: sha512-uLW/CIz3zk1jr5zH0ahOUqJIrpWP02Mv4emfrplh7Mh5JCb/oumhYaC/ALJJEjzUHKg9wwiyuM0pCwK/kSf1jQ==} engines: {node: '>=12.0.0'} peerDependencies: '@emotion/react': ^11.5.0 @@ -5265,21 +6354,21 @@ packages: '@types/react': optional: true dependencies: - '@babel/runtime': 7.22.6 - '@emotion/react': 11.11.1(react@18.2.0) - '@emotion/styled': 11.11.0(@emotion/react@11.11.1)(react@18.2.0) - '@mui/private-theming': 5.13.7(react@18.2.0) - '@mui/styled-engine': 5.13.2(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(react@18.2.0) - '@mui/types': 7.2.4 - '@mui/utils': 5.13.7(react@18.2.0) + '@babel/runtime': 7.18.9 + '@emotion/react': 11.10.4(@babel/core@7.22.5)(react@18.2.0) + '@emotion/styled': 11.10.4(@babel/core@7.22.5)(@emotion/react@11.10.4)(react@18.2.0) + '@mui/private-theming': 5.10.3(react@18.2.0) + '@mui/styled-engine': 5.10.3(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(react@18.2.0) + '@mui/types': 7.2.0 + '@mui/utils': 5.10.3(react@18.2.0) clsx: 1.2.1 csstype: 3.1.2 prop-types: 15.8.1 react: 18.2.0 dev: false - /@mui/types@7.2.4: - resolution: {integrity: sha512-LBcwa8rN84bKF+f5sDyku42w1NTxaPgPyYKODsh01U1fVstTClbUoSA96oyRBnSNyEiAVjKm6Gwx9vjR+xyqHA==} + /@mui/types@7.2.0: + resolution: {integrity: sha512-lGXtFKe5lp3UxTBGqKI1l7G8sE2xBik8qCfrLHD5olwP/YU0/ReWoWT7Lp1//ri32dK39oPMrJN8TgbkCSbsNA==} peerDependencies: '@types/react': '*' peerDependenciesMeta: @@ -5287,21 +6376,21 @@ packages: optional: true dev: false - /@mui/utils@5.13.7(react@18.2.0): - resolution: {integrity: sha512-/3BLptG/q0u36eYED7Nhf4fKXmcKb6LjjT7ZMwhZIZSdSxVqDqSTmATW3a56n3KEPQUXCU9TpxAfCBQhs6brVA==} + /@mui/utils@5.10.3(react@18.2.0): + resolution: {integrity: sha512-4jXMDPfx6bpMVuheLaOpKTjpzw39ogAZLeaLj5+RJec3E37/hAZMYjURfblLfTWMMoGoqkY03mNsZaEwNobBow==} engines: {node: '>=12.0.0'} peerDependencies: react: ^17.0.0 || ^18.0.0 dependencies: - '@babel/runtime': 7.22.6 + '@babel/runtime': 7.18.9 '@types/prop-types': 15.7.5 - '@types/react-is': 18.2.1 + '@types/react-is': 17.0.3 prop-types: 15.8.1 react: 18.2.0 react-is: 18.2.0 dev: false - /@mui/x-date-pickers@5.0.0-beta.0(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(@mui/material@5.14.0)(@mui/system@5.14.0)(date-fns@2.30.0)(react-dom@18.2.0)(react@18.2.0): + /@mui/x-date-pickers@5.0.0-beta.0(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(@mui/material@5.10.3)(@mui/system@5.10.3)(date-fns@2.29.2)(react-dom@18.2.0)(react@18.2.0): resolution: {integrity: sha512-WfcYe+5j3xbGO9d+uMFem06b9q+9yIcFj0dP3PKCa1zb6m3Tbkigig6vlCuHLKLSXe1P6IQCt+BNVVbU1rfh7A==} engines: {node: '>=12.0.0'} peerDependencies: @@ -5328,20 +6417,20 @@ packages: moment: optional: true dependencies: - '@babel/runtime': 7.22.6 - '@date-io/core': 2.16.0 - '@date-io/date-fns': 2.16.0(date-fns@2.30.0) - '@date-io/dayjs': 2.16.0 - '@date-io/luxon': 2.16.1 - '@date-io/moment': 2.16.1 - '@emotion/react': 11.11.1(react@18.2.0) - '@emotion/styled': 11.11.0(@emotion/react@11.11.1)(react@18.2.0) - '@mui/material': 5.14.0(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(react-dom@18.2.0)(react@18.2.0) - '@mui/system': 5.14.0(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(react@18.2.0) - '@mui/utils': 5.13.7(react@18.2.0) - '@types/react-transition-group': 4.4.6 + '@babel/runtime': 7.18.9 + '@date-io/core': 2.15.0 + '@date-io/date-fns': 2.15.0(date-fns@2.29.2) + '@date-io/dayjs': 2.15.0 + '@date-io/luxon': 2.15.0 + '@date-io/moment': 2.15.0 + '@emotion/react': 11.10.4(@babel/core@7.22.5)(react@18.2.0) + '@emotion/styled': 11.10.4(@babel/core@7.22.5)(@emotion/react@11.10.4)(react@18.2.0) + '@mui/material': 5.10.3(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(react-dom@18.2.0)(react@18.2.0) + '@mui/system': 5.10.3(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(react@18.2.0) + '@mui/utils': 5.10.3(react@18.2.0) + '@types/react-transition-group': 4.4.5 clsx: 1.2.1 - date-fns: 2.30.0 + date-fns: 2.29.2 prop-types: 15.8.1 react: 18.2.0 react-transition-group: 4.4.5(react-dom@18.2.0)(react@18.2.0) @@ -5462,10 +6551,6 @@ packages: dev: false optional: true - /@nicolo-ribaudo/semver-v6@6.3.3: - resolution: {integrity: sha512-3Yc1fUTs69MG/uZbJlLSI3JISMn2UV2rg+1D/vROUqZyh3l6iYHCs7GMp+M40ZD7yOdDbYjJcU1oTJhrc+dGKg==} - hasBin: true - /@nodelib/fs.scandir@2.1.5: resolution: {integrity: sha512-vq24Bq3ym5HEQm2NKCr3yXDwjc7vTsEThRDnkp2DK9p1uqLR+DHurm/NOTo0KG7HYHU7eppKZj3MyqYuMBf62g==} engines: {node: '>= 8'} @@ -5487,19 +6572,18 @@ packages: engines: {node: '>= 8'} dependencies: '@nodelib/fs.scandir': 2.1.5 - fastq: 1.15.0 + fastq: 1.13.0 /@npmcli/fs@1.1.1: resolution: {integrity: sha512-8KG5RD0GVP4ydEzRn/I4BNDuxDtqVbOdm8675T49OIG/NGhaK0pjPX7ZcDlvKYbA+ulvVK3ztfcF4uBdOxuJbQ==} dependencies: '@gar/promisify': 1.1.3 - semver: 7.5.4 + semver: 7.5.2 dev: true /@npmcli/move-file@1.1.2: resolution: {integrity: sha512-1SUf/Cg2GzGDyaf15aR9St9TWlb+XvbZXWpDx8YKs7MLzMH/BCeopv+y9vzrzgkfykCGuWOlSu3mZhj2+FQcrg==} engines: {node: '>=10'} - deprecated: This functionality has been moved to @npmcli/fs dependencies: mkdirp: 1.0.4 rimraf: 3.0.2 @@ -5516,25 +6600,23 @@ packages: dev: true optional: true - /@playwright/test@1.36.0: - resolution: {integrity: sha512-yN+fvMYtiyLFDCQos+lWzoX4XW3DNuaxjBu68G0lkgLgC6BP+m/iTxJQoSicz/x2G5EsrqlZTqTIP9sTgLQerg==} - engines: {node: '>=16'} + /@playwright/test@1.28.0: + resolution: {integrity: sha512-vrHs5DFTPwYox5SGKq/7TDn/S4q6RA1zArd7uhO6EyP9hj3XgZBBM12ktMbnDQNxh/fL1IUKsTNLxihmsU38lQ==} + engines: {node: '>=14'} hasBin: true dependencies: '@types/node': 20.4.1 - playwright-core: 1.36.0 - optionalDependencies: - fsevents: 2.3.2 + playwright-core: 1.28.0 dev: true - /@pmmmwh/react-refresh-webpack-plugin@0.5.10(react-refresh@0.11.0)(webpack@5.88.1): - resolution: {integrity: sha512-j0Ya0hCFZPd4x40qLzbhGsh9TMtdb+CJQiso+WxLOPNasohq9cc5SNUcwsZaRH6++Xh91Xkm/xHCkuIiIu0LUA==} + /@pmmmwh/react-refresh-webpack-plugin@0.5.7(react-refresh@0.11.0)(webpack@5.74.0): + resolution: {integrity: sha512-bcKCAzF0DV2IIROp9ZHkRJa6O4jy7NlnHdWL3GmcUxYWNjLXkK5kfELELwEfSP5hXPfVL/qOGMAROuMQb9GG8Q==} engines: {node: '>= 10.13'} peerDependencies: '@types/webpack': 4.x || 5.x react-refresh: '>=0.10.0 <1.0.0' sockjs-client: ^1.4.0 - type-fest: '>=0.17.0 <4.0.0' + type-fest: '>=0.17.0 <3.0.0' webpack: '>=4.43.0 <6.0.0' webpack-dev-server: 3.x || 4.x webpack-hot-middleware: 2.x @@ -5555,22 +6637,22 @@ packages: dependencies: ansi-html-community: 0.0.8 common-path-prefix: 3.0.0 - core-js-pure: 3.31.1 + core-js-pure: 3.25.0 error-stack-parser: 2.1.4 find-up: 5.0.0 - html-entities: 2.4.0 - loader-utils: 2.0.4 + html-entities: 2.3.3 + loader-utils: 2.0.2 react-refresh: 0.11.0 - schema-utils: 3.3.0 + schema-utils: 3.1.1 source-map: 0.7.4 - webpack: 5.88.1(esbuild@0.18.11) + webpack: 5.74.0(esbuild@0.18.11) dev: true /@polka/url@1.0.0-next.21: resolution: {integrity: sha512-a5Sab1C4/icpTZVzZc5Ghpz88yQtGOyNqYXcZgOssB2uuAr+wF/MvN6bgtW32q7HHrvBki+BsZ0OuNv6EV3K9g==} - /@popperjs/core@2.11.8: - resolution: {integrity: sha512-P1st0aksCrn9sGZhp8GMYwBnQsbvAWsZAX44oXNNvLHGqAOcoVxmjZiohstwQ7SqKnbR47akdNi+uleWD8+g6A==} + /@popperjs/core@2.11.6: + resolution: {integrity: sha512-50/17A98tWUfQ176raKiOGXuYpLyyVMkxxG6oylzL3BPOlA6ADGdK7EYunSa4I064xerltq9TGXs8HmOk5E+vw==} dev: false /@puppeteer/browsers@1.3.0(typescript@5.1.6): @@ -5597,12 +6679,7 @@ packages: - supports-color dev: true - /@remix-run/router@1.7.1: - resolution: {integrity: sha512-bgVQM4ZJ2u2CM8k1ey70o1ePFXsEzYVZoWghh6WjM8p59jQ7HxzbHW4SbnWFG7V9ig9chLawQxDTZ3xzOF8MkQ==} - engines: {node: '>=14'} - dev: false - - /@rollup/plugin-alias@5.0.0(rollup@3.26.2): + /@rollup/plugin-alias@5.0.0(rollup@3.26.0): resolution: {integrity: sha512-l9hY5chSCjuFRPsnRm16twWBiSApl2uYFLsepQYwtBuAxNMQ/1dJqADld40P0Jkqm65GRTLy/AC6hnpVebtLsA==} engines: {node: '>=14.0.0'} peerDependencies: @@ -5611,11 +6688,11 @@ packages: rollup: optional: true dependencies: - rollup: 3.26.2 + rollup: 3.26.0 slash: 4.0.0 dev: true - /@rollup/plugin-babel@5.3.1(@babel/core@7.22.8)(rollup@2.79.1): + /@rollup/plugin-babel@5.3.1(@babel/core@7.22.5)(rollup@2.79.1): resolution: {integrity: sha512-WFfdLWU/xVWKeRQnKmIAQULUI7Il0gZnBIH/ZFO069wYIfPu+8zrfp/KMW0atmELoRDq8FbiP3VCss9MhCut7Q==} engines: {node: '>= 10.0.0'} peerDependencies: @@ -5626,13 +6703,13 @@ packages: '@types/babel__core': optional: true dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@babel/helper-module-imports': 7.22.5 '@rollup/pluginutils': 3.1.0(rollup@2.79.1) rollup: 2.79.1 dev: true - /@rollup/plugin-commonjs@25.0.2(rollup@3.26.2): + /@rollup/plugin-commonjs@25.0.2(rollup@3.26.0): resolution: {integrity: sha512-NGTwaJxIO0klMs+WSFFtBP7b9TdTJ3K76HZkewT8/+yHzMiUGVQgaPtLQxNVYIgT5F7lxkEyVID+yS3K7bhCow==} engines: {node: '>=14.0.0'} peerDependencies: @@ -5641,28 +6718,28 @@ packages: rollup: optional: true dependencies: - '@rollup/pluginutils': 5.0.2(rollup@3.26.2) + '@rollup/pluginutils': 5.0.2(rollup@3.26.0) commondir: 1.0.1 estree-walker: 2.0.2 - glob: 8.1.0 + glob: 8.0.3 is-reference: 1.2.1 magic-string: 0.27.0 - rollup: 3.26.2 + rollup: 3.26.0 dev: true - /@rollup/plugin-graphql@1.1.0(graphql@16.7.1)(rollup@2.79.1): + /@rollup/plugin-graphql@1.1.0(graphql@16.6.0)(rollup@2.79.1): resolution: {integrity: sha512-X+H6oFlprDlnO3D0UiEytdW97AMphPXO0C7KunS7i/rBXIGQRQVDU5WKTXnBu2tfyYbjCTtfhXMSGI0i885PNg==} peerDependencies: graphql: '>=0.9.0' rollup: ^1.20.0 || ^2.0.0 dependencies: '@rollup/pluginutils': 4.2.1 - graphql: 16.7.1 - graphql-tag: 2.12.6(graphql@16.7.1) + graphql: 16.6.0 + graphql-tag: 2.12.6(graphql@16.6.0) rollup: 2.79.1 dev: false - /@rollup/plugin-json@6.0.0(rollup@3.26.2): + /@rollup/plugin-json@6.0.0(rollup@3.26.0): resolution: {integrity: sha512-i/4C5Jrdr1XUarRhVu27EEwjt4GObltD7c+MkCIpO2QIbojw8MUs+CCTqOphQi3Qtg1FLmYt+l+6YeoIf51J7w==} engines: {node: '>=14.0.0'} peerDependencies: @@ -5671,8 +6748,8 @@ packages: rollup: optional: true dependencies: - '@rollup/pluginutils': 5.0.2(rollup@3.26.2) - rollup: 3.26.2 + '@rollup/pluginutils': 5.0.2(rollup@3.26.0) + rollup: 3.26.0 dev: true /@rollup/plugin-node-resolve@11.2.1(rollup@2.79.1): @@ -5690,7 +6767,7 @@ packages: rollup: 2.79.1 dev: true - /@rollup/plugin-node-resolve@15.1.0(rollup@3.26.2): + /@rollup/plugin-node-resolve@15.1.0(rollup@3.26.0): resolution: {integrity: sha512-xeZHCgsiZ9pzYVgAo9580eCGqwh/XCEUM9q6iQfGNocjgkufHAqC3exA+45URvhiYV8sBF9RlBai650eNs7AsA==} engines: {node: '>=14.0.0'} peerDependencies: @@ -5699,13 +6776,13 @@ packages: rollup: optional: true dependencies: - '@rollup/pluginutils': 5.0.2(rollup@3.26.2) + '@rollup/pluginutils': 5.0.2(rollup@3.26.0) '@types/resolve': 1.20.2 deepmerge: 4.3.1 is-builtin-module: 3.2.1 is-module: 1.0.0 resolve: 1.22.2 - rollup: 3.26.2 + rollup: 3.26.0 dev: true /@rollup/plugin-replace@2.4.2(rollup@2.79.1): @@ -5730,7 +6807,7 @@ packages: rollup: 2.79.1 dev: true - /@rollup/pluginutils@3.1.0(rollup@3.26.2): + /@rollup/pluginutils@3.1.0(rollup@3.26.0): resolution: {integrity: sha512-GksZ6pr6TpIjHm8h9lSQ8pi8BE9VeubNT0OMJ3B5uZJ8pz73NPiqOtCog/x2/QzM1ENChPKxMDhiQuRHsqc+lg==} engines: {node: '>= 8.0.0'} peerDependencies: @@ -5739,7 +6816,7 @@ packages: '@types/estree': 0.0.39 estree-walker: 1.0.1 picomatch: 2.3.1 - rollup: 3.26.2 + rollup: 3.26.0 dev: false /@rollup/pluginutils@4.2.1: @@ -5764,7 +6841,7 @@ packages: rollup: 2.79.1 dev: true - /@rollup/pluginutils@5.0.2(rollup@3.26.2): + /@rollup/pluginutils@5.0.2(rollup@3.26.0): resolution: {integrity: sha512-pTd9rIsP92h+B6wWwFbW8RkZv4hiR/xKsqre4SIuAOaOEQRxi0lqLke9k2/7WegC85GgUs9pjmOjCUi3In4vwA==} engines: {node: '>=14.0.0'} peerDependencies: @@ -5776,14 +6853,14 @@ packages: '@types/estree': 1.0.1 estree-walker: 2.0.2 picomatch: 2.3.1 - rollup: 3.26.2 + rollup: 3.26.0 dev: true - /@sinclair/typebox@0.27.8: - resolution: {integrity: sha512-+Fj43pSMwJs4KRrH/938Uf+uAELIgVBmQzg/q1YG10djyfA3TnrU8N8XzqCh/okZdszqBQTZf96idMfE5lnwTA==} + /@sinclair/typebox@0.25.24: + resolution: {integrity: sha512-XJfwUVUKDHF5ugKwIcxEgc9k8b7HbznCp6eUfWgu710hMPNIO4aw4/zB5RogDQz8nd6gyCDpU9O/m6qYEWY6yQ==} - /@sindresorhus/is@5.4.1: - resolution: {integrity: sha512-axlrvsHlHlFmKKMEg4VyvMzFr93JWJj4eIfXY1STVuO2fsImCa7ncaiG5gC8HKOX590AW5RtRsC41/B+OfrSqw==} + /@sindresorhus/is@5.3.0: + resolution: {integrity: sha512-CX6t4SYQ37lzxicAqsBtxA3OseeoVrh9cSJ5PFYam0GksYlupRfy1A+Q4aYD3zvcfECLc0zO2u+ZnR2UYKvCrw==} engines: {node: '>=14.16'} dev: true @@ -5811,8 +6888,8 @@ packages: '@sinonjs/commons': 1.8.6 dev: true - /@storybook/addon-actions@6.5.16(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-aADjilFmuD6TNGz2CRPSupnyiA/IGkPJHDBTqMpsDXTUr8xnuD122xkIhg6UxmCM2y1c+ncwYXy3WPK2xXK57g==} + /@storybook/addon-actions@6.5.10(react-dom@17.0.2)(react@17.0.2): + resolution: {integrity: sha512-vpCnEu81fmtYzOf0QsRYoDuf9wXgVVl2VysE1dWRebRhIUDU0JurrthTnw322e38D4FzaoNGqZE7wnBYBohzZA==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -5822,14 +6899,14 @@ packages: react-dom: optional: true dependencies: - '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/api': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.16 - '@storybook/components': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/core-events': 6.5.16 + '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/api': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/client-logger': 6.5.10 + '@storybook/components': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/core-events': 6.5.10 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/theming': 6.5.16(react-dom@17.0.2)(react@17.0.2) - core-js: 3.31.1 + '@storybook/theming': 6.5.10(react-dom@17.0.2)(react@17.0.2) + core-js: 3.25.0 fast-deep-equal: 3.1.3 global: 4.4.0 lodash: 4.17.21 @@ -5838,15 +6915,15 @@ packages: react: 17.0.2 react-dom: 17.0.2(react@17.0.2) react-inspector: 5.1.1(react@17.0.2) - regenerator-runtime: 0.13.11 + regenerator-runtime: 0.13.9 telejson: 6.0.8 ts-dedent: 2.2.0 util-deprecate: 1.0.2 uuid-browser: 3.1.0 dev: true - /@storybook/addon-backgrounds@6.5.16(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-t7qooZ892BruhilFmzYPbysFwpULt/q4zYXNSmKVbAYta8UVvitjcU4F18p8FpWd9WvhiTr0SDlyhNZuzvDfug==} + /@storybook/addon-backgrounds@6.5.10(react-dom@17.0.2)(react@17.0.2): + resolution: {integrity: sha512-5uzQda3dh891h7BL8e9Ymk7BI+QgkkzDJXuA4mHjOXfIiD3S3efhJI8amXuBC2ZpIr6zmVit0MqZVyoVve46cQ==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -5856,14 +6933,14 @@ packages: react-dom: optional: true dependencies: - '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/api': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.16 - '@storybook/components': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/core-events': 6.5.16 + '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/api': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/client-logger': 6.5.10 + '@storybook/components': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/core-events': 6.5.10 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/theming': 6.5.16(react-dom@17.0.2)(react@17.0.2) - core-js: 3.31.1 + '@storybook/theming': 6.5.10(react-dom@17.0.2)(react@17.0.2) + core-js: 3.25.0 global: 4.4.0 memoizerific: 1.11.3 react: 17.0.2 @@ -5873,8 +6950,8 @@ packages: util-deprecate: 1.0.2 dev: true - /@storybook/addon-controls@6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5): - resolution: {integrity: sha512-kShSGjq1MjmmyL3l8i+uPz6yddtf82mzys0l82VKtcuyjrr5944wYFJ5NTXMfZxrO/U6FeFsfuFZE/k6ex3EMg==} + /@storybook/addon-controls@6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4): + resolution: {integrity: sha512-lC2y3XcolmQAJwFurIyGrynAHPWmfNtTCdu3rQBTVGwyxCoNwdOOeC2jV0BRqX2+CW6OHzJr9frNWXPSaZ8c4w==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -5884,16 +6961,16 @@ packages: react-dom: optional: true dependencies: - '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/api': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.16 - '@storybook/components': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/core-common': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) + '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/api': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/client-logger': 6.5.10 + '@storybook/components': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/core-common': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/node-logger': 6.5.16 - '@storybook/store': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/theming': 6.5.16(react-dom@17.0.2)(react@17.0.2) - core-js: 3.31.1 + '@storybook/node-logger': 6.5.10 + '@storybook/store': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/theming': 6.5.10(react-dom@17.0.2)(react@17.0.2) + core-js: 3.25.0 lodash: 4.17.21 react: 17.0.2 react-dom: 17.0.2(react@17.0.2) @@ -5907,8 +6984,8 @@ packages: - webpack-command dev: true - /@storybook/addon-docs@6.5.16(@babel/core@7.22.8)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5)(webpack@5.88.1): - resolution: {integrity: sha512-QM9WDZG9P02UvbzLu947a8ZngOrQeAKAT8jCibQFM/+RJ39xBlfm8rm+cQy3dm94wgtjmVkA3mKGOV/yrrsddg==} + /@storybook/addon-docs@6.5.10(@babel/core@7.18.13)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4)(webpack@5.74.0): + resolution: {integrity: sha512-1kgjo3f0vL6GN8fTwLL05M/q/kDdzvuqwhxPY/v5hubFb3aQZGr2yk9pRBaLAbs4bez0yG0ASXcwhYnrEZUppg==} peerDependencies: '@storybook/mdx2-csf': ^0.0.3 react: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -5921,26 +6998,26 @@ packages: react-dom: optional: true dependencies: - '@babel/plugin-transform-react-jsx': 7.22.5(@babel/core@7.22.8) - '@babel/preset-env': 7.22.7(@babel/core@7.22.8) + '@babel/plugin-transform-react-jsx': 7.19.0(@babel/core@7.18.13) + '@babel/preset-env': 7.18.10(@babel/core@7.18.13) '@jest/transform': 26.6.2 '@mdx-js/react': 1.6.22(react@17.0.2) - '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/api': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/components': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/core-common': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) - '@storybook/core-events': 6.5.16 + '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/api': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/components': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/core-common': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) + '@storybook/core-events': 6.5.10 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/docs-tools': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/mdx1-csf': 0.0.1(@babel/core@7.22.8) - '@storybook/node-logger': 6.5.16 - '@storybook/postinstall': 6.5.16 - '@storybook/preview-web': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/source-loader': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/store': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/theming': 6.5.16(react-dom@17.0.2)(react@17.0.2) - babel-loader: 8.3.0(@babel/core@7.22.8)(webpack@5.88.1) - core-js: 3.31.1 + '@storybook/docs-tools': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/mdx1-csf': 0.0.1(@babel/core@7.18.13) + '@storybook/node-logger': 6.5.10 + '@storybook/postinstall': 6.5.10 + '@storybook/preview-web': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/source-loader': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/store': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/theming': 6.5.10(react-dom@17.0.2)(react@17.0.2) + babel-loader: 8.2.5(@babel/core@7.18.13)(webpack@5.74.0) + core-js: 3.25.0 fast-deep-equal: 3.1.3 global: 4.4.0 lodash: 4.17.21 @@ -5962,8 +7039,8 @@ packages: - webpack-command dev: true - /@storybook/addon-essentials@6.5.16(@babel/core@7.22.8)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5)(webpack@5.88.1): - resolution: {integrity: sha512-TeoMr6tEit4Pe91GH6f8g/oar1P4M0JL9S6oMcFxxrhhtOGO7XkWD5EnfyCx272Ok2VYfE58FNBTGPNBVIqYKQ==} + /@storybook/addon-essentials@6.5.10(@babel/core@7.18.13)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4)(webpack@5.74.0): + resolution: {integrity: sha512-PT2aiR4vgAyB0pl3HNBUa4/a7NDRxASxAazz7zt9ZDirkipDKfxwdcLeRoJzwSngVDWEhuz5/paN5x4eNp4Hww==} peerDependencies: '@babel/core': ^7.9.6 '@storybook/angular': '*' @@ -6019,25 +7096,25 @@ packages: webpack: optional: true dependencies: - '@babel/core': 7.22.8 - '@storybook/addon-actions': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/addon-backgrounds': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/addon-controls': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) - '@storybook/addon-docs': 6.5.16(@babel/core@7.22.8)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5)(webpack@5.88.1) - '@storybook/addon-measure': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/addon-outline': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/addon-toolbars': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/addon-viewport': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/api': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/core-common': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) - '@storybook/node-logger': 6.5.16 - core-js: 3.31.1 + '@babel/core': 7.18.13 + '@storybook/addon-actions': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/addon-backgrounds': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/addon-controls': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) + '@storybook/addon-docs': 6.5.10(@babel/core@7.18.13)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4)(webpack@5.74.0) + '@storybook/addon-measure': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/addon-outline': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/addon-toolbars': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/addon-viewport': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/api': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/core-common': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) + '@storybook/node-logger': 6.5.10 + core-js: 3.25.0 react: 17.0.2 react-dom: 17.0.2(react@17.0.2) - regenerator-runtime: 0.13.11 + regenerator-runtime: 0.13.9 ts-dedent: 2.2.0 - webpack: 5.88.1(esbuild@0.18.11) + webpack: 5.74.0(esbuild@0.18.11) transitivePeerDependencies: - '@storybook/mdx2-csf' - eslint @@ -6048,8 +7125,8 @@ packages: - webpack-command dev: true - /@storybook/addon-links@6.5.16(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-P/mmqK57NGXnR0i3d/T5B0rIt0Lg8Yq+qionRr3LK3AwG/4yGnYt4GNomLEknn/eEwABYq1Q/Z1aOpgIhNdq5A==} + /@storybook/addon-links@6.5.10(react-dom@17.0.2)(react@17.0.2): + resolution: {integrity: sha512-r3WzYIPz7WjHiaPObC2Tg6bHuZRBb/Kt/X+Eitw+jTqBel7ksvkO36tn81q8Eyj61qIdNQmUWAaX/0aewT0kLA==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -6059,24 +7136,24 @@ packages: react-dom: optional: true dependencies: - '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.16 - '@storybook/core-events': 6.5.16 + '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/client-logger': 6.5.10 + '@storybook/core-events': 6.5.10 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/router': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/router': 6.5.10(react-dom@17.0.2)(react@17.0.2) '@types/qs': 6.9.7 - core-js: 3.31.1 + core-js: 3.25.0 global: 4.4.0 prop-types: 15.8.1 - qs: 6.11.2 + qs: 6.11.0 react: 17.0.2 react-dom: 17.0.2(react@17.0.2) - regenerator-runtime: 0.13.11 + regenerator-runtime: 0.13.9 ts-dedent: 2.2.0 dev: true - /@storybook/addon-measure@6.5.16(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-DMwnXkmM2L6POTh4KaOWvOAtQ2p9Tr1UUNxz6VXiN5cKFohpCs6x0txdLU5WN8eWIq0VFsO7u5ZX34CGCc6gCg==} + /@storybook/addon-measure@6.5.10(react-dom@17.0.2)(react@17.0.2): + resolution: {integrity: sha512-ss7L1H5K5hXygDIoVwj+QyVXbve5V67x7CofLiLCgQYuJzfO16+sPGjiTGWMpTb4ijox2uKWnTkpilt5bCjXgw==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -6086,20 +7163,20 @@ packages: react-dom: optional: true dependencies: - '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/api': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.16 - '@storybook/components': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/core-events': 6.5.16 + '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/api': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/client-logger': 6.5.10 + '@storybook/components': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/core-events': 6.5.10 '@storybook/csf': 0.0.2--canary.4566f4d.1 - core-js: 3.31.1 + core-js: 3.25.0 global: 4.4.0 react: 17.0.2 react-dom: 17.0.2(react@17.0.2) dev: true - /@storybook/addon-outline@6.5.16(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-0du96nha4qltexO0Xq1xB7LeRSbqjC9XqtZLflXG7/X3ABoPD2cXgOV97eeaXUodIyb2qYBbHUfftBeA75x0+w==} + /@storybook/addon-outline@6.5.10(react-dom@17.0.2)(react@17.0.2): + resolution: {integrity: sha512-AjdaeQ+/iBKmGrAqRW4niwMB6AkgGnYmSzVs5Cf6F/Sb4Dp+vzgLNOwLABD9qs8Ri8dvHl5J4QpVwQKUhYZaOQ==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -6109,13 +7186,13 @@ packages: react-dom: optional: true dependencies: - '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/api': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.16 - '@storybook/components': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/core-events': 6.5.16 + '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/api': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/client-logger': 6.5.10 + '@storybook/components': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/core-events': 6.5.10 '@storybook/csf': 0.0.2--canary.4566f4d.1 - core-js: 3.31.1 + core-js: 3.25.0 global: 4.4.0 react: 17.0.2 react-dom: 17.0.2(react@17.0.2) @@ -6123,8 +7200,8 @@ packages: ts-dedent: 2.2.0 dev: true - /@storybook/addon-toolbars@6.5.16(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-y3PuUKiwOWrAvqx1YdUvArg0UaAwmboXFeR2bkrowk1xcT+xnRO3rML4npFeUl26OQ1FzwxX/cw6nknREBBLEA==} + /@storybook/addon-toolbars@6.5.10(react-dom@17.0.2)(react@17.0.2): + resolution: {integrity: sha512-S0Ljc6Wv+bPbx2e0iTveJ6bBDqjsemu+FZD4qDLsHreoI7DAcqyrF5Def1l8xNohixIVpx8dQpYXRtyzNlXekg==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -6134,19 +7211,19 @@ packages: react-dom: optional: true dependencies: - '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/api': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.16 - '@storybook/components': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/theming': 6.5.16(react-dom@17.0.2)(react@17.0.2) - core-js: 3.31.1 + '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/api': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/client-logger': 6.5.10 + '@storybook/components': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/theming': 6.5.10(react-dom@17.0.2)(react@17.0.2) + core-js: 3.25.0 react: 17.0.2 react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 dev: true - /@storybook/addon-viewport@6.5.16(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-1Vyqf1U6Qng6TXlf4SdqUKyizlw1Wn6+qW8YeA2q1lbkJqn3UlnHXIp8Q0t/5q1dK5BFtREox3+jkGwbJrzkmA==} + /@storybook/addon-viewport@6.5.10(react-dom@17.0.2)(react@17.0.2): + resolution: {integrity: sha512-RFMd+4kZljyuJjR9OJ2bFXHrSG7VTi5FDZYWEU+4W1sBxzC+JhnVnUP+HJH3gUxEFIRQC5neRzwWRE9RUUoALQ==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -6156,13 +7233,13 @@ packages: react-dom: optional: true dependencies: - '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/api': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.16 - '@storybook/components': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/core-events': 6.5.16 - '@storybook/theming': 6.5.16(react-dom@17.0.2)(react@17.0.2) - core-js: 3.31.1 + '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/api': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/client-logger': 6.5.10 + '@storybook/components': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/core-events': 6.5.10 + '@storybook/theming': 6.5.10(react-dom@17.0.2)(react@17.0.2) + core-js: 3.25.0 global: 4.4.0 memoizerific: 1.11.3 prop-types: 15.8.1 @@ -6171,41 +7248,41 @@ packages: regenerator-runtime: 0.13.11 dev: true - /@storybook/addons@6.5.16(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-p3DqQi+8QRL5k7jXhXmJZLsE/GqHqyY6PcoA1oNTJr0try48uhTGUOYkgzmqtDaa/qPFO5LP+xCPzZXckGtquQ==} + /@storybook/addons@6.5.10(react-dom@17.0.2)(react@17.0.2): + resolution: {integrity: sha512-VD4tBCQ23PkSeDoxuHcKy0RfhIs3oMYjBacOZx7d0bvOzK9WjPyvE2ysDAh7r/ceqnwmWHAScIpE+I1RU7gl+g==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/api': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/channels': 6.5.16 - '@storybook/client-logger': 6.5.16 - '@storybook/core-events': 6.5.16 + '@storybook/api': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/channels': 6.5.10 + '@storybook/client-logger': 6.5.10 + '@storybook/core-events': 6.5.10 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/router': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/theming': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@types/webpack-env': 1.18.1 - core-js: 3.31.1 + '@storybook/router': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/theming': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@types/webpack-env': 1.18.0 + core-js: 3.25.0 global: 4.4.0 react: 17.0.2 react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 dev: true - /@storybook/api@6.5.16(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-HOsuT8iomqeTMQJrRx5U8nsC7lJTwRr1DhdD0SzlqL4c80S/7uuCy4IZvOt4sYQjOzW5fOo/kamcoBXyLproTA==} + /@storybook/api@6.5.10(react-dom@17.0.2)(react@17.0.2): + resolution: {integrity: sha512-AkmgSPNEGdKp4oZA4KQ+RJsacw7GwfvjsVDnCkcXqS9zmSr/RNL0fhpcd60KKkmx/hGKPTDFpK3ZayxDrJ/h4A==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/channels': 6.5.16 - '@storybook/client-logger': 6.5.16 - '@storybook/core-events': 6.5.16 + '@storybook/channels': 6.5.10 + '@storybook/client-logger': 6.5.10 + '@storybook/core-events': 6.5.10 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/router': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/router': 6.5.10(react-dom@17.0.2)(react@17.0.2) '@storybook/semver': 7.3.2 - '@storybook/theming': 6.5.16(react-dom@17.0.2)(react@17.0.2) - core-js: 3.31.1 + '@storybook/theming': 6.5.10(react-dom@17.0.2)(react@17.0.2) + core-js: 3.25.0 fast-deep-equal: 3.1.3 global: 4.4.0 lodash: 4.17.21 @@ -6219,7 +7296,7 @@ packages: util-deprecate: 1.0.2 dev: true - /@storybook/builder-vite@0.1.41(@babel/core@7.22.8)(@storybook/core-common@6.5.16)(@storybook/node-logger@6.5.16)(@storybook/source-loader@6.5.16)(react@17.0.2)(typescript@4.9.5)(vite@4.4.3): + /@storybook/builder-vite@0.1.41(@babel/core@7.18.13)(@storybook/core-common@6.5.10)(@storybook/node-logger@6.5.10)(@storybook/source-loader@6.5.10)(react@17.0.2)(typescript@4.8.4)(vite@4.3.9): resolution: {integrity: sha512-h/7AgEUfSuVexTD6LuJ6BCNu+FSo/+IKYBQ1O3TyF2BEgcob5/BGrx9QcwM0LJCF44L1zNKaxkKpCZs9p+LRRA==} peerDependencies: '@storybook/core-common': '>=6.4.3 || >=6.5.0-alpha.0' @@ -6231,21 +7308,21 @@ packages: '@storybook/mdx2-csf': optional: true dependencies: - '@joshwooding/vite-plugin-react-docgen-typescript': 0.0.4(typescript@4.9.5)(vite@4.4.3) - '@storybook/core-common': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) - '@storybook/mdx1-csf': 0.0.4(@babel/core@7.22.8)(react@17.0.2) - '@storybook/node-logger': 6.5.16 - '@storybook/source-loader': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@joshwooding/vite-plugin-react-docgen-typescript': 0.0.4(typescript@4.8.4)(vite@4.3.9) + '@storybook/core-common': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) + '@storybook/mdx1-csf': 0.0.4(@babel/core@7.18.13)(react@17.0.2) + '@storybook/node-logger': 6.5.10 + '@storybook/source-loader': 6.5.10(react-dom@17.0.2)(react@17.0.2) '@vitejs/plugin-react': 1.3.2 ast-types: 0.14.2 es-module-lexer: 0.9.3 glob: 7.2.3 glob-promise: 4.2.2(glob@7.2.3) magic-string: 0.26.7 - react-docgen: 6.0.1 + react-docgen: 6.0.0-alpha.3 slash: 3.0.0 sveltedoc-parser: 4.2.1 - vite: 4.4.3(@types/node@18.16.19) + vite: 4.3.9(@types/node@18.16.19) transitivePeerDependencies: - '@babel/core' - react @@ -6253,8 +7330,8 @@ packages: - typescript dev: true - /@storybook/builder-webpack4@6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5): - resolution: {integrity: sha512-YqDIrVNsUo8r9xc6AxsYDLxVYtMgl5Bxk+8/h1adsOko+jAFhdg6hOcAVxEmoSI0TMASOOVMFlT2hr23ppN2rQ==} + /@storybook/builder-webpack4@6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4): + resolution: {integrity: sha512-AoKjsCNoQQoZXYwBDxO8s+yVEd5FjBJAaysEuUTHq2fb81jwLrGcEOo6hjw4jqfugZQIzYUEjPazlvubS78zpw==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -6263,38 +7340,38 @@ packages: typescript: optional: true dependencies: - '@babel/core': 7.22.8 - '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/api': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/channel-postmessage': 6.5.16 - '@storybook/channels': 6.5.16 - '@storybook/client-api': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.16 - '@storybook/components': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/core-common': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) - '@storybook/core-events': 6.5.16 - '@storybook/node-logger': 6.5.16 - '@storybook/preview-web': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/router': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@babel/core': 7.22.5 + '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/api': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/channel-postmessage': 6.5.10 + '@storybook/channels': 6.5.10 + '@storybook/client-api': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/client-logger': 6.5.10 + '@storybook/components': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/core-common': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) + '@storybook/core-events': 6.5.10 + '@storybook/node-logger': 6.5.10 + '@storybook/preview-web': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/router': 6.5.10(react-dom@17.0.2)(react@17.0.2) '@storybook/semver': 7.3.2 - '@storybook/store': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/theming': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/ui': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@types/node': 16.18.38 - '@types/webpack': 4.41.33 + '@storybook/store': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/theming': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/ui': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@types/node': 16.11.56 + '@types/webpack': 4.41.32 autoprefixer: 9.8.8 - babel-loader: 8.3.0(@babel/core@7.22.8)(webpack@4.46.0) + babel-loader: 8.2.5(@babel/core@7.22.5)(webpack@4.46.0) case-sensitive-paths-webpack-plugin: 2.4.0 - core-js: 3.31.1 + core-js: 3.25.0 css-loader: 3.6.0(webpack@4.46.0) file-loader: 6.2.0(webpack@4.46.0) find-up: 5.0.0 - fork-ts-checker-webpack-plugin: 4.1.6(eslint@8.4.1)(typescript@4.9.5)(webpack@4.46.0) + fork-ts-checker-webpack-plugin: 4.1.6(eslint@8.4.1)(typescript@4.8.4)(webpack@4.46.0) glob: 7.2.3 glob-promise: 3.4.0(glob@7.2.3) global: 4.4.0 html-webpack-plugin: 4.5.2(webpack@4.46.0) - pnp-webpack-plugin: 1.6.4(typescript@4.9.5) + pnp-webpack-plugin: 1.6.4(typescript@4.8.4) postcss: 7.0.39 postcss-flexbugs-fixes: 4.2.1 postcss-loader: 4.3.0(postcss@7.0.39)(webpack@4.46.0) @@ -6305,13 +7382,13 @@ packages: style-loader: 1.3.0(webpack@4.46.0) terser-webpack-plugin: 4.2.3(webpack@4.46.0) ts-dedent: 2.2.0 - typescript: 4.9.5 + typescript: 4.8.4 url-loader: 4.1.1(file-loader@6.2.0)(webpack@4.46.0) util-deprecate: 1.0.2 webpack: 4.46.0 webpack-dev-middleware: 3.7.3(webpack@4.46.0) webpack-filter-warnings-plugin: 1.2.1(webpack@4.46.0) - webpack-hot-middleware: 2.25.4 + webpack-hot-middleware: 2.25.2 webpack-virtual-modules: 0.2.2 transitivePeerDependencies: - bluebird @@ -6322,114 +7399,93 @@ packages: - webpack-command dev: true - /@storybook/channel-postmessage@6.5.16: - resolution: {integrity: sha512-fZZSN29dsUArWOx7e7lTdMA9+7zijVwCwbvi2Fo4fqhRLh1DsTb/VXfz1FKMCWAjNlcX7QQvV25tnxbqsD6lyw==} + /@storybook/channel-postmessage@6.5.10: + resolution: {integrity: sha512-t9PTA0UzFvYa3IlOfpBOolfrRMPTjUMIeCQ6FNyM0aj5GqLKSvoQzP8NeoRpIrvyf6ljFKKdaMaZ3fiCvh45ag==} dependencies: - '@storybook/channels': 6.5.16 - '@storybook/client-logger': 6.5.16 - '@storybook/core-events': 6.5.16 - core-js: 3.31.1 + '@storybook/channels': 6.5.10 + '@storybook/client-logger': 6.5.10 + '@storybook/core-events': 6.5.10 + core-js: 3.25.0 global: 4.4.0 - qs: 6.11.2 + qs: 6.11.0 telejson: 6.0.8 dev: true - /@storybook/channel-postmessage@7.0.26: - resolution: {integrity: sha512-ZvFLr/tUD9dWIjQtIn1JXHjqrbOP/uEEOqzwpKSVj0Cl4Vgc12s8hecbzBufkOF7fwLsFvfieSi7ENOmjoncdQ==} + /@storybook/channel-websocket@6.5.10: + resolution: {integrity: sha512-RTXMZbMWCS3xU+4GVIdfnUXsKcwg/WTozy88/5OxaKjGw6KgRedqLAQJKJ6Y5XlnwIcWelirkHj/COwTTXhbPg==} dependencies: - '@storybook/channels': 7.0.26 - '@storybook/client-logger': 7.0.26 - '@storybook/core-events': 7.0.26 - '@storybook/global': 5.0.0 - qs: 6.11.2 - telejson: 7.1.0 - dev: true - - /@storybook/channel-websocket@6.5.16: - resolution: {integrity: sha512-wJg2lpBjmRC2GJFzmhB9kxlh109VE58r/0WhFtLbwKvPqsvGf82xkBEl6BtBCvIQ4stzYnj/XijjA8qSi2zpOg==} - dependencies: - '@storybook/channels': 6.5.16 - '@storybook/client-logger': 6.5.16 - core-js: 3.31.1 + '@storybook/channels': 6.5.10 + '@storybook/client-logger': 6.5.10 + core-js: 3.25.0 global: 4.4.0 telejson: 6.0.8 dev: true - /@storybook/channels@6.5.16: - resolution: {integrity: sha512-VylzaWQZaMozEwZPJdyJoz+0jpDa8GRyaqu9TGG6QGv+KU5POoZaGLDkRE7TzWkyyP0KQLo80K99MssZCpgSeg==} + /@storybook/channels@6.5.10: + resolution: {integrity: sha512-lo26YZ6kWpHXLhuHJF4P/bICY7jD/rXEZqReKtGOSk1Lv99/xvG6pqmcy3hWLf3v3Dy/8otjRPSR7izFVIIZgQ==} dependencies: - core-js: 3.31.1 + core-js: 3.25.0 ts-dedent: 2.2.0 util-deprecate: 1.0.2 dev: true - /@storybook/channels@7.0.26: - resolution: {integrity: sha512-Br3XILhrtuL5Sdp91I04kKjJzSqU/N8gGL6B6nIfnuaHUvGMDuMCHAB+g7aoiyH5dnpDZ6yBVGNwtYAyJA+0Og==} - dev: true - - /@storybook/client-api@6.5.16(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-i3UwkzzUFw8I+E6fOcgB5sc4oU2fhvaKnqC1mpd9IYGJ9JN9MnGIaVl3Ko28DtFItu/QabC9JsLIJVripFLktQ==} + /@storybook/client-api@6.5.10(react-dom@17.0.2)(react@17.0.2): + resolution: {integrity: sha512-3wBWZl3NvMFgMovgEh+euiARAT2FXzpvTF4Q1gerGMNNDlrGxHnFvSuy4FHg/irtOGLa4yLz43ULFbYtpKw0Lg==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/channel-postmessage': 6.5.16 - '@storybook/channels': 6.5.16 - '@storybook/client-logger': 6.5.16 - '@storybook/core-events': 6.5.16 + '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/channel-postmessage': 6.5.10 + '@storybook/channels': 6.5.10 + '@storybook/client-logger': 6.5.10 + '@storybook/core-events': 6.5.10 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/store': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/store': 6.5.10(react-dom@17.0.2)(react@17.0.2) '@types/qs': 6.9.7 - '@types/webpack-env': 1.18.1 - core-js: 3.31.1 + '@types/webpack-env': 1.18.0 + core-js: 3.25.0 fast-deep-equal: 3.1.3 global: 4.4.0 lodash: 4.17.21 memoizerific: 1.11.3 - qs: 6.11.2 + qs: 6.11.0 react: 17.0.2 react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 store2: 2.14.2 - synchronous-promise: 2.0.17 + synchronous-promise: 2.0.16 ts-dedent: 2.2.0 util-deprecate: 1.0.2 dev: true - /@storybook/client-logger@6.5.16: - resolution: {integrity: sha512-pxcNaCj3ItDdicPTXTtmYJE3YC1SjxFrBmHcyrN+nffeNyiMuViJdOOZzzzucTUG0wcOOX8jaSyak+nnHg5H1Q==} + /@storybook/client-logger@6.5.10: + resolution: {integrity: sha512-/xA0MHOevXev68hyLMQw8Qo8KczSIdXOxliAgrycMTkDmw5eKeA8TP7B8zP3wGuq/e3MrdD9/8MWhb/IQBNC3w==} dependencies: - core-js: 3.31.1 + core-js: 3.25.0 global: 4.4.0 dev: true - /@storybook/client-logger@7.0.26: - resolution: {integrity: sha512-OMVLbgceoeuM8sWOfTX/9a4zCrH78G32hg7x8yXLZnRJ9OLaHJHzUM0Onc4MLudqVUdaKH0c8ejpBXUyIr1rJQ==} - dependencies: - '@storybook/global': 5.0.0 - dev: true - - /@storybook/components@6.5.16(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-LzBOFJKITLtDcbW9jXl0/PaG+4xAz25PK8JxPZpIALbmOpYWOAPcO6V9C2heX6e6NgWFMUxjplkULEk9RCQMNA==} + /@storybook/components@6.5.10(react-dom@17.0.2)(react@17.0.2): + resolution: {integrity: sha512-9OhgB8YQfGwOKjo/N96N5mrtJ6qDVVoEM1zuhea32tJUd2eYf0aSWpryA9VnOM0V1q/8DAoCg5rPBMYWMBU5uw==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/client-logger': 6.5.16 + '@storybook/client-logger': 6.5.10 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/theming': 6.5.16(react-dom@17.0.2)(react@17.0.2) - core-js: 3.31.1 + '@storybook/theming': 6.5.10(react-dom@17.0.2)(react@17.0.2) + core-js: 3.25.0 memoizerific: 1.11.3 - qs: 6.11.2 + qs: 6.11.0 react: 17.0.2 react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 util-deprecate: 1.0.2 dev: true - /@storybook/core-client@6.5.16(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5)(webpack@4.46.0): - resolution: {integrity: sha512-14IRaDrVtKrQ+gNWC0wPwkCNfkZOKghYV/swCUnQX3rP99defsZK8Hc7xHIYoAiOP5+sc3sweRAxgmFiJeQ1Ig==} + /@storybook/core-client@6.5.10(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4)(webpack@4.46.0): + resolution: {integrity: sha512-THsIjNrOrampTl0Lgfjvfjk1JnktKb4CQLOM80KpQb4cjDqorBjJmErzUkUQ2y3fXvrDmQ/kUREkShET4XEdtA==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -6439,34 +7495,34 @@ packages: typescript: optional: true dependencies: - '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/channel-postmessage': 6.5.16 - '@storybook/channel-websocket': 6.5.16 - '@storybook/client-api': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.16 - '@storybook/core-events': 6.5.16 + '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/channel-postmessage': 6.5.10 + '@storybook/channel-websocket': 6.5.10 + '@storybook/client-api': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/client-logger': 6.5.10 + '@storybook/core-events': 6.5.10 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/preview-web': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/store': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/ui': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/preview-web': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/store': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/ui': 6.5.10(react-dom@17.0.2)(react@17.0.2) airbnb-js-shims: 2.2.1 ansi-to-html: 0.6.15 - core-js: 3.31.1 + core-js: 3.25.0 global: 4.4.0 lodash: 4.17.21 - qs: 6.11.2 + qs: 6.11.0 react: 17.0.2 react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 ts-dedent: 2.2.0 - typescript: 4.9.5 + typescript: 4.8.4 unfetch: 4.2.0 util-deprecate: 1.0.2 webpack: 4.46.0 dev: true - /@storybook/core-client@6.5.16(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5)(webpack@5.88.1): - resolution: {integrity: sha512-14IRaDrVtKrQ+gNWC0wPwkCNfkZOKghYV/swCUnQX3rP99defsZK8Hc7xHIYoAiOP5+sc3sweRAxgmFiJeQ1Ig==} + /@storybook/core-client@6.5.10(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4)(webpack@5.74.0): + resolution: {integrity: sha512-THsIjNrOrampTl0Lgfjvfjk1JnktKb4CQLOM80KpQb4cjDqorBjJmErzUkUQ2y3fXvrDmQ/kUREkShET4XEdtA==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -6476,34 +7532,34 @@ packages: typescript: optional: true dependencies: - '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/channel-postmessage': 6.5.16 - '@storybook/channel-websocket': 6.5.16 - '@storybook/client-api': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.16 - '@storybook/core-events': 6.5.16 + '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/channel-postmessage': 6.5.10 + '@storybook/channel-websocket': 6.5.10 + '@storybook/client-api': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/client-logger': 6.5.10 + '@storybook/core-events': 6.5.10 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/preview-web': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/store': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/ui': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/preview-web': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/store': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/ui': 6.5.10(react-dom@17.0.2)(react@17.0.2) airbnb-js-shims: 2.2.1 ansi-to-html: 0.6.15 - core-js: 3.31.1 + core-js: 3.25.0 global: 4.4.0 lodash: 4.17.21 - qs: 6.11.2 + qs: 6.11.0 react: 17.0.2 react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 ts-dedent: 2.2.0 - typescript: 4.9.5 + typescript: 4.8.4 unfetch: 4.2.0 util-deprecate: 1.0.2 - webpack: 5.88.1(esbuild@0.18.11) + webpack: 5.74.0(esbuild@0.18.11) dev: true - /@storybook/core-common@6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5): - resolution: {integrity: sha512-2qtnKP3TTOzt2cp6LXKRTh7XrI9z5VanMnMTgeoFcA5ebnndD4V6BExQUdYPClE/QooLx6blUWNgS9dFEpjSqQ==} + /@storybook/core-common@6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4): + resolution: {integrity: sha512-Bx+VKkfWdrAmD8T51Sjq/mMhRaiapBHcpG4cU5bc3DMbg+LF2/yrgqv/cjVu+m5gHAzYCac5D7gqzBgvG7Myww==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -6512,41 +7568,41 @@ packages: typescript: optional: true dependencies: - '@babel/core': 7.22.8 - '@babel/plugin-proposal-class-properties': 7.18.6(@babel/core@7.22.8) - '@babel/plugin-proposal-decorators': 7.22.7(@babel/core@7.22.8) - '@babel/plugin-proposal-export-default-from': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-proposal-nullish-coalescing-operator': 7.18.6(@babel/core@7.22.8) - '@babel/plugin-proposal-object-rest-spread': 7.20.7(@babel/core@7.22.8) - '@babel/plugin-proposal-optional-chaining': 7.21.0(@babel/core@7.22.8) - '@babel/plugin-proposal-private-methods': 7.18.6(@babel/core@7.22.8) - '@babel/plugin-proposal-private-property-in-object': 7.21.11(@babel/core@7.22.8) - '@babel/plugin-syntax-dynamic-import': 7.8.3(@babel/core@7.22.8) - '@babel/plugin-transform-arrow-functions': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-block-scoping': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-classes': 7.22.6(@babel/core@7.22.8) - '@babel/plugin-transform-destructuring': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-for-of': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-parameters': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-shorthand-properties': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-spread': 7.22.5(@babel/core@7.22.8) - '@babel/preset-env': 7.22.7(@babel/core@7.22.8) - '@babel/preset-react': 7.22.5(@babel/core@7.22.8) - '@babel/preset-typescript': 7.22.5(@babel/core@7.22.8) - '@babel/register': 7.22.5(@babel/core@7.22.8) - '@storybook/node-logger': 6.5.16 + '@babel/core': 7.22.5 + '@babel/plugin-proposal-class-properties': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-proposal-decorators': 7.18.10(@babel/core@7.22.5) + '@babel/plugin-proposal-export-default-from': 7.18.10(@babel/core@7.22.5) + '@babel/plugin-proposal-nullish-coalescing-operator': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-proposal-object-rest-spread': 7.18.9(@babel/core@7.22.5) + '@babel/plugin-proposal-optional-chaining': 7.18.9(@babel/core@7.22.5) + '@babel/plugin-proposal-private-methods': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-proposal-private-property-in-object': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-syntax-dynamic-import': 7.8.3(@babel/core@7.22.5) + '@babel/plugin-transform-arrow-functions': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-transform-block-scoping': 7.18.9(@babel/core@7.22.5) + '@babel/plugin-transform-classes': 7.18.9(@babel/core@7.22.5) + '@babel/plugin-transform-destructuring': 7.18.13(@babel/core@7.22.5) + '@babel/plugin-transform-for-of': 7.18.8(@babel/core@7.22.5) + '@babel/plugin-transform-parameters': 7.18.8(@babel/core@7.22.5) + '@babel/plugin-transform-shorthand-properties': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-transform-spread': 7.18.9(@babel/core@7.22.5) + '@babel/preset-env': 7.18.10(@babel/core@7.22.5) + '@babel/preset-react': 7.18.6(@babel/core@7.22.5) + '@babel/preset-typescript': 7.18.6(@babel/core@7.22.5) + '@babel/register': 7.18.9(@babel/core@7.22.5) + '@storybook/node-logger': 6.5.10 '@storybook/semver': 7.3.2 - '@types/node': 16.18.38 + '@types/node': 16.11.56 '@types/pretty-hrtime': 1.0.1 - babel-loader: 8.3.0(@babel/core@7.22.8)(webpack@4.46.0) + babel-loader: 8.2.5(@babel/core@7.22.5)(webpack@4.46.0) babel-plugin-macros: 3.1.0 - babel-plugin-polyfill-corejs3: 0.1.7(@babel/core@7.22.8) + babel-plugin-polyfill-corejs3: 0.1.7(@babel/core@7.22.5) chalk: 4.1.2 - core-js: 3.31.1 - express: 4.18.2 + core-js: 3.25.0 + express: 4.18.1 file-system-cache: 1.1.0 find-up: 5.0.0 - fork-ts-checker-webpack-plugin: 6.5.3(eslint@8.4.1)(typescript@4.9.5)(webpack@4.46.0) + fork-ts-checker-webpack-plugin: 6.5.2(eslint@8.4.1)(typescript@4.8.4)(webpack@4.46.0) fs-extra: 9.1.0 glob: 7.2.3 handlebars: 4.7.7 @@ -6562,7 +7618,7 @@ packages: slash: 3.0.0 telejson: 6.0.8 ts-dedent: 2.2.0 - typescript: 4.9.5 + typescript: 4.8.4 util-deprecate: 1.0.2 webpack: 4.46.0 transitivePeerDependencies: @@ -6573,18 +7629,14 @@ packages: - webpack-command dev: true - /@storybook/core-events@6.5.16: - resolution: {integrity: sha512-qMZQwmvzpH5F2uwNUllTPg6eZXr2OaYZQRRN8VZJiuorZzDNdAFmiVWMWdkThwmyLEJuQKXxqCL8lMj/7PPM+g==} + /@storybook/core-events@6.5.10: + resolution: {integrity: sha512-EVb1gO1172klVIAABLOoigFMx0V88uctY0K/qVCO8n6v+wd2+0Ccn63kl+gTxsAC3WZ8XhXh9q2w5ImHklVECw==} dependencies: - core-js: 3.31.1 + core-js: 3.25.0 dev: true - /@storybook/core-events@7.0.26: - resolution: {integrity: sha512-ckZszphEAYs9wp8tPVhayEMzk8JxCiQfzbq0S45sbdqdTrl40PmsOjv5iPNaUYElI/Stfz+v4gDCEUfOsxyC+w==} - dev: true - - /@storybook/core-server@6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5): - resolution: {integrity: sha512-/3NPfmNyply395Dm0zaVZ8P9aruwO+tPx4D6/jpw8aqrRSwvAMndPMpoMCm0NXcpSm5rdX+Je4S3JW6JcggFkA==} + /@storybook/core-server@6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4): + resolution: {integrity: sha512-jqwpA0ccA8X5ck4esWBid04+cEIVqirdAcqJeNb9IZAD+bRreO4Im8ilzr7jc5AmQ9fkqHs2NByFKh9TITp8NQ==} peerDependencies: '@storybook/builder-webpack5': '*' '@storybook/manager-webpack5': '*' @@ -6600,38 +7652,38 @@ packages: optional: true dependencies: '@discoveryjs/json-ext': 0.5.7 - '@storybook/builder-webpack4': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) - '@storybook/core-client': 6.5.16(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5)(webpack@4.46.0) - '@storybook/core-common': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) - '@storybook/core-events': 6.5.16 + '@storybook/builder-webpack4': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) + '@storybook/core-client': 6.5.10(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4)(webpack@4.46.0) + '@storybook/core-common': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) + '@storybook/core-events': 6.5.10 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/csf-tools': 6.5.16 - '@storybook/manager-webpack4': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) - '@storybook/node-logger': 6.5.16 + '@storybook/csf-tools': 6.5.10 + '@storybook/manager-webpack4': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) + '@storybook/node-logger': 6.5.10 '@storybook/semver': 7.3.2 - '@storybook/store': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/telemetry': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) - '@types/node': 16.18.38 - '@types/node-fetch': 2.6.4 + '@storybook/store': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/telemetry': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) + '@types/node': 16.11.56 + '@types/node-fetch': 2.6.2 '@types/pretty-hrtime': 1.0.1 - '@types/webpack': 4.41.33 + '@types/webpack': 4.41.32 better-opn: 2.1.1 boxen: 5.1.2 chalk: 4.1.2 - cli-table3: 0.6.3 + cli-table3: 0.6.2 commander: 6.2.1 compression: 1.7.4 - core-js: 3.31.1 + core-js: 3.25.0 cpy: 8.1.2 - detect-port: 1.5.1 - express: 4.18.2 + detect-port: 1.3.0 + express: 4.18.1 fs-extra: 9.1.0 global: 4.4.0 globby: 11.1.0 ip: 2.0.0 lodash: 4.17.21 - node-fetch: 2.6.12 - open: 8.4.2 + node-fetch: 2.6.11 + open: 8.4.0 pretty-hrtime: 1.0.3 prompts: 2.4.2 react: 17.0.2 @@ -6641,7 +7693,7 @@ packages: slash: 3.0.0 telejson: 6.0.8 ts-dedent: 2.2.0 - typescript: 4.9.5 + typescript: 4.8.4 util-deprecate: 1.0.2 watchpack: 2.4.0 webpack: 4.46.0 @@ -6660,8 +7712,8 @@ packages: - webpack-command dev: true - /@storybook/core@6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5)(webpack@5.88.1): - resolution: {integrity: sha512-CEF3QFTsm/VMnMKtRNr4rRdLeIkIG0g1t26WcmxTdSThNPBd8CsWzQJ7Jqu7CKiut+MU4A1LMOwbwCE5F2gmyA==} + /@storybook/core@6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4)(webpack@5.74.0): + resolution: {integrity: sha512-K86yYa0tYlMxADlwQTculYvPROokQau09SCVqpsLg3wJCTvYFL4+SIqcYoyBSbFmHOdnYbJgPydjN33MYLiOZQ==} peerDependencies: '@storybook/builder-webpack5': '*' '@storybook/manager-webpack5': '*' @@ -6677,12 +7729,12 @@ packages: typescript: optional: true dependencies: - '@storybook/core-client': 6.5.16(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5)(webpack@5.88.1) - '@storybook/core-server': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) + '@storybook/core-client': 6.5.10(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4)(webpack@5.74.0) + '@storybook/core-server': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) react: 17.0.2 react-dom: 17.0.2(react@17.0.2) - typescript: 4.9.5 - webpack: 5.88.1(esbuild@0.18.11) + typescript: 4.8.4 + webpack: 5.74.0(esbuild@0.18.11) transitivePeerDependencies: - '@storybook/mdx2-csf' - bluebird @@ -6696,24 +7748,24 @@ packages: - webpack-command dev: true - /@storybook/csf-tools@6.5.16: - resolution: {integrity: sha512-+WD4sH/OwAfXZX3IN6/LOZ9D9iGEFcN+Vvgv9wOsLRgsAZ10DG/NK6c1unXKDM/ogJtJYccNI8Hd+qNE/GFV6A==} + /@storybook/csf-tools@6.5.10: + resolution: {integrity: sha512-H77kZQEisu7+skzeIbNZwmE09OqLjwJTeFhLN1pcjxKVa30LEI3pBHcNBxVKqgxl+Yg3KkB7W/ArLO2N+i2ohw==} peerDependencies: '@storybook/mdx2-csf': ^0.0.3 peerDependenciesMeta: '@storybook/mdx2-csf': optional: true dependencies: - '@babel/core': 7.22.8 - '@babel/generator': 7.22.7 - '@babel/parser': 7.22.7 - '@babel/plugin-transform-react-jsx': 7.22.5(@babel/core@7.22.8) - '@babel/preset-env': 7.22.7(@babel/core@7.22.8) - '@babel/traverse': 7.22.8 + '@babel/core': 7.22.5 + '@babel/generator': 7.22.5 + '@babel/parser': 7.22.5 + '@babel/plugin-transform-react-jsx': 7.19.0(@babel/core@7.22.5) + '@babel/preset-env': 7.18.10(@babel/core@7.22.5) + '@babel/traverse': 7.22.5 '@babel/types': 7.22.5 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/mdx1-csf': 0.0.1(@babel/core@7.22.8) - core-js: 3.31.1 + '@storybook/mdx1-csf': 0.0.1(@babel/core@7.22.5) + core-js: 3.25.0 fs-extra: 9.1.0 global: 4.4.0 regenerator-runtime: 0.13.11 @@ -6734,19 +7786,13 @@ packages: lodash: 4.17.21 dev: true - /@storybook/csf@0.1.1: - resolution: {integrity: sha512-4hE3AlNVxR60Wc5KSC68ASYzUobjPqtSKyhV6G+ge0FIXU55N5nTY7dXGRZHQGDBPq+XqchMkIdlkHPRs8nTHg==} - dependencies: - type-fest: 2.19.0 - dev: true - - /@storybook/docs-tools@6.5.16(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-o+rAWPRGifjBF5xZzTKOqnHN3XQWkl0QFJYVDIiJYJrVll7ExCkpEq/PahOGzIBBV+tpMstJgmKM3lr/lu/jmg==} + /@storybook/docs-tools@6.5.10(react-dom@17.0.2)(react@17.0.2): + resolution: {integrity: sha512-/bvYgOO+CxMEcHifkjJg0A60OTGOhcjGxnsB1h0gJuxMrqA/7Qwc108bFmPiX0eiD1BovFkZLJV4O6OY7zP5Vw==} dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/store': 6.5.16(react-dom@17.0.2)(react@17.0.2) - core-js: 3.31.1 + '@storybook/store': 6.5.10(react-dom@17.0.2)(react@17.0.2) + core-js: 3.25.0 doctrine: 3.0.0 lodash: 4.17.21 regenerator-runtime: 0.13.11 @@ -6756,22 +7802,21 @@ packages: - supports-color dev: true - /@storybook/global@5.0.0: - resolution: {integrity: sha512-FcOqPAXACP0I3oJ/ws6/rrPT9WGhu915Cg8D02a9YxLo0DE9zI+a9A5gRGvmQ09fiWPukqI8ZAEoQEdWUKMQdQ==} - dev: true - - /@storybook/instrumenter@7.0.26: - resolution: {integrity: sha512-7Ty0LTslgkm5RyH6CqTAKhWz/cF6wq/sNdMYKwvVZHWNZ2LKMtXD0RWM2caCPruAGOQ9+52H+3s4TZGKaPSSWQ==} + /@storybook/instrumenter@6.5.10(react-dom@17.0.2)(react@17.0.2): + resolution: {integrity: sha512-3yKJW68wTnGYEts2mJQG6M7ZE+fe54fuy5lBBzRtvWnC15uWTxuaiFp2kxH5b+stSCi4m71ws45RNiEafdBgEQ==} dependencies: - '@storybook/channels': 7.0.26 - '@storybook/client-logger': 7.0.26 - '@storybook/core-events': 7.0.26 - '@storybook/global': 5.0.0 - '@storybook/preview-api': 7.0.26 + '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/client-logger': 6.5.10 + '@storybook/core-events': 6.5.10 + core-js: 3.25.0 + global: 4.4.0 + transitivePeerDependencies: + - react + - react-dom dev: true - /@storybook/manager-webpack4@6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5): - resolution: {integrity: sha512-5VJZwmQU6AgdsBPsYdu886UKBHQ9SJEnFMaeUxKEclXk+iRsmbzlL4GHKyVd6oGX/ZaecZtcHPR6xrzmA4Ziew==} + /@storybook/manager-webpack4@6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4): + resolution: {integrity: sha512-N/TlNDhuhARuFipR/ZJ/xEVESz23iIbCsZ4VNehLHm8PpiGlQUehk+jMjWmz5XV0bJItwjRclY+CU3GjZKblfQ==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 @@ -6780,29 +7825,29 @@ packages: typescript: optional: true dependencies: - '@babel/core': 7.22.8 - '@babel/plugin-transform-template-literals': 7.22.5(@babel/core@7.22.8) - '@babel/preset-react': 7.22.5(@babel/core@7.22.8) - '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/core-client': 6.5.16(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5)(webpack@4.46.0) - '@storybook/core-common': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) - '@storybook/node-logger': 6.5.16 - '@storybook/theming': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/ui': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@types/node': 16.18.38 - '@types/webpack': 4.41.33 - babel-loader: 8.3.0(@babel/core@7.22.8)(webpack@4.46.0) + '@babel/core': 7.22.5 + '@babel/plugin-transform-template-literals': 7.18.9(@babel/core@7.22.5) + '@babel/preset-react': 7.18.6(@babel/core@7.22.5) + '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/core-client': 6.5.10(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4)(webpack@4.46.0) + '@storybook/core-common': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) + '@storybook/node-logger': 6.5.10 + '@storybook/theming': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/ui': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@types/node': 16.11.56 + '@types/webpack': 4.41.32 + babel-loader: 8.2.5(@babel/core@7.22.5)(webpack@4.46.0) case-sensitive-paths-webpack-plugin: 2.4.0 chalk: 4.1.2 - core-js: 3.31.1 + core-js: 3.25.0 css-loader: 3.6.0(webpack@4.46.0) - express: 4.18.2 + express: 4.18.1 file-loader: 6.2.0(webpack@4.46.0) find-up: 5.0.0 fs-extra: 9.1.0 html-webpack-plugin: 4.5.2(webpack@4.46.0) - node-fetch: 2.6.12 - pnp-webpack-plugin: 1.6.4(typescript@4.9.5) + node-fetch: 2.6.11 + pnp-webpack-plugin: 1.6.4(typescript@4.8.4) react: 17.0.2 react-dom: 17.0.2(react@17.0.2) read-pkg-up: 7.0.1 @@ -6812,7 +7857,7 @@ packages: telejson: 6.0.8 terser-webpack-plugin: 4.2.3(webpack@4.46.0) ts-dedent: 2.2.0 - typescript: 4.9.5 + typescript: 4.8.4 url-loader: 4.1.1(file-loader@6.2.0)(webpack@4.46.0) util-deprecate: 1.0.2 webpack: 4.46.0 @@ -6828,17 +7873,36 @@ packages: - webpack-command dev: true - /@storybook/mdx1-csf@0.0.1(@babel/core@7.22.8): + /@storybook/mdx1-csf@0.0.1(@babel/core@7.18.13): + resolution: {integrity: sha512-4biZIWWzoWlCarMZmTpqcJNgo/RBesYZwGFbQeXiGYsswuvfWARZnW9RE9aUEMZ4XPn7B1N3EKkWcdcWe/K2tg==} + dependencies: + '@babel/generator': 7.22.5 + '@babel/parser': 7.22.5 + '@babel/preset-env': 7.18.10(@babel/core@7.18.13) + '@babel/types': 7.22.5 + '@mdx-js/mdx': 1.6.22 + '@types/lodash': 4.14.195 + js-string-escape: 1.0.1 + loader-utils: 2.0.2 + lodash: 4.17.21 + prettier: 2.3.0 + ts-dedent: 2.2.0 + transitivePeerDependencies: + - '@babel/core' + - supports-color + dev: true + + /@storybook/mdx1-csf@0.0.1(@babel/core@7.22.5): resolution: {integrity: sha512-4biZIWWzoWlCarMZmTpqcJNgo/RBesYZwGFbQeXiGYsswuvfWARZnW9RE9aUEMZ4XPn7B1N3EKkWcdcWe/K2tg==} dependencies: - '@babel/generator': 7.22.7 - '@babel/parser': 7.22.7 - '@babel/preset-env': 7.22.7(@babel/core@7.22.8) + '@babel/generator': 7.22.5 + '@babel/parser': 7.22.5 + '@babel/preset-env': 7.18.10(@babel/core@7.22.5) '@babel/types': 7.22.5 '@mdx-js/mdx': 1.6.22 '@types/lodash': 4.14.195 js-string-escape: 1.0.1 - loader-utils: 2.0.4 + loader-utils: 2.0.2 lodash: 4.17.21 prettier: 2.3.0 ts-dedent: 2.2.0 @@ -6847,18 +7911,18 @@ packages: - supports-color dev: true - /@storybook/mdx1-csf@0.0.4(@babel/core@7.22.8)(react@17.0.2): + /@storybook/mdx1-csf@0.0.4(@babel/core@7.18.13)(react@17.0.2): resolution: {integrity: sha512-xxUEMy0D+0G1aSYxbeVNbs+XBU5nCqW4I7awpBYSTywXDv/MJWeC6FDRpj5P1pgfq8j8jWDD5ZDvBQ7syFg0LQ==} dependencies: - '@babel/generator': 7.22.7 - '@babel/parser': 7.22.7 - '@babel/preset-env': 7.22.7(@babel/core@7.22.8) + '@babel/generator': 7.22.5 + '@babel/parser': 7.22.5 + '@babel/preset-env': 7.18.10(@babel/core@7.18.13) '@babel/types': 7.22.5 '@mdx-js/mdx': 1.6.22 '@mdx-js/react': 1.6.22(react@17.0.2) '@types/lodash': 4.14.195 js-string-escape: 1.0.1 - loader-utils: 2.0.4 + loader-utils: 2.0.2 lodash: 4.17.21 prettier: 2.3.0 ts-dedent: 2.2.0 @@ -6868,69 +7932,49 @@ packages: - supports-color dev: true - /@storybook/node-logger@6.5.16: - resolution: {integrity: sha512-YjhBKrclQtjhqFNSO+BZK+RXOx6EQypAELJKoLFaawg331e8VUfvUuRCNB3fcEWp8G9oH13PQQte0OTjLyyOYg==} + /@storybook/node-logger@6.5.10: + resolution: {integrity: sha512-bYswXIKV7Stru8vYfkjUMNN8UhF7Qg7NRsUvG5Djt5lLIae1XmUIgnH40mU/nW4X4BSfcR9MKxsSsngvn2WmQg==} dependencies: '@types/npmlog': 4.1.4 chalk: 4.1.2 - core-js: 3.31.1 + core-js: 3.25.0 npmlog: 5.0.1 pretty-hrtime: 1.0.3 dev: true - /@storybook/postinstall@6.5.16: - resolution: {integrity: sha512-08K2q+qN6pqyPW7PHLCZ5G5Xa6Wosd6t0F16PQ4abX2ItlJLabVoJN5mZ0gm/aeLTjD8QYr8IDvacu4eXh0SVA==} - dependencies: - core-js: 3.31.1 - dev: true - - /@storybook/preview-api@7.0.26: - resolution: {integrity: sha512-uJwA4errBOZOoDF2T7Z2oLqjAYvvjMr31sTsOoT0niJtWr29RQp8yS6VoSrsuh+y3FAVqBEl5pS+DX3IGLjvxw==} + /@storybook/postinstall@6.5.10: + resolution: {integrity: sha512-xqUdpnFHYkn8MgtV+QztvIsRWa6jQUk7QT1Mu17Y0S7PbslNGsuskRPHenHhACXBJF+TM86R+4BaAhnVYTmElw==} dependencies: - '@storybook/channel-postmessage': 7.0.26 - '@storybook/channels': 7.0.26 - '@storybook/client-logger': 7.0.26 - '@storybook/core-events': 7.0.26 - '@storybook/csf': 0.1.1 - '@storybook/global': 5.0.0 - '@storybook/types': 7.0.26 - '@types/qs': 6.9.7 - dequal: 2.0.3 - lodash: 4.17.21 - memoizerific: 1.11.3 - qs: 6.11.2 - synchronous-promise: 2.0.17 - ts-dedent: 2.2.0 - util-deprecate: 1.0.2 + core-js: 3.25.0 dev: true - /@storybook/preview-web@6.5.16(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-IJnvfe2sKCfk7apN9Fu9U8qibbarrPX5JB55ZzK1amSHVmSDuYk5MIMc/U3NnSQNnvd1DO5v/zMcGgj563hrtg==} + /@storybook/preview-web@6.5.10(react-dom@17.0.2)(react@17.0.2): + resolution: {integrity: sha512-sTC/o5gkvALOtcNgtApGKGN9EavvSxRHBeBh+5BQjV2qQ8ap+26RsfUizNBECAa2Jrn4osaDYn9HRhJLFL69WA==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/channel-postmessage': 6.5.16 - '@storybook/client-logger': 6.5.16 - '@storybook/core-events': 6.5.16 + '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/channel-postmessage': 6.5.10 + '@storybook/client-logger': 6.5.10 + '@storybook/core-events': 6.5.10 '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/store': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/store': 6.5.10(react-dom@17.0.2)(react@17.0.2) ansi-to-html: 0.6.15 - core-js: 3.31.1 + core-js: 3.25.0 global: 4.4.0 lodash: 4.17.21 - qs: 6.11.2 + qs: 6.11.0 react: 17.0.2 react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 - synchronous-promise: 2.0.17 + synchronous-promise: 2.0.16 ts-dedent: 2.2.0 unfetch: 4.2.0 util-deprecate: 1.0.2 dev: true - /@storybook/react-docgen-typescript-plugin@1.0.2-canary.6.9d540b91e815f8fc2f8829189deb00553559ff63.0(typescript@4.9.5)(webpack@5.88.1): + /@storybook/react-docgen-typescript-plugin@1.0.2-canary.6.9d540b91e815f8fc2f8829189deb00553559ff63.0(typescript@4.8.4)(webpack@5.74.0): resolution: {integrity: sha512-eVg3BxlOm2P+chijHBTByr90IZVUtgRW56qEOLX7xlww2NBuKrcavBlcmn+HH7GIUktquWkMPtvy6e0W0NgA5w==} peerDependencies: typescript: '>= 3.x' @@ -6941,16 +7985,16 @@ packages: find-cache-dir: 3.3.2 flat-cache: 3.0.4 micromatch: 4.0.5 - react-docgen-typescript: 2.2.2(typescript@4.9.5) - tslib: 2.6.0 - typescript: 4.9.5 - webpack: 5.88.1(esbuild@0.18.11) + react-docgen-typescript: 2.2.2(typescript@4.8.4) + tslib: 2.5.3 + typescript: 4.8.4 + webpack: 5.74.0(esbuild@0.18.11) transitivePeerDependencies: - supports-color dev: true - /@storybook/react@6.5.16(@babel/core@7.22.8)(esbuild@0.18.11)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(require-from-string@2.0.2)(typescript@4.9.5): - resolution: {integrity: sha512-cBtNlOzf/MySpNLBK22lJ8wFU22HnfTB2xJyBk7W7Zi71Lm7Uxkhv1Pz8HdiQndJ0SlsAAQOWjQYsSZsGkZIaA==} + /@storybook/react@6.5.10(@babel/core@7.18.13)(esbuild@0.18.11)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(require-from-string@2.0.2)(typescript@4.8.4): + resolution: {integrity: sha512-m8S1qQrwA7pDGwdKEvL6LV3YKvSzVUY297Fq+xcTU3irnAy4sHDuFoLqV6Mi1510mErK1r8+rf+0R5rEXB219g==} engines: {node: '>=10.13.0'} hasBin: true peerDependencies: @@ -6977,33 +8021,33 @@ packages: typescript: optional: true dependencies: - '@babel/core': 7.22.8 - '@babel/preset-flow': 7.22.5(@babel/core@7.22.8) - '@babel/preset-react': 7.22.5(@babel/core@7.22.8) - '@pmmmwh/react-refresh-webpack-plugin': 0.5.10(react-refresh@0.11.0)(webpack@5.88.1) - '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.16 - '@storybook/core': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5)(webpack@5.88.1) - '@storybook/core-common': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) + '@babel/core': 7.18.13 + '@babel/preset-flow': 7.18.6(@babel/core@7.18.13) + '@babel/preset-react': 7.18.6(@babel/core@7.18.13) + '@pmmmwh/react-refresh-webpack-plugin': 0.5.7(react-refresh@0.11.0)(webpack@5.74.0) + '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/client-logger': 6.5.10 + '@storybook/core': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4)(webpack@5.74.0) + '@storybook/core-common': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) '@storybook/csf': 0.0.2--canary.4566f4d.1 - '@storybook/docs-tools': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/node-logger': 6.5.16 - '@storybook/react-docgen-typescript-plugin': 1.0.2-canary.6.9d540b91e815f8fc2f8829189deb00553559ff63.0(typescript@4.9.5)(webpack@5.88.1) + '@storybook/docs-tools': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/node-logger': 6.5.10 + '@storybook/react-docgen-typescript-plugin': 1.0.2-canary.6.9d540b91e815f8fc2f8829189deb00553559ff63.0(typescript@4.8.4)(webpack@5.74.0) '@storybook/semver': 7.3.2 - '@storybook/store': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/store': 6.5.10(react-dom@17.0.2)(react@17.0.2) '@types/estree': 0.0.51 - '@types/node': 16.18.38 - '@types/webpack-env': 1.18.1 + '@types/node': 16.11.56 + '@types/webpack-env': 1.18.0 acorn: 7.4.1 acorn-jsx: 5.3.2(acorn@7.4.1) acorn-walk: 7.2.0 babel-plugin-add-react-displayname: 0.0.5 babel-plugin-react-docgen: 4.2.1 - core-js: 3.31.1 - escodegen: 2.1.0 + core-js: 3.25.0 + escodegen: 2.0.0 fs-extra: 9.1.0 global: 4.4.0 - html-tags: 3.3.1 + html-tags: 3.2.0 lodash: 4.17.21 prop-types: 15.8.1 react: 17.0.2 @@ -7011,12 +8055,12 @@ packages: react-element-to-jsx-string: 14.3.4(react-dom@17.0.2)(react@17.0.2) react-refresh: 0.11.0 read-pkg-up: 7.0.1 - regenerator-runtime: 0.13.11 + regenerator-runtime: 0.13.9 require-from-string: 2.0.2 ts-dedent: 2.2.0 - typescript: 4.9.5 + typescript: 4.8.4 util-deprecate: 1.0.2 - webpack: 5.88.1(esbuild@0.18.11) + webpack: 5.74.0(esbuild@0.18.11) transitivePeerDependencies: - '@storybook/mdx2-csf' - '@swc/core' @@ -7039,16 +8083,16 @@ packages: - webpack-plugin-serve dev: true - /@storybook/router@6.5.16(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-ZgeP8a5YV/iuKbv31V8DjPxlV4AzorRiR8OuSt/KqaiYXNXlOoQDz/qMmiNcrshrfLpmkzoq7fSo4T8lWo2UwQ==} + /@storybook/router@6.5.10(react-dom@17.0.2)(react@17.0.2): + resolution: {integrity: sha512-O+vNW/eEpYFF8eCg5jZjNQ6q2DKQVxqDRPCy9pJdEbvavMDZn6AFYgVK+VJe5F4211WW2yncOu922xObCxXJYg==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/client-logger': 6.5.16 - core-js: 3.31.1 + '@storybook/client-logger': 6.5.10 + core-js: 3.25.0 memoizerific: 1.11.3 - qs: 6.11.2 + qs: 6.11.0 react: 17.0.2 react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 @@ -7059,23 +8103,23 @@ packages: engines: {node: '>=10'} hasBin: true dependencies: - core-js: 3.31.1 + core-js: 3.25.0 find-up: 4.1.0 dev: true - /@storybook/source-loader@6.5.16(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-fyVl4jrM/5JLrb48aqXPu7sTsmySQaVGFp1zfeqvPPlJRFMastDrePm5XGPN7Qjv1wsKmpuBvuweFKOT1pru3g==} + /@storybook/source-loader@6.5.10(react-dom@17.0.2)(react@17.0.2): + resolution: {integrity: sha512-1RxxRumpjs8VUUwES9LId+cuNQnixhZAcwCxd6jaKkTZbjiQCtAhXX6DBTjJGV1u/JnCsqEp5b1wB8j/EioNHw==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.16 + '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/client-logger': 6.5.10 '@storybook/csf': 0.0.2--canary.4566f4d.1 - core-js: 3.31.1 + core-js: 3.25.0 estraverse: 5.3.0 global: 4.4.0 - loader-utils: 2.0.4 + loader-utils: 2.0.2 lodash: 4.17.21 prettier: 2.3.0 react: 17.0.2 @@ -7083,17 +8127,17 @@ packages: regenerator-runtime: 0.13.11 dev: true - /@storybook/store@6.5.16(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-g+bVL5hmMq/9cM51K04e37OviUPHT0rHHrRm5wj/hrf18Kd9120b3sxdQ5Dc+HZ292yuME0n+cyrQPTYx9Epmw==} + /@storybook/store@6.5.10(react-dom@17.0.2)(react@17.0.2): + resolution: {integrity: sha512-RswrSYh2IiKkytFPxP9AvP+hekjrvHK2ILvyDk2ZgduCN4n5ivsekOb+N3M2t+dq1eLuW9or5n2T4OWwAwjxxQ==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-logger': 6.5.16 - '@storybook/core-events': 6.5.16 + '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/client-logger': 6.5.10 + '@storybook/core-events': 6.5.10 '@storybook/csf': 0.0.2--canary.4566f4d.1 - core-js: 3.31.1 + core-js: 3.25.0 fast-deep-equal: 3.1.3 global: 4.4.0 lodash: 4.17.21 @@ -7103,20 +8147,20 @@ packages: regenerator-runtime: 0.13.11 slash: 3.0.0 stable: 0.1.8 - synchronous-promise: 2.0.17 + synchronous-promise: 2.0.16 ts-dedent: 2.2.0 util-deprecate: 1.0.2 dev: true - /@storybook/telemetry@6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5): - resolution: {integrity: sha512-CWr5Uko1l9jJW88yTXsZTj/3GTabPvw0o7pDPOXPp8JRZiJTxv1JFaFCafhK9UzYbgcRuGfCC8kEWPZims7iKA==} + /@storybook/telemetry@6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4): + resolution: {integrity: sha512-+M5HILDFS8nDumLxeSeAwi1MTzIuV6UWzV4yB2wcsEXOBTdplcl9oYqFKtlst78oOIdGtpPYxYfivDlqxC2K4g==} dependencies: - '@storybook/client-logger': 6.5.16 - '@storybook/core-common': 6.5.16(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.9.5) + '@storybook/client-logger': 6.5.10 + '@storybook/core-common': 6.5.10(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(typescript@4.8.4) chalk: 4.1.2 - core-js: 3.31.1 + core-js: 3.25.0 detect-package-manager: 2.0.1 - fetch-retry: 5.0.6 + fetch-retry: 5.0.3 fs-extra: 9.1.0 global: 4.4.0 isomorphic-unfetch: 3.1.0 @@ -7135,17 +8179,20 @@ packages: - webpack-command dev: true - /@storybook/testing-library@0.0.11: + /@storybook/testing-library@0.0.11(react-dom@17.0.2)(react@17.0.2): resolution: {integrity: sha512-8KbKx3s1e+uF3oWlPdyXRpZa6xtCsCHtXh1nCTisMA6P5YcSDaCg59NXIOVIQCAwKvjRomlqMJH8JL1WyOzeVg==} dependencies: - '@storybook/client-logger': 7.0.26 - '@storybook/instrumenter': 7.0.26 - '@testing-library/dom': 8.20.1 - '@testing-library/user-event': 13.5.0(@testing-library/dom@8.20.1) + '@storybook/client-logger': 6.5.10 + '@storybook/instrumenter': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@testing-library/dom': 8.17.1 + '@testing-library/user-event': 13.5.0(@testing-library/dom@8.17.1) ts-dedent: 2.2.0 + transitivePeerDependencies: + - react + - react-dom dev: true - /@storybook/testing-react@1.3.0(@storybook/addons@6.5.16)(@storybook/client-api@6.5.16)(@storybook/preview-web@6.5.16)(@storybook/react@6.5.16)(react@17.0.2): + /@storybook/testing-react@1.3.0(@storybook/addons@6.5.10)(@storybook/client-api@6.5.10)(@storybook/preview-web@6.5.10)(@storybook/react@6.5.10)(react@17.0.2): resolution: {integrity: sha512-TfxzflxwBHSPhetWKuYt239t+1iN8gnnUN8OKo5UGtwwirghKQlApjH23QXW6j8YBqFhmq+yP29Oqf8HgKCFLw==} engines: {node: '>=10'} peerDependencies: @@ -7155,55 +8202,46 @@ packages: '@storybook/react': '>=6.4.0' react: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/client-api': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/client-api': 6.5.10(react-dom@17.0.2)(react@17.0.2) '@storybook/csf': 0.0.2--canary.87bc651.0 - '@storybook/preview-web': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/react': 6.5.16(@babel/core@7.22.8)(esbuild@0.18.11)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(require-from-string@2.0.2)(typescript@4.9.5) + '@storybook/preview-web': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/react': 6.5.10(@babel/core@7.18.13)(esbuild@0.18.11)(eslint@8.4.1)(react-dom@17.0.2)(react@17.0.2)(require-from-string@2.0.2)(typescript@4.8.4) react: 17.0.2 dev: true - /@storybook/theming@6.5.16(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-hNLctkjaYLRdk1+xYTkC1mg4dYz2wSv6SqbLpcKMbkPHTE0ElhddGPHQqB362md/w9emYXNkt1LSMD8Xk9JzVQ==} + /@storybook/theming@6.5.10(react-dom@17.0.2)(react@17.0.2): + resolution: {integrity: sha512-BvTQBBcSEwKKcsVmF+Ol6v0RIQUr+bxP7gb10wtfBd23mZTEFA0C1N5FnZr/dDeiBKG1pvf1UKvoYA731y0BsA==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/client-logger': 6.5.16 - core-js: 3.31.1 + '@storybook/client-logger': 6.5.10 + core-js: 3.25.0 memoizerific: 1.11.3 react: 17.0.2 react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 dev: true - /@storybook/types@7.0.26: - resolution: {integrity: sha512-5RBi6agtDglNXdffmw4+Fyv2dUdlIdeOdUj0O5+JRYajTxfHdurZd9r/42z4OstN+ORDkLA/svt8Q9JyRpIb6Q==} - dependencies: - '@storybook/channels': 7.0.26 - '@types/babel__core': 7.20.1 - '@types/express': 4.17.17 - file-system-cache: 2.3.0 - dev: true - - /@storybook/ui@6.5.16(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-rHn/n12WM8BaXtZ3IApNZCiS+C4Oc5+Lkl4MoctX8V7QSml0SxZBB5hsJ/AiWkgbRxjQpa/L/Nt7/Qw0FjTH/A==} + /@storybook/ui@6.5.10(react-dom@17.0.2)(react@17.0.2): + resolution: {integrity: sha512-6iaoaRAiTqB1inTw35vao+5hjcDE0Qa0A3a9ZIeNa6yHvpB1k0lO/N/0PMrRdVvySYpXVD1iry4z4QYdo1rU+w==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.8.0 || ^17.0.0 || ^18.0.0 dependencies: - '@storybook/addons': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/api': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/channels': 6.5.16 - '@storybook/client-logger': 6.5.16 - '@storybook/components': 6.5.16(react-dom@17.0.2)(react@17.0.2) - '@storybook/core-events': 6.5.16 - '@storybook/router': 6.5.16(react-dom@17.0.2)(react@17.0.2) + '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/api': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/channels': 6.5.10 + '@storybook/client-logger': 6.5.10 + '@storybook/components': 6.5.10(react-dom@17.0.2)(react@17.0.2) + '@storybook/core-events': 6.5.10 + '@storybook/router': 6.5.10(react-dom@17.0.2)(react@17.0.2) '@storybook/semver': 7.3.2 - '@storybook/theming': 6.5.16(react-dom@17.0.2)(react@17.0.2) - core-js: 3.31.1 + '@storybook/theming': 6.5.10(react-dom@17.0.2)(react@17.0.2) + core-js: 3.25.0 memoizerific: 1.11.3 - qs: 6.11.2 + qs: 6.11.0 react: 17.0.2 react-dom: 17.0.2(react@17.0.2) regenerator-runtime: 0.13.11 @@ -7213,23 +8251,23 @@ packages: /@surma/rollup-plugin-off-main-thread@2.2.3: resolution: {integrity: sha512-lR8q/9W7hZpMWweNiAKU7NQerBnzQQLvi8qnTDU/fxItPhtZVMbPV3lbCwjhIlNBe9Bbr5V+KHshvWmVSG9cxQ==} dependencies: - ejs: 3.1.9 + ejs: 3.1.8 json5: 2.2.3 magic-string: 0.25.9 - string.prototype.matchall: 4.0.8 + string.prototype.matchall: 4.0.7 dev: true - /@sveltejs/adapter-auto@2.1.0(@sveltejs/kit@1.22.2): + /@sveltejs/adapter-auto@2.1.0(@sveltejs/kit@1.20.2): resolution: {integrity: sha512-o2pZCfATFtA/Gw/BB0Xm7k4EYaekXxaPGER3xGSY3FvzFJGTlJlZjBseaXwYSM94lZ0HniOjTokN3cWaLX6fow==} peerDependencies: '@sveltejs/kit': ^1.0.0 dependencies: - '@sveltejs/kit': 1.22.2(svelte@3.59.2)(vite@4.4.3) + '@sveltejs/kit': 1.20.2(svelte@3.59.1)(vite@4.3.9) import-meta-resolve: 3.0.0 dev: true - /@sveltejs/kit@1.22.2(svelte@3.59.2)(vite@4.4.3): - resolution: {integrity: sha512-T6GY5jSfQgoDnNPNqAuDi9IK+ZW0TspzTV16UAN6GTsxbri67DGVIbw7QOXPg8FMrZQMmda1AtAxPMfXbOqCgw==} + /@sveltejs/kit@1.20.2(svelte@3.59.1)(vite@4.3.9): + resolution: {integrity: sha512-MtR1i+HtmYWcRgtubw1GQqT/+CWXL/z24PegE0xYAdObbhdr7YtEfmoe705D/JZMtMmoPXrmSk4W0MfL5A3lYw==} engines: {node: ^16.14 || >=18} hasBin: true requiresBuild: true @@ -7237,25 +8275,26 @@ packages: svelte: ^3.54.0 || ^4.0.0-next.0 vite: ^4.0.0 dependencies: - '@sveltejs/vite-plugin-svelte': 2.4.2(svelte@3.59.2)(vite@4.4.3) + '@sveltejs/vite-plugin-svelte': 2.4.2(svelte@3.59.1)(vite@4.3.9) '@types/cookie': 0.5.1 cookie: 0.5.0 devalue: 4.3.2 esm-env: 1.0.0 kleur: 4.1.5 - magic-string: 0.30.1 + magic-string: 0.30.0 mime: 3.0.0 sade: 1.8.1 set-cookie-parser: 2.6.0 sirv: 2.0.3 - svelte: 3.59.2 + svelte: 3.59.1 + tiny-glob: 0.2.9 undici: 5.22.1 - vite: 4.4.3(@types/node@18.16.19) + vite: 4.3.9(@types/node@18.16.19) transitivePeerDependencies: - supports-color dev: true - /@sveltejs/vite-plugin-svelte-inspector@1.0.3(@sveltejs/vite-plugin-svelte@2.4.2)(svelte@3.59.2)(vite@4.4.3): + /@sveltejs/vite-plugin-svelte-inspector@1.0.3(@sveltejs/vite-plugin-svelte@2.4.2)(svelte@3.59.1)(vite@4.3.9): resolution: {integrity: sha512-Khdl5jmmPN6SUsVuqSXatKpQTMIifoQPDanaxC84m9JxIibWvSABJyHpyys0Z+1yYrxY5TTEQm+6elh0XCMaOA==} engines: {node: ^14.18.0 || >= 16} peerDependencies: @@ -7263,15 +8302,15 @@ packages: svelte: ^3.54.0 || ^4.0.0 vite: ^4.0.0 dependencies: - '@sveltejs/vite-plugin-svelte': 2.4.2(svelte@3.59.2)(vite@4.4.3) + '@sveltejs/vite-plugin-svelte': 2.4.2(svelte@3.59.1)(vite@4.3.9) debug: 4.3.4(supports-color@8.1.1) - svelte: 3.59.2 - vite: 4.4.3(@types/node@18.16.19) + svelte: 3.59.1 + vite: 4.3.9(@types/node@18.16.19) transitivePeerDependencies: - supports-color dev: true - /@sveltejs/vite-plugin-svelte-inspector@1.0.3(@sveltejs/vite-plugin-svelte@2.4.2)(svelte@4.0.5)(vite@4.4.3): + /@sveltejs/vite-plugin-svelte-inspector@1.0.3(@sveltejs/vite-plugin-svelte@2.4.2)(svelte@4.0.5)(vite@4.3.9): resolution: {integrity: sha512-Khdl5jmmPN6SUsVuqSXatKpQTMIifoQPDanaxC84m9JxIibWvSABJyHpyys0Z+1yYrxY5TTEQm+6elh0XCMaOA==} engines: {node: ^14.18.0 || >= 16} peerDependencies: @@ -7279,50 +8318,50 @@ packages: svelte: ^3.54.0 || ^4.0.0 vite: ^4.0.0 dependencies: - '@sveltejs/vite-plugin-svelte': 2.4.2(svelte@4.0.5)(vite@4.4.3) + '@sveltejs/vite-plugin-svelte': 2.4.2(svelte@4.0.5)(vite@4.3.9) debug: 4.3.4(supports-color@8.1.1) svelte: 4.0.5 - vite: 4.4.3(@types/node@18.16.19) + vite: 4.3.9(@types/node@18.16.19) transitivePeerDependencies: - supports-color dev: true - /@sveltejs/vite-plugin-svelte@2.4.2(svelte@3.59.2)(vite@4.4.3): + /@sveltejs/vite-plugin-svelte@2.4.2(svelte@3.59.1)(vite@4.3.9): resolution: {integrity: sha512-ePfcC48ftMKhkT0OFGdOyycYKnnkT6i/buzey+vHRTR/JpQvuPzzhf1PtKqCDQfJRgoPSN2vscXs6gLigx/zGw==} engines: {node: ^14.18.0 || >= 16} peerDependencies: svelte: ^3.54.0 || ^4.0.0 vite: ^4.0.0 dependencies: - '@sveltejs/vite-plugin-svelte-inspector': 1.0.3(@sveltejs/vite-plugin-svelte@2.4.2)(svelte@3.59.2)(vite@4.4.3) + '@sveltejs/vite-plugin-svelte-inspector': 1.0.3(@sveltejs/vite-plugin-svelte@2.4.2)(svelte@3.59.1)(vite@4.3.9) debug: 4.3.4(supports-color@8.1.1) deepmerge: 4.3.1 kleur: 4.1.5 magic-string: 0.30.1 - svelte: 3.59.2 - svelte-hmr: 0.15.2(svelte@3.59.2) - vite: 4.4.3(@types/node@18.16.19) - vitefu: 0.2.4(vite@4.4.3) + svelte: 3.59.1 + svelte-hmr: 0.15.2(svelte@3.59.1) + vite: 4.3.9(@types/node@18.16.19) + vitefu: 0.2.4(vite@4.3.9) transitivePeerDependencies: - supports-color dev: true - /@sveltejs/vite-plugin-svelte@2.4.2(svelte@4.0.5)(vite@4.4.3): + /@sveltejs/vite-plugin-svelte@2.4.2(svelte@4.0.5)(vite@4.3.9): resolution: {integrity: sha512-ePfcC48ftMKhkT0OFGdOyycYKnnkT6i/buzey+vHRTR/JpQvuPzzhf1PtKqCDQfJRgoPSN2vscXs6gLigx/zGw==} engines: {node: ^14.18.0 || >= 16} peerDependencies: svelte: ^3.54.0 || ^4.0.0 vite: ^4.0.0 dependencies: - '@sveltejs/vite-plugin-svelte-inspector': 1.0.3(@sveltejs/vite-plugin-svelte@2.4.2)(svelte@4.0.5)(vite@4.4.3) + '@sveltejs/vite-plugin-svelte-inspector': 1.0.3(@sveltejs/vite-plugin-svelte@2.4.2)(svelte@4.0.5)(vite@4.3.9) debug: 4.3.4(supports-color@8.1.1) deepmerge: 4.3.1 kleur: 4.1.5 magic-string: 0.30.1 svelte: 4.0.5 svelte-hmr: 0.15.2(svelte@4.0.5) - vite: 4.4.3(@types/node@18.16.19) - vitefu: 0.2.4(vite@4.4.3) + vite: 4.3.9(@types/node@18.16.19) + vitefu: 0.2.4(vite@4.3.9) transitivePeerDependencies: - supports-color dev: true @@ -7334,27 +8373,41 @@ packages: defer-to-connect: 2.0.1 dev: true - /@testing-library/cypress@9.0.0(cypress@12.17.1): + /@testing-library/cypress@9.0.0(cypress@12.16.0): resolution: {integrity: sha512-c1XiCGeHGGTWn0LAU12sFUfoX3qfId5gcSE2yHode+vsyHDWraxDPALjVnHd4/Fa3j4KBcc5k++Ccy6A9qnkMA==} engines: {node: '>=12', npm: '>=6'} peerDependencies: cypress: ^12.0.0 dependencies: - '@babel/runtime': 7.22.6 - '@testing-library/dom': 8.20.1 - cypress: 12.17.1 + '@babel/runtime': 7.18.9 + '@testing-library/dom': 8.19.0 + cypress: 12.16.0 dev: true - /@testing-library/dom@8.20.1: - resolution: {integrity: sha512-/DiOQ5xBxgdYRC8LNk7U+RWat0S3qRLeIw3ZIkMQ9kkVlRmwD/Eg8k8CqIpD6GW7u20JIUOfMKbxtiLutpjQ4g==} + /@testing-library/dom@8.17.1: + resolution: {integrity: sha512-KnH2MnJUzmFNPW6RIKfd+zf2Wue8mEKX0M3cpX6aKl5ZXrJM1/c/Pc8c2xDNYQCnJO48Sm5ITbMXgqTr3h4jxQ==} engines: {node: '>=12'} dependencies: '@babel/code-frame': 7.22.5 - '@babel/runtime': 7.22.6 - '@types/aria-query': 5.0.1 - aria-query: 5.1.3 + '@babel/runtime': 7.18.9 + '@types/aria-query': 4.2.2 + aria-query: 5.3.0 + chalk: 4.1.2 + dom-accessibility-api: 0.5.14 + lz-string: 1.4.4 + pretty-format: 27.5.1 + dev: true + + /@testing-library/dom@8.19.0: + resolution: {integrity: sha512-6YWYPPpxG3e/xOo6HIWwB/58HukkwIVTOaZ0VwdMVjhRUX/01E4FtQbck9GazOOj7MXHc5RBzMrU86iBJHbI+A==} + engines: {node: '>=12'} + dependencies: + '@babel/code-frame': 7.22.5 + '@babel/runtime': 7.18.9 + '@types/aria-query': 4.2.2 + aria-query: 5.3.0 chalk: 4.1.2 - dom-accessibility-api: 0.5.16 + dom-accessibility-api: 0.5.14 lz-string: 1.5.0 pretty-format: 27.5.1 dev: true @@ -7364,11 +8417,11 @@ packages: engines: {node: '>=14'} dependencies: '@babel/code-frame': 7.22.5 - '@babel/runtime': 7.22.6 + '@babel/runtime': 7.18.9 '@types/aria-query': 5.0.1 aria-query: 5.1.3 chalk: 4.1.2 - dom-accessibility-api: 0.5.16 + dom-accessibility-api: 0.5.14 lz-string: 1.5.0 pretty-format: 27.5.1 dev: true @@ -7377,13 +8430,13 @@ packages: resolution: {integrity: sha512-N5ixQ2qKpi5OLYfwQmUb/5mSV9LneAcaUfp32pn4yCnpb8r/Yz0pXFPck21dIicKmi+ta5WRAknkZCfA8refMA==} engines: {node: '>=8', npm: '>=6', yarn: '>=1'} dependencies: - '@adobe/css-tools': 4.2.0 - '@babel/runtime': 7.22.6 - '@types/testing-library__jest-dom': 5.14.8 - aria-query: 5.3.0 + '@adobe/css-tools': 4.0.1 + '@babel/runtime': 7.18.9 + '@types/testing-library__jest-dom': 5.14.5 + aria-query: 5.0.2 chalk: 3.0.0 css.escape: 1.5.1 - dom-accessibility-api: 0.5.16 + dom-accessibility-api: 0.5.14 lodash: 4.17.21 redent: 3.0.0 dev: true @@ -7395,27 +8448,41 @@ packages: react: <18.0.0 react-dom: <18.0.0 dependencies: - '@babel/runtime': 7.22.6 - '@testing-library/dom': 8.20.1 - '@types/react-dom': 17.0.20 + '@babel/runtime': 7.18.9 + '@testing-library/dom': 8.17.1 + '@types/react-dom': 17.0.17 react: 17.0.2 react-dom: 17.0.2(react@17.0.2) dev: true - /@testing-library/react@13.4.0(react-dom@18.0.0)(react@18.0.0): - resolution: {integrity: sha512-sXOGON+WNTh3MLE9rve97ftaZukN3oNf2KjDy7YTx6hcTO2uuLHuCGynMDhFwGw/jYf4OJ2Qk0i4i79qMNNkyw==} + /@testing-library/react@13.3.0(react-dom@18.0.0)(react@18.0.0): + resolution: {integrity: sha512-DB79aA426+deFgGSjnf5grczDPiL4taK3hFaa+M5q7q20Kcve9eQottOG5kZ74KEr55v0tU2CQormSSDK87zYQ==} engines: {node: '>=12'} peerDependencies: react: ^18.0.0 react-dom: ^18.0.0 dependencies: - '@babel/runtime': 7.22.6 - '@testing-library/dom': 8.20.1 - '@types/react-dom': 18.2.6 + '@babel/runtime': 7.18.9 + '@testing-library/dom': 8.17.1 + '@types/react-dom': 18.0.6 react: 18.0.0 react-dom: 18.0.0(react@18.0.0) dev: true + /@testing-library/react@13.3.0(react-dom@18.2.0)(react@18.2.0): + resolution: {integrity: sha512-DB79aA426+deFgGSjnf5grczDPiL4taK3hFaa+M5q7q20Kcve9eQottOG5kZ74KEr55v0tU2CQormSSDK87zYQ==} + engines: {node: '>=12'} + peerDependencies: + react: ^18.0.0 + react-dom: ^18.0.0 + dependencies: + '@babel/runtime': 7.18.9 + '@testing-library/dom': 8.17.1 + '@types/react-dom': 18.0.6 + react: 18.2.0 + react-dom: 18.2.0(react@18.2.0) + dev: true + /@testing-library/react@13.4.0(react-dom@18.2.0)(react@18.2.0): resolution: {integrity: sha512-sXOGON+WNTh3MLE9rve97ftaZukN3oNf2KjDy7YTx6hcTO2uuLHuCGynMDhFwGw/jYf4OJ2Qk0i4i79qMNNkyw==} engines: {node: '>=12'} @@ -7423,9 +8490,9 @@ packages: react: ^18.0.0 react-dom: ^18.0.0 dependencies: - '@babel/runtime': 7.22.6 - '@testing-library/dom': 8.20.1 - '@types/react-dom': 18.2.6 + '@babel/runtime': 7.18.9 + '@testing-library/dom': 8.17.1 + '@types/react-dom': 18.0.8 react: 18.2.0 react-dom: 18.2.0(react@18.2.0) dev: true @@ -7440,14 +8507,14 @@ packages: svelte: 4.0.5 dev: true - /@testing-library/user-event@13.5.0(@testing-library/dom@8.20.1): + /@testing-library/user-event@13.5.0(@testing-library/dom@8.17.1): resolution: {integrity: sha512-5Kwtbo3Y/NowpkbRuSepbyMFkZmHgD+vPzYB/RJ4oxt5Gj/avFFBYjhw27cqSVPVw/3a67NK1PbiIr9k4Gwmdg==} engines: {node: '>=10', npm: '>=6'} peerDependencies: '@testing-library/dom': '>=7.21.4' dependencies: - '@babel/runtime': 7.22.6 - '@testing-library/dom': 8.20.1 + '@babel/runtime': 7.18.9 + '@testing-library/dom': 8.17.1 dev: true /@testing-library/user-event@13.5.0(@testing-library/dom@9.3.1): @@ -7456,7 +8523,7 @@ packages: peerDependencies: '@testing-library/dom': '>=7.21.4' dependencies: - '@babel/runtime': 7.22.6 + '@babel/runtime': 7.18.9 '@testing-library/dom': 9.3.1 dev: true @@ -7491,8 +8558,12 @@ packages: resolution: {integrity: sha512-ysT8mhdixWK6Hw3i1V2AeRqZ5WfXg1G43mqoYlM2nc6388Fq5jcXyr5mRsqViLx/GJYdoL0bfXD8nmF+Zn/Iow==} dev: true - /@tsconfig/node16@1.0.4: - resolution: {integrity: sha512-vxhUy4J8lyeyinH7Azl1pdd43GJhZH/tP2weN8TntQblOY+A0XbT8DJk1/oCPuOOyg/Ja757rG0CgHcWC8OfMA==} + /@tsconfig/node16@1.0.3: + resolution: {integrity: sha512-yOlFc+7UtL/89t2ZhjPvvB/DeAr3r+Dq58IgzsFkOAvVC6NMJXmCGjbptdXdR9qsX7pKcTL+s87FtYREi2dEEQ==} + dev: true + + /@types/aria-query@4.2.2: + resolution: {integrity: sha512-HnYpAE1Y6kRyKM/XkEuiRQhTHvkzMBurTHnpFLYLBGPIylZNPs9jJcuOOYWxPLJCSEtmZT0Y8rHDokKN7rRTig==} dev: true /@types/aria-query@5.0.1: @@ -7503,14 +8574,14 @@ packages: resolution: {integrity: sha512-pkPtJUUY+Vwv6B1inAz55rQvivClHJxc9aVEPPmaq2cbyeMLCiDpbKpcKyX4LAwpNGi+SHBv0tHv6+0gXv0P2A==} dev: true - /@types/babel__core@7.20.1: - resolution: {integrity: sha512-aACu/U/omhdk15O4Nfb+fHgH/z3QsfQzpnvRZhYhThms83ZnAOZz7zZAWO7mn2yyNQaA4xTO8GLK3uqFU4bYYw==} + /@types/babel__core@7.20.0: + resolution: {integrity: sha512-+n8dL/9GWblDO0iU6eZAwEIJVr5DWigtle+Q6HLOrh/pdbXOhOtqzq8VPPE2zvNJzSKY4vH/z3iT3tn0A3ypiQ==} dependencies: - '@babel/parser': 7.22.7 + '@babel/parser': 7.22.5 '@babel/types': 7.22.5 '@types/babel__generator': 7.6.4 '@types/babel__template': 7.4.1 - '@types/babel__traverse': 7.20.1 + '@types/babel__traverse': 7.18.3 dev: true /@types/babel__generator@7.6.4: @@ -7522,25 +8593,18 @@ packages: /@types/babel__template@7.4.1: resolution: {integrity: sha512-azBFKemX6kMg5Io+/rdGT0dkGreboUVR0Cdm3fz9QJWpaQGJRQXl7C+6hOTCZcMll7KFyEQpgbYI2lHdsS4U7g==} dependencies: - '@babel/parser': 7.22.7 + '@babel/parser': 7.22.5 '@babel/types': 7.22.5 dev: true - /@types/babel__traverse@7.20.1: - resolution: {integrity: sha512-MitHFXnhtgwsGZWtT68URpOvLN4EREih1u3QtQiN4VdAxWKRVvGCSvw/Qth0M0Qq3pJpnGOu5JaM/ydK7OGbqg==} + /@types/babel__traverse@7.18.3: + resolution: {integrity: sha512-1kbcJ40lLB7MHsj39U4Sh1uTd2E7rLEa79kmDpI6cy+XiXsteB3POdQomoq4FxszMrO3ZYchkhYJw7A2862b3w==} dependencies: '@babel/types': 7.22.5 dev: true - /@types/body-parser@1.19.2: - resolution: {integrity: sha512-ALYone6pm6QmwZoAgeyNksccT9Q4AWZQ6PvfwR37GT6r6FWUPguq6sUmNGSMV2Wr761oQoBxwGGa6DR5o1DC9g==} - dependencies: - '@types/connect': 3.4.35 - '@types/node': 20.4.1 - dev: true - - /@types/braces@3.0.2: - resolution: {integrity: sha512-U5tlMYa0U/2eFTmJgKcPWQOEICP173sJDa6OjHbj5Tv+NVaYcrq2xmdWpNXOwWYGwJu+jER/pfTLdoQ31q8PzA==} + /@types/braces@3.0.1: + resolution: {integrity: sha512-+euflG6ygo4bn0JHtn4pYqcXwRtLvElQ7/nnjDu7iYG56H0+OhCd7d6Ug0IE3WcFpZozBKW2+80FUbv5QGk5AQ==} dev: true /@types/chai-subset@1.3.3: @@ -7565,12 +8629,6 @@ packages: '@types/tern': 0.23.4 dev: true - /@types/connect@3.4.35: - resolution: {integrity: sha512-cdeYyv4KWoEgpBISTxWvqYsVy444DOqehiF3fM3ne10AmJ62RSyNkUnxMJXHQWRQQX2eR94m5y1IZyDwBjV9FQ==} - dependencies: - '@types/node': 20.4.1 - dev: true - /@types/cookie@0.4.1: resolution: {integrity: sha512-XW/Aa8APYr6jSVVA1y/DEIZX0/GMKLEVekNG727R8cs56ahETkRAy/3DR7+fJyh7oUgGwNQaRfXCun0+KbWY7Q==} dev: true @@ -7579,56 +8637,14 @@ packages: resolution: {integrity: sha512-COUnqfB2+ckwXXSFInsFdOAWQzCCx+a5hq2ruyj+Vjund94RJQd4LG2u9hnvJrTgunKAaax7ancBYlDrNYxA0g==} dev: true - /@types/d3-array@3.0.5: - resolution: {integrity: sha512-Qk7fpJ6qFp+26VeQ47WY0mkwXaiq8+76RJcncDEfMc2ocRzXLO67bLFRNI4OX1aGBoPzsM5Y2T+/m1pldOgD+A==} - dev: false - - /@types/d3-color@3.1.0: - resolution: {integrity: sha512-HKuicPHJuvPgCD+np6Se9MQvS6OCbJmOjGvylzMJRlDwUXjKTTXs6Pwgk79O09Vj/ho3u1ofXnhFOaEWWPrlwA==} - dev: false - - /@types/d3-ease@3.0.0: - resolution: {integrity: sha512-aMo4eaAOijJjA6uU+GIeW018dvy9+oH5Y2VPPzjjfxevvGQ/oRDs+tfYC9b50Q4BygRR8yE2QCLsrT0WtAVseA==} - dev: false - /@types/d3-force@3.0.4: resolution: {integrity: sha512-q7xbVLrWcXvSBBEoadowIUJ7sRpS1yvgMWnzHJggFy5cUZBq2HZL5k/pBSm0GdYWS1vs5/EDwMjSKF55PDY4Aw==} dev: true - /@types/d3-interpolate@3.0.1: - resolution: {integrity: sha512-jx5leotSeac3jr0RePOH1KdR9rISG91QIE4Q2PYTu4OymLTZfA3SrnURSLzKH48HmXVUru50b8nje4E79oQSQw==} - dependencies: - '@types/d3-color': 3.1.0 - dev: false - - /@types/d3-path@3.0.0: - resolution: {integrity: sha512-0g/A+mZXgFkQxN3HniRDbXMN79K3CdTpLsevj+PXiTcb2hVyvkZUBg37StmgCQkaD84cUJ4uaDAWq7UJOQy2Tg==} - dev: false - - /@types/d3-scale@4.0.3: - resolution: {integrity: sha512-PATBiMCpvHJSMtZAMEhc2WyL+hnzarKzI6wAHYjhsonjWJYGq5BXTzQjv4l8m2jO183/4wZ90rKvSeT7o72xNQ==} - dependencies: - '@types/d3-time': 3.0.0 - dev: false - /@types/d3-selection@3.0.5: resolution: {integrity: sha512-xCB0z3Hi8eFIqyja3vW8iV01+OHGYR2di/+e+AiOcXIOrY82lcvWW8Ke1DYE/EUVMsBl4Db9RppSBS3X1U6J0w==} dev: true - /@types/d3-shape@3.1.1: - resolution: {integrity: sha512-6Uh86YFF7LGg4PQkuO2oG6EMBRLuW9cbavUW46zkIO5kuS2PfTqo2o9SkgtQzguBHbLgNnU90UNsITpsX1My+A==} - dependencies: - '@types/d3-path': 3.0.0 - dev: false - - /@types/d3-time@3.0.0: - resolution: {integrity: sha512-sZLCdHvBUcNby1cB6Fd3ZBrABbjz3v1Vm90nysCQ6Vt7vd6e/h9Lt7SiJUoEX0l4Dzc7P5llKyhqSi1ycSf1Hg==} - dev: false - - /@types/d3-timer@3.0.0: - resolution: {integrity: sha512-HNB/9GHqu7Fo8AQiugyJbv6ZxYz58wef0esl4Mv828w1ZKpAshw/uFWVDUcIB9KKFeFKoxS3cHY07FFgtTRZ1g==} - dev: false - /@types/debug@4.1.8: resolution: {integrity: sha512-/vPO1EPOs306Cvhwv7KfVfYvOJqA/S/AXjaHQiJboCZzcNDb+TIJFN9/2C9DZ//ijSKWioNyUxD792QmDJ+HKQ==} dependencies: @@ -7639,29 +8655,25 @@ packages: resolution: {integrity: sha512-amrLbRqTU9bXMCc6uX0sWpxsQzRIo9z6MJPkH1pkez/qOxuqSZVuryJAWoBRq94CeG8JxY+VK4Le9HtjQR5T9A==} dev: true - /@types/doctrine@0.0.5: - resolution: {integrity: sha512-JJwEeFy8Sl9ctiugU4h4DGN9hCB47oyhUkM2H8g8xZr4tHTEXtmV4U6krKrU8Ng0S7RlG/J7fkta1rGu3pq+YQ==} - dev: true - - /@types/enzyme@3.10.13: - resolution: {integrity: sha512-FCtoUhmFsud0Yx9fmZk179GkdZ4U9B0GFte64/Md+W/agx0L5SxsIIbhLBOxIb9y2UfBA4WQnaG1Od/UsUQs9Q==} + /@types/enzyme@3.10.12: + resolution: {integrity: sha512-xryQlOEIe1TduDWAOphR0ihfebKFSWOXpIsk+70JskCfRfW+xALdnJ0r1ZOTo85F9Qsjk6vtlU7edTYHbls9tA==} dependencies: '@types/cheerio': 0.22.31 - '@types/react': 16.14.43 + '@types/react': 18.2.14 dev: true /@types/eslint-scope@3.7.4: resolution: {integrity: sha512-9K4zoImiZc3HlIp6AVUDE4CWYx22a+lhSZMYNpbjW04+YF0KWj4pJXnEMjdnFTiQibFFmElcsasJXDbdI/EPhA==} dependencies: - '@types/eslint': 8.44.0 + '@types/eslint': 8.4.6 '@types/estree': 1.0.1 dev: true - /@types/eslint@8.44.0: - resolution: {integrity: sha512-gsF+c/0XOguWgaOgvFs+xnnRqt9GwgTvIks36WpE6ueeI4KCEHHd8K/CKHqhOqrJKsYH8m27kRzQEvWXAwXUTw==} + /@types/eslint@8.4.6: + resolution: {integrity: sha512-/fqTbjxyFUaYNO7VcW5g+4npmqVACz1bB7RTHYuLj+PRjw9hrCwrUXVQFpChUS0JsyEFvMZ7U/PfmvWgxJhI9g==} dependencies: '@types/estree': 1.0.1 - '@types/json-schema': 7.0.12 + '@types/json-schema': 7.0.11 dev: true /@types/estree@0.0.39: @@ -7674,24 +8686,6 @@ packages: /@types/estree@1.0.1: resolution: {integrity: sha512-LG4opVs2ANWZ1TJoKc937iMmNstM/d0ae1vNbnBvBhqCSezgVUOzcLCqbI5elV8Vy6WKwKjaqR+zO9VKirBBCA==} - /@types/express-serve-static-core@4.17.35: - resolution: {integrity: sha512-wALWQwrgiB2AWTT91CB62b6Yt0sNHpznUXeZEcnPU3DRdlDIz74x8Qg1UUYKSVFi+va5vKOLYRBI1bRKiLLKIg==} - dependencies: - '@types/node': 20.4.1 - '@types/qs': 6.9.7 - '@types/range-parser': 1.2.4 - '@types/send': 0.17.1 - dev: true - - /@types/express@4.17.17: - resolution: {integrity: sha512-Q4FmmuLGBG58btUnfS1c1r/NQdlp3DMfGDGig8WhfpA2YRUtEkxAjkZb0yvplJGYdF1fsQ81iMDcH24sSCNC/Q==} - dependencies: - '@types/body-parser': 1.19.2 - '@types/express-serve-static-core': 4.17.35 - '@types/qs': 6.9.7 - '@types/serve-static': 1.15.2 - dev: true - /@types/fs-extra@11.0.1: resolution: {integrity: sha512-MxObHvNl4A69ofaTRU8DFqvgzzv8s9yRtaPPm5gud9HDNvpB3GPQFvNuTWAI59B9huVGV5jXYJwbCsmBsOGYWA==} dependencies: @@ -7708,27 +8702,27 @@ packages: /@types/glob@7.2.0: resolution: {integrity: sha512-ZUxbzKl0IfJILTS6t7ip5fQQM/J3TJYubDm3nMbgubNNYS62eXeUpoLUC8/7fJNiFYHTrGPQn7hspDUzIHX3UA==} dependencies: - '@types/minimatch': 5.1.2 + '@types/minimatch': 5.1.1 '@types/node': 20.4.1 dev: true - /@types/glob@8.1.0: - resolution: {integrity: sha512-IO+MJPVhoqz+28h1qLAcBEH2+xHMK6MTyHJc7MTnnYb6wsoLR29POVGJ7LycmVXIqyy/4/2ShP5sUwTXuOwb/w==} + /@types/glob@8.0.0: + resolution: {integrity: sha512-l6NQsDDyQUVeoTynNpC9uRvCUint/gSUXQA2euwmTuWGvPY5LSDUu6tkCtJB2SvGQlJQzLaKqcGZP4//7EDveA==} dependencies: - '@types/minimatch': 5.1.2 + '@types/minimatch': 5.1.1 '@types/node': 20.4.1 dev: true - /@types/graceful-fs@4.1.6: - resolution: {integrity: sha512-Sig0SNORX9fdW+bQuTEovKj3uHcUL6LQKbCrrqb1X7J6/ReAbhCXRAhc+SMejhLELFj2QcyuxmUooZ4bt5ReSw==} + /@types/graceful-fs@4.1.5: + resolution: {integrity: sha512-anKkLmZZ+xm4p8JWBf4hElkM4XR+EZeA2M9BAkkTldmcyDY4mbdIJnRghDJH3Ov5ooY7/UAoENtmdMSkaAd7Cw==} dependencies: '@types/node': 20.4.1 dev: true - /@types/hast@2.3.5: - resolution: {integrity: sha512-SvQi0L/lNpThgPoleH53cdjB3y9zpLlVjRbqB3rH8hx1jiRSBGAhyjV3H+URFjNVRqt2EdYNrbZE5IsGlNfpRg==} + /@types/hast@2.3.4: + resolution: {integrity: sha512-wLEm0QvaoawEDoTRwzTXp4b4jpwiJDvR5KMnFnVodm3scufTlBOWRD6N1OBf9TZMhjlNsSfcO5V+7AF4+Vy+9g==} dependencies: - '@types/unist': 2.0.7 + '@types/unist': 2.0.6 dev: true /@types/html-minifier-terser@5.1.2: @@ -7739,10 +8733,6 @@ packages: resolution: {integrity: sha512-SZs7ekbP8CN0txVG2xVRH6EgKmEm31BOxA07vkFaETzZz1xh+cbt8BcI0slpymvwhx5dlFnQG2rTlPVQn+iRPQ==} dev: true - /@types/http-errors@2.0.1: - resolution: {integrity: sha512-/K3ds8TRAfBvi5vfjuz8y6+GiAYBZ0x4tXv1Av6CWBWn0IlADc+ZX9pMq7oU0fNQPnBwIZl3rmeLp6SBApbxSQ==} - dev: true - /@types/inquirer@9.0.3: resolution: {integrity: sha512-CzNkWqQftcmk2jaCWdBTf9Sm7xSw4rkI1zpU/Udw3HX5//adEZUIm9STtoRP1qgWj0CWQtJ9UTvqmO2NNjhMJw==} dependencies: @@ -7784,11 +8774,11 @@ packages: '@types/istanbul-lib-report': 3.0.0 dev: true - /@types/jest@29.5.3: - resolution: {integrity: sha512-1Nq7YrO/vJE/FYnqYyw0FS8LdrjExSgIiHyKg7xPpn+yi8Q4huZryKnkJatN1ZRH89Kw2v33/8ZMB7DuZeSLlA==} + /@types/jest@29.0.0: + resolution: {integrity: sha512-X6Zjz3WO4cT39Gkl0lZ2baFRaEMqJl5NC1OjElkwtNzAlbkr2K/WJXkBkH5VP0zx4Hgsd2TZYdOEfvp2Dxia+Q==} dependencies: - expect: 29.6.1 - pretty-format: 29.6.1 + expect: 29.0.1 + pretty-format: 29.5.0 dev: true /@types/js-levenshtein@1.1.1: @@ -7803,8 +8793,8 @@ packages: parse5: 7.1.2 dev: true - /@types/json-schema@7.0.12: - resolution: {integrity: sha512-Hr5Jfhc9eYOQNPYO5WLDq/n4jqijdHNlDXjuAQkkt+mWdQR+XJToOHrsD4cPaMXpn6KO7y2+wM8AZEs8VpBLVA==} + /@types/json-schema@7.0.11: + resolution: {integrity: sha512-wOuvG1SN4Us4rez+tylwwwCV1psiNVOkJeM3AUWUNWg/jDQY2+HE/444y5gc+jBmRqASOm2Oeh5c1axHobwRKQ==} dev: true /@types/jsonfile@6.1.1: @@ -7817,28 +8807,20 @@ packages: resolution: {integrity: sha512-Hwx9EUgdwf2GLarOjQp5ZH8ZmblzcbTBC2wtQWNKARBSxM9ezRIAUpeDTgoQRAFB0+8CNWXVA9+MaSOzOF3nPg==} dev: true - /@types/mdast@3.0.12: - resolution: {integrity: sha512-DT+iNIRNX884cx0/Q1ja7NyUPpZuv0KPyL5rGNxm1WC1OtHstl7n4Jb7nk+xacNShQMbczJjt8uFzznpp6kYBg==} + /@types/mdast@3.0.10: + resolution: {integrity: sha512-W864tg/Osz1+9f4lrGTZpCSO5/z4608eUp19tbozkq2HJK6i3z1kT0H9tlADXuYIb1YYOBByU4Jsqkk75q48qA==} dependencies: - '@types/unist': 2.0.7 + '@types/unist': 2.0.6 dev: true /@types/micromatch@4.0.2: resolution: {integrity: sha512-oqXqVb0ci19GtH0vOA/U2TmHTcRY9kuZl4mqUxe0QmJAlIW13kzhuK5pi1i9+ngav8FjpSb9FVS/GE00GLX1VA==} dependencies: - '@types/braces': 3.0.2 - dev: true - - /@types/mime@1.3.2: - resolution: {integrity: sha512-YATxVxgRqNH6nHEIsvg6k2Boc1JHI9ZbH5iWFFv/MTkchz3b1ieGDa5T0a9RznNdI0KhVbdbWSN+KWWrQZRxTw==} - dev: true - - /@types/mime@3.0.1: - resolution: {integrity: sha512-Y4XFY5VJAuw0FgAqPNd6NNoV44jbq9Bz2L7Rh/J6jLTiHBSBJa9fxqQIvkIld4GsoDOcCbvzOUAbLPsSKKg+uA==} + '@types/braces': 3.0.1 dev: true - /@types/minimatch@5.1.2: - resolution: {integrity: sha512-K0VQKziLUWkVKiRVrx4a40iPaxTUefQmjtkQofBkYRcoaaL/8rhwDWww9qWbrgicNOgnpIsMxyNIUM4+n6dUIA==} + /@types/minimatch@5.1.1: + resolution: {integrity: sha512-v55NF6Dz0wrj14Rn8iEABTWrhYRmgkJYuokduunSiq++t3hZ9VZ6dvcDt+850Pm5sGJZk8RaHzkFCXPxVINZ+g==} dev: true /@types/ms@0.7.31: @@ -7849,26 +8831,31 @@ packages: resolution: {integrity: sha512-9dr4UakpvN0QUvwNefk9+o14Sr1pPPIDWkgCxPkHcg3kyjtc9eKK1ng6dZ23vRwByloCqXYtZ1T5nJxkk3Ib3A==} dev: true - /@types/node-fetch@2.6.4: - resolution: {integrity: sha512-1ZX9fcN4Rvkvgv4E6PAY5WXUFWFcRWxZa3EW83UjycOB9ljJCedb2CupIP4RZMEwF/M3eTcCihbBRgwtGbg5Rg==} + /@types/node-fetch@2.6.2: + resolution: {integrity: sha512-DHqhlq5jeESLy19TYhLakJ07kNumXWjcDdxXsLUMJZ6ue8VZJj4kLPQVE/2mdHh3xZziNF1xppu5lwmS53HR+A==} dependencies: '@types/node': 20.4.1 form-data: 3.0.1 dev: true - /@types/node@14.18.53: - resolution: {integrity: sha512-soGmOpVBUq+gaBMwom1M+krC/NNbWlosh4AtGA03SyWNDiqSKtwp7OulO1M6+mg8YkHMvJ/y0AkCeO8d1hNb7A==} + /@types/node@14.18.26: + resolution: {integrity: sha512-0b+utRBSYj8L7XAp0d+DX7lI4cSmowNaaTkk6/1SKzbKkG+doLuPusB9EOvzLJ8ahJSk03bTLIL6cWaEd4dBKA==} dev: true - /@types/node@16.18.38: - resolution: {integrity: sha512-6sfo1qTulpVbkxECP+AVrHV9OoJqhzCsfTNp5NIG+enM4HyM3HvZCO798WShIXBN0+QtDIcutJCjsVYnQP5rIQ==} + /@types/node@16.11.56: + resolution: {integrity: sha512-aFcUkv7EddxxOa/9f74DINReQ/celqH8DiB3fRYgVDM2Xm5QJL8sl80QKuAnGvwAsMn+H3IFA6WCrQh1CY7m1A==} dev: true /@types/node@18.16.19: resolution: {integrity: sha512-IXl7o+R9iti9eBW4Wg2hx1xQDig183jj7YLn8F7udNceyfkbn1ZxmzZXuak20gR40D7pIkIY1kYGx5VIGbaHKA==} + /@types/node@18.7.13: + resolution: {integrity: sha512-46yIhxSe5xEaJZXWdIBP7GU4HDTG8/eo0qd9atdiL+lFpA03y8KS+lkTN834TWJj5767GbWv4n/P6efyTFt1Dw==} + dev: false + /@types/node@20.4.1: resolution: {integrity: sha512-JIzsAvJeA/5iY6Y/OxZbv1lUcc8dNSE77lb2gnBH+/PJ3lFR1Ccvgwl5JWnHAkNHcRsT0TbpVOsiMKZ1F/yyJg==} + dev: true /@types/normalize-package-data@2.4.1: resolution: {integrity: sha512-Gj7cI7z+98M282Tqmp2K5EIsoouUEzbBJhQQzDE3jSIRk6r9gsz0oUokqIUR4u1R3dMHo0pDHM7sNOHyhulypw==} @@ -7885,8 +8872,8 @@ packages: resolution: {integrity: sha512-kUNnecmtkunAoQ3CnjmMkzNU/gtxG8guhi+Fk2U/kOpIKjIMKnXGp4IJCgQJrXSgMsWYimYG4TGjz/UzbGEBTw==} dev: true - /@types/prettier@2.7.3: - resolution: {integrity: sha512-+68kP9yzs4LMp7VNh8gdzMSPZFL44MLGqiHWvttYJe+6qnuVr4Ek9wSBQoveqY/r+LwjCcU29kNVkidwim+kYA==} + /@types/prettier@2.7.0: + resolution: {integrity: sha512-RI1L7N4JnW5gQw2spvL7Sllfuf1SaHdrZpCHiBlCXjIlufi1SMNnbu2teze3/QE67Fg2tBlH7W+mi4hVNk4p0A==} dev: true /@types/pretty-hrtime@1.0.1: @@ -7911,24 +8898,26 @@ packages: resolution: {integrity: sha512-FGa1F62FT09qcrueBA6qYTrJPVDzah9a+493+o2PCXsesWHIn27G98TsSMs3WPNbZIEj4+VJf6saSFpvD+3Zsw==} dev: true - /@types/range-parser@1.2.4: - resolution: {integrity: sha512-EEhsLsD6UsDM1yFhAvy0Cjr6VwmpMWqFBCb9w07wVugF7w9nfajxLuVmngTIpgS6svCnm6Vaw+MZhoDCKnOfsw==} + /@types/react-dom@17.0.17: + resolution: {integrity: sha512-VjnqEmqGnasQKV0CWLevqMTXBYG9GbwuE6x3VetERLh0cq2LTptFE73MrQi2S7GkKXCf2GgwItB/melLnxfnsg==} + dependencies: + '@types/react': 17.0.49 dev: true - /@types/react-dom@17.0.20: - resolution: {integrity: sha512-4pzIjSxDueZZ90F52mU3aPoogkHIoSIDG+oQ+wQK7Cy2B9S+MvOqY0uEA/qawKz381qrEDkvpwyt8Bm31I8sbA==} + /@types/react-dom@18.0.6: + resolution: {integrity: sha512-/5OFZgfIPSwy+YuIBP/FgJnQnsxhZhjjrnxudMddeblOouIodEQ75X14Rr4wGSG/bknL+Omy9iWlLo1u/9GzAA==} dependencies: - '@types/react': 17.0.62 + '@types/react': 18.2.14 dev: true - /@types/react-dom@18.2.6: - resolution: {integrity: sha512-2et4PDvg6PVCyS7fuTc4gPoksV58bW0RwSxWKcPRcHZf0PRUGq03TKcD/rUHe3azfV6/5/biUBJw+HhCQjaP0A==} + /@types/react-dom@18.0.8: + resolution: {integrity: sha512-C3GYO0HLaOkk9dDAz3Dl4sbe4AKUGTCfFIZsz3n/82dPNN8Du533HzKatDxeUYWu24wJgMP1xICqkWk1YOLOIw==} dependencies: '@types/react': 18.2.14 dev: true - /@types/react-is@18.2.1: - resolution: {integrity: sha512-wyUkmaaSZEzFZivD8F2ftSyAfk6L+DfFliVj/mYdOXbVjRcS87fQJLTnhk6dRZPuJjI+9g6RZJO4PNCngUrmyw==} + /@types/react-is@17.0.3: + resolution: {integrity: sha512-aBTIWg1emtu95bLTLx0cpkxwGW3ueZv71nE2YFBpL8k/z5czEW8yYpOo8Dp+UUAFAtKwNaOsh/ioSeQnWlZcfw==} dependencies: '@types/react': 18.2.14 dev: false @@ -7936,36 +8925,36 @@ packages: /@types/react-test-renderer@17.0.2: resolution: {integrity: sha512-+F1KONQTBHDBBhbHuT2GNydeMpPuviduXIVJRB7Y4nma4NR5DrTJfMMZ+jbhEHbpwL+Uqhs1WXh4KHiyrtYTPg==} dependencies: - '@types/react': 17.0.62 + '@types/react': 17.0.49 dev: true - /@types/react-transition-group@4.4.6: - resolution: {integrity: sha512-VnCdSxfcm08KjsJVQcfBmhEQAPnLB8G08hAxn39azX1qYBQ/5RVQuoHuKIcfKOdncuaUvEpFKFzEvbtIMsfVew==} + /@types/react-transition-group@4.4.5: + resolution: {integrity: sha512-juKD/eiSM3/xZYzjuzH6ZwpP+/lejltmiS3QEzV/vmb/Q8+HfDmxu+Baga8UEMGBqV88Nbg4l2hY/K2DkyaLLA==} dependencies: '@types/react': 18.2.14 dev: false - /@types/react@16.14.43: - resolution: {integrity: sha512-7zdjv7jvoLLQg1tTvpQsm+hyNUMT2mPlNV1+d0I8fbGhkJl82spopMyBlu4wb1dviZAxpGdk5eHu/muacknnfw==} + /@types/react@17.0.49: + resolution: {integrity: sha512-CCBPMZaPhcKkYUTqFs/hOWqKjPxhTEmnZWjlHHgIMop67DsXywf9B5Os9Hz8KSacjNOgIdnZVJamwl232uxoPg==} dependencies: '@types/prop-types': 15.7.5 - '@types/scheduler': 0.16.3 - csstype: 3.1.2 + '@types/scheduler': 0.16.2 + csstype: 3.1.0 dev: true - /@types/react@17.0.62: - resolution: {integrity: sha512-eANCyz9DG8p/Vdhr0ZKST8JV12PhH2ACCDYlFw6DIO+D+ca+uP4jtEDEpVqXZrh/uZdXQGwk7whJa3ah5DtyLw==} + /@types/react@18.0.25: + resolution: {integrity: sha512-xD6c0KDT4m7n9uD4ZHi02lzskaiqcBxf4zi+tXZY98a04wvc0hi/TcCPC2FOESZi51Nd7tlUeOJY8RofL799/g==} dependencies: '@types/prop-types': 15.7.5 - '@types/scheduler': 0.16.3 - csstype: 3.1.2 + '@types/scheduler': 0.16.2 + csstype: 3.1.0 dev: true /@types/react@18.2.14: resolution: {integrity: sha512-A0zjq+QN/O0Kpe30hA1GidzyFjatVvrpIvWLxD+xv67Vt91TWWgco9IvrJBkeyHm1trGaFS/FSGqPlhyeZRm0g==} dependencies: '@types/prop-types': 15.7.5 - '@types/scheduler': 0.16.3 + '@types/scheduler': 0.16.2 csstype: 3.1.2 /@types/resolve@1.17.1: @@ -7978,26 +8967,11 @@ packages: resolution: {integrity: sha512-60BCwRFOZCQhDncwQdxxeOEEkbc5dIMccYLwbxsS4TUNeVECQ/pBJ0j09mrHOl/JJvpRPGwO9SvE4nR2Nb/a4Q==} dev: true - /@types/scheduler@0.16.3: - resolution: {integrity: sha512-5cJ8CB4yAx7BH1oMvdU0Jh9lrEXyPkar6F9G/ERswkCuvP4KQZfZkSjcMbAICCpQTN4OuZn8tz0HiKv9TGZgrQ==} - - /@types/semver@7.5.0: - resolution: {integrity: sha512-G8hZ6XJiHnuhQKR7ZmysCeJWE08o8T0AXtk5darsCaTVsYZhhgUrq53jizaR2FvsoeCwJhlmwTjkXBY5Pn/ZHw==} - dev: true - - /@types/send@0.17.1: - resolution: {integrity: sha512-Cwo8LE/0rnvX7kIIa3QHCkcuF21c05Ayb0ZfxPiv0W8VRiZiNW/WuRupHKpqqGVGf7SUA44QSOUKaEd9lIrd/Q==} - dependencies: - '@types/mime': 1.3.2 - '@types/node': 20.4.1 - dev: true + /@types/scheduler@0.16.2: + resolution: {integrity: sha512-hppQEBDmlwhFAXKJX2KnWLYu5yMfi91yazPb2l+lbJiwW+wdo1gNeRA+3RgNSO39WYX2euey41KEwnqesU2Jew==} - /@types/serve-static@1.15.2: - resolution: {integrity: sha512-J2LqtvFYCzaj8pVYKw8klQXrLLk7TBZmQ4ShlcdkELFKGwGMfevMLneMMRkMgZxotOD9wg497LpC7O8PcvAmfw==} - dependencies: - '@types/http-errors': 2.0.1 - '@types/mime': 3.0.1 - '@types/node': 20.4.1 + /@types/semver@7.3.13: + resolution: {integrity: sha512-21cFJr9z3g5dW8B0CVI9g2O9beqaThGQ6ZFBqHfwhzLDKUxaqTIy3vnfah/UPkfOiF2pLq+tGz+W8RyCskuslw==} dev: true /@types/set-cookie-parser@2.4.2: @@ -8036,10 +9010,10 @@ packages: '@types/estree': 1.0.1 dev: true - /@types/testing-library__jest-dom@5.14.8: - resolution: {integrity: sha512-NRfJE9Cgpmu4fx716q9SYmU4jxxhYRU1BQo239Txt/9N3EC745XZX1Yl7h/SBIDlo1ANVOCRB4YDXjaQdoKCHQ==} + /@types/testing-library__jest-dom@5.14.5: + resolution: {integrity: sha512-SBwbxYoyPIvxHbeHxTZX2Pe/74F/tX2/D3mMvzabdeJ25bBojfW0TyB8BHrbq/9zaaKICJZjLP+8r6AeZMFCuQ==} dependencies: - '@types/jest': 29.5.3 + '@types/jest': 29.0.0 dev: true /@types/through@0.0.30: @@ -8052,11 +9026,11 @@ packages: resolution: {integrity: sha512-Q5vtl1W5ue16D+nIaW8JWebSSraJVlK+EthKn7e7UcD4KWsaSJ8BqGPXNaPghgtcn/fhvrN17Tv8ksUsQpiplw==} dev: true - /@types/trusted-types@2.0.3: - resolution: {integrity: sha512-NfQ4gyz38SL8sDNrSixxU2Os1a5xcdFxipAFxYEuLUlvU2uDwS4NUpsImcf1//SlWItCVMMLiylsxbmNMToV/g==} + /@types/trusted-types@2.0.2: + resolution: {integrity: sha512-F5DIZ36YVLE+PN+Zwws4kJogq47hNgX3Nx6WyDJ3kcplxyke3XIzB8uK5n/Lpm1HBsbGzd6nmGehL8cPekP+Tg==} - /@types/uglify-js@3.17.1: - resolution: {integrity: sha512-GkewRA4i5oXacU/n4MA9+bLgt5/L3F1mKrYvFGm7r2ouLXhRKjuWwo9XHNnbx6WF3vlGW21S3fCvgqxvxXXc5g==} + /@types/uglify-js@3.17.0: + resolution: {integrity: sha512-3HO6rm0y+/cqvOyA8xcYLweF0TKXlAxmQASjbOi49Co51A1N4nR4bEwBgRoD9kNM+rqFGArjKr654SLp2CoGmQ==} dependencies: source-map: 0.6.1 dev: true @@ -8065,8 +9039,8 @@ packages: resolution: {integrity: sha512-eBWREUhVUGPze+bUW22AgUr05k8u+vETzuYdLYSvWqGTUe0KOf+zVnOB1qER5wMcw8V6D9Ar4DfJmVvD1yu0kQ==} dev: true - /@types/unist@2.0.7: - resolution: {integrity: sha512-cputDpIbFgLUaGQn6Vqg3/YsJwxUwHLO13v3i5ouxT4lat0khip9AEWxtERujXV9wxIB1EyF97BSJFt6vpdI8g==} + /@types/unist@2.0.6: + resolution: {integrity: sha512-PBjIUxZHOuj0R15/xuwJYjFi+KZdNFrehocChv4g5hu6aFroHue8m0lBP0POdK2nKzbw0cgV1mws8+V/JAcEkQ==} dev: true /@types/web-bluetooth@0.0.14: @@ -8076,8 +9050,8 @@ packages: /@types/web-bluetooth@0.0.17: resolution: {integrity: sha512-4p9vcSmxAayx72yn70joFoL44c9MO/0+iVEBIQXe3v2h2SiAsEIo/G5v6ObFWvNKRFjbrVadNf9LqEEZeQPzdA==} - /@types/webpack-env@1.18.1: - resolution: {integrity: sha512-D0HJET2/UY6k9L6y3f5BL+IDxZmPkYmPT4+qBrRdmRLYRuV0qNKizMgTvYxXZYn+36zjPeoDZAEYBCM6XB+gww==} + /@types/webpack-env@1.18.0: + resolution: {integrity: sha512-56/MAlX5WMsPVbOg7tAxnYvNYMMWr/QJiIp6BxVSW3JJXUVzzOn64qW8TzQyMSqSUFM2+PVI4aUHcHOzIz/1tg==} dev: true /@types/webpack-sources@3.2.0: @@ -8088,14 +9062,14 @@ packages: source-map: 0.7.4 dev: true - /@types/webpack@4.41.33: - resolution: {integrity: sha512-PPajH64Ft2vWevkerISMtnZ8rTs4YmRbs+23c402J0INmxDKCrhZNvwZYtzx96gY2wAtXdrK1BS2fiC8MlLr3g==} + /@types/webpack@4.41.32: + resolution: {integrity: sha512-cb+0ioil/7oz5//7tZUSwbrSAN/NWHrQylz5cW8G0dWTcF/g+/dSdMlKVZspBYuMAN1+WnwHrkxiRrLcwd0Heg==} dependencies: '@types/node': 20.4.1 '@types/tapable': 1.0.8 - '@types/uglify-js': 3.17.1 + '@types/uglify-js': 3.17.0 '@types/webpack-sources': 3.2.0 - anymatch: 3.1.3 + anymatch: 3.1.2 source-map: 0.6.1 dev: true @@ -8113,8 +9087,8 @@ packages: resolution: {integrity: sha512-iO9ZQHkZxHn4mSakYV0vFHAVDyEOIJQrV2uZ06HxEPcx+mt8swXoZHIbaaJ2crJYFfErySgktuTZ3BeLz+XmFA==} dev: true - /@types/yargs@15.0.15: - resolution: {integrity: sha512-IziEYMU9XoVj8hWg7k+UJrXALkGFjWJhn5QFEv9q4p+v40oZhSuC135M38st8XPjICL7Ey4TV64ferBGUoJhBg==} + /@types/yargs@15.0.14: + resolution: {integrity: sha512-yEJzHoxf6SyQGhBhIYGXQDSCkJjB6HohDShto7m8vaKg9Yp0Yn8+71J9eakh2bnPg6BfsH9PRMhiRTZnd4eXGQ==} dependencies: '@types/yargs-parser': 21.0.0 dev: true @@ -8125,8 +9099,8 @@ packages: '@types/yargs-parser': 21.0.0 dev: true - /@types/yargs@17.0.24: - resolution: {integrity: sha512-6i0aC7jV6QzQB8ne1joVZ0eSFIstHsCrobmOtghM11yGlH0j43FKL2UhWdELkyps0zuf7qVTUVCCR+tgSlyLLw==} + /@types/yargs@17.0.12: + resolution: {integrity: sha512-Nz4MPhecOFArtm81gFQvQqdV7XYCrWKx5uUt6GNHredFHn1i2mtWqXTON7EPXMtNi1qjtjEM/VCHDhcHsAMLXQ==} dependencies: '@types/yargs-parser': 21.0.0 dev: true @@ -8139,8 +9113,8 @@ packages: dev: true optional: true - /@typescript-eslint/eslint-plugin@5.62.0(@typescript-eslint/parser@5.62.0)(eslint@8.44.0)(typescript@5.1.6): - resolution: {integrity: sha512-TiZzBSJja/LbhNPvk6yc0JrX9XqhQ0hdh6M2svYfsHGejaKFIAGd9MQ+ERIMzLGlN/kZoYIgdxFV0PuljTKXag==} + /@typescript-eslint/eslint-plugin@5.60.0(@typescript-eslint/parser@5.60.0)(eslint@8.44.0)(typescript@5.1.6): + resolution: {integrity: sha512-78B+anHLF1TI8Jn/cD0Q00TBYdMgjdOn980JfAVa9yw5sop8nyTfVOQAv6LWywkOGLclDBtv5z3oxN4w7jxyNg==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: '@typescript-eslint/parser': ^5.0.0 @@ -8150,25 +9124,25 @@ packages: typescript: optional: true dependencies: - '@eslint-community/regexpp': 4.5.1 - '@typescript-eslint/parser': 5.62.0(eslint@8.44.0)(typescript@5.1.6) - '@typescript-eslint/scope-manager': 5.62.0 - '@typescript-eslint/type-utils': 5.62.0(eslint@8.44.0)(typescript@5.1.6) - '@typescript-eslint/utils': 5.62.0(eslint@8.44.0)(typescript@5.1.6) + '@eslint-community/regexpp': 4.5.0 + '@typescript-eslint/parser': 5.60.0(eslint@8.44.0)(typescript@5.1.6) + '@typescript-eslint/scope-manager': 5.60.0 + '@typescript-eslint/type-utils': 5.60.0(eslint@8.44.0)(typescript@5.1.6) + '@typescript-eslint/utils': 5.60.0(eslint@8.44.0)(typescript@5.1.6) debug: 4.3.4(supports-color@8.1.1) eslint: 8.44.0 - graphemer: 1.4.0 - ignore: 5.2.4 + grapheme-splitter: 1.0.4 + ignore: 5.2.0 natural-compare-lite: 1.4.0 - semver: 7.5.4 + semver: 7.5.2 tsutils: 3.21.0(typescript@5.1.6) typescript: 5.1.6 transitivePeerDependencies: - supports-color dev: true - /@typescript-eslint/parser@5.62.0(eslint@8.44.0)(typescript@5.1.6): - resolution: {integrity: sha512-VlJEV0fOQ7BExOsHYAGrgbEiZoi8D+Bl2+f6V2RrXerRSylnp+ZBHmPvaIa8cz0Ajx7WO7Z5RqfgYg7ED1nRhA==} + /@typescript-eslint/parser@5.60.0(eslint@8.44.0)(typescript@5.1.6): + resolution: {integrity: sha512-jBONcBsDJ9UoTWrARkRRCgDz6wUggmH5RpQVlt7BimSwaTkTjwypGzKORXbR4/2Hqjk9hgwlon2rVQAjWNpkyQ==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: eslint: ^6.0.0 || ^7.0.0 || ^8.0.0 @@ -8177,9 +9151,9 @@ packages: typescript: optional: true dependencies: - '@typescript-eslint/scope-manager': 5.62.0 - '@typescript-eslint/types': 5.62.0 - '@typescript-eslint/typescript-estree': 5.62.0(typescript@5.1.6) + '@typescript-eslint/scope-manager': 5.60.0 + '@typescript-eslint/types': 5.60.0 + '@typescript-eslint/typescript-estree': 5.60.0(typescript@5.1.6) debug: 4.3.4(supports-color@8.1.1) eslint: 8.44.0 typescript: 5.1.6 @@ -8187,16 +9161,16 @@ packages: - supports-color dev: true - /@typescript-eslint/scope-manager@5.62.0: - resolution: {integrity: sha512-VXuvVvZeQCQb5Zgf4HAxc04q5j+WrNAtNh9OwCsCgpKqESMTu3tF/jhZ3xG6T4NZwWl65Bg8KuS2uEvhSfLl0w==} + /@typescript-eslint/scope-manager@5.60.0: + resolution: {integrity: sha512-hakuzcxPwXi2ihf9WQu1BbRj1e/Pd8ZZwVTG9kfbxAMZstKz8/9OoexIwnmLzShtsdap5U/CoQGRCWlSuPbYxQ==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dependencies: - '@typescript-eslint/types': 5.62.0 - '@typescript-eslint/visitor-keys': 5.62.0 + '@typescript-eslint/types': 5.60.0 + '@typescript-eslint/visitor-keys': 5.60.0 dev: true - /@typescript-eslint/type-utils@5.62.0(eslint@8.44.0)(typescript@5.1.6): - resolution: {integrity: sha512-xsSQreu+VnfbqQpW5vnCJdq1Z3Q0U31qiWmRhr98ONQmcp/yhiPJFPq8MXiJVLiksmOKSjIldZzkebzHuCGzew==} + /@typescript-eslint/type-utils@5.60.0(eslint@8.44.0)(typescript@5.1.6): + resolution: {integrity: sha512-X7NsRQddORMYRFH7FWo6sA9Y/zbJ8s1x1RIAtnlj6YprbToTiQnM6vxcMu7iYhdunmoC0rUWlca13D5DVHkK2g==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: eslint: '*' @@ -8205,8 +9179,8 @@ packages: typescript: optional: true dependencies: - '@typescript-eslint/typescript-estree': 5.62.0(typescript@5.1.6) - '@typescript-eslint/utils': 5.62.0(eslint@8.44.0)(typescript@5.1.6) + '@typescript-eslint/typescript-estree': 5.60.0(typescript@5.1.6) + '@typescript-eslint/utils': 5.60.0(eslint@8.44.0)(typescript@5.1.6) debug: 4.3.4(supports-color@8.1.1) eslint: 8.44.0 tsutils: 3.21.0(typescript@5.1.6) @@ -8215,13 +9189,13 @@ packages: - supports-color dev: true - /@typescript-eslint/types@5.62.0: - resolution: {integrity: sha512-87NVngcbVXUahrRTqIK27gD2t5Cu1yuCXxbLcFtCzZGlfyVWWh8mLHkoxzjsB6DDNnvdL+fW8MiwPEJyGJQDgQ==} + /@typescript-eslint/types@5.60.0: + resolution: {integrity: sha512-ascOuoCpNZBccFVNJRSC6rPq4EmJ2NkuoKnd6LDNyAQmdDnziAtxbCGWCbefG1CNzmDvd05zO36AmB7H8RzKPA==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dev: true - /@typescript-eslint/typescript-estree@5.62.0(typescript@5.1.6): - resolution: {integrity: sha512-CmcQ6uY7b9y694lKdRB8FEel7JbU/40iSAPomu++SjLMntB+2Leay2LO6i8VnJk58MtE9/nQSFIH6jpyRWyYzA==} + /@typescript-eslint/typescript-estree@5.60.0(typescript@5.1.6): + resolution: {integrity: sha512-R43thAuwarC99SnvrBmh26tc7F6sPa2B3evkXp/8q954kYL6Ro56AwASYWtEEi+4j09GbiNAHqYwNNZuNlARGQ==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: typescript: '*' @@ -8229,43 +9203,43 @@ packages: typescript: optional: true dependencies: - '@typescript-eslint/types': 5.62.0 - '@typescript-eslint/visitor-keys': 5.62.0 + '@typescript-eslint/types': 5.60.0 + '@typescript-eslint/visitor-keys': 5.60.0 debug: 4.3.4(supports-color@8.1.1) globby: 11.1.0 is-glob: 4.0.3 - semver: 7.5.4 + semver: 7.5.2 tsutils: 3.21.0(typescript@5.1.6) typescript: 5.1.6 transitivePeerDependencies: - supports-color dev: true - /@typescript-eslint/utils@5.62.0(eslint@8.44.0)(typescript@5.1.6): - resolution: {integrity: sha512-n8oxjeb5aIbPFEtmQxQYOLI0i9n5ySBEY/ZEHHZqKQSFnxio1rv6dthascc9dLuwrL0RC5mPCxB7vnAVGAYWAQ==} + /@typescript-eslint/utils@5.60.0(eslint@8.44.0)(typescript@5.1.6): + resolution: {integrity: sha512-ba51uMqDtfLQ5+xHtwlO84vkdjrqNzOnqrnwbMHMRY8Tqeme8C2Q8Fc7LajfGR+e3/4LoYiWXUM6BpIIbHJ4hQ==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: eslint: ^6.0.0 || ^7.0.0 || ^8.0.0 dependencies: '@eslint-community/eslint-utils': 4.4.0(eslint@8.44.0) - '@types/json-schema': 7.0.12 - '@types/semver': 7.5.0 - '@typescript-eslint/scope-manager': 5.62.0 - '@typescript-eslint/types': 5.62.0 - '@typescript-eslint/typescript-estree': 5.62.0(typescript@5.1.6) + '@types/json-schema': 7.0.11 + '@types/semver': 7.3.13 + '@typescript-eslint/scope-manager': 5.60.0 + '@typescript-eslint/types': 5.60.0 + '@typescript-eslint/typescript-estree': 5.60.0(typescript@5.1.6) eslint: 8.44.0 eslint-scope: 5.1.1 - semver: 7.5.4 + semver: 7.5.2 transitivePeerDependencies: - supports-color - typescript dev: true - /@typescript-eslint/visitor-keys@5.62.0: - resolution: {integrity: sha512-07ny+LHRzQXepkGg6w0mFY41fVUNBrL2Roj/++7V1txKugfjm/Ci/qSND03r2RhlJhJYMcTn9AhhSSqQp0Ysyw==} + /@typescript-eslint/visitor-keys@5.60.0: + resolution: {integrity: sha512-wm9Uz71SbCyhUKgcaPRauBdTegUyY/ZWl8gLwD/i/ybJqscrrdVSFImpvUz16BLPChIeKBK5Fa9s6KDQjsjyWw==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dependencies: - '@typescript-eslint/types': 5.62.0 + '@typescript-eslint/types': 5.60.0 eslint-visitor-keys: 3.4.1 dev: true @@ -8273,42 +9247,42 @@ packages: resolution: {integrity: sha512-zuVdFrMJiuCDQUMCzQaD6KL28MjnqqN8XnAqiEq9PNm/hCPTSGfrXCOfwj1ow4LFb/tNymJPwsNbVePc1xFqrQ==} dev: true - /@unocss/astro@0.53.5(rollup@2.79.1)(vite@4.4.3): - resolution: {integrity: sha512-W4A0uIN4xAzVH6Vwf5ukG8rJpCeIwQZcpZPrEBWsqY5YcHZcLTFGMHcNmxyeG0qoXpXoxtvHyXXhgGU0BY5ZEw==} + /@unocss/astro@0.53.4(rollup@2.79.1)(vite@4.3.9): + resolution: {integrity: sha512-fR1F0mNktoN79R+t4GD4y3cvfHUVxtV0+9/6vraZTw3SOXTOMdHeisdxDLjJb3N1yer7XoKX+2GHrKCt873IUA==} dependencies: - '@unocss/core': 0.53.5 - '@unocss/reset': 0.53.5 - '@unocss/vite': 0.53.5(rollup@2.79.1)(vite@4.4.3) + '@unocss/core': 0.53.4 + '@unocss/reset': 0.53.4 + '@unocss/vite': 0.53.4(rollup@2.79.1)(vite@4.3.9) transitivePeerDependencies: - rollup - vite dev: true - /@unocss/astro@0.53.5(rollup@3.26.2)(vite@4.4.3): - resolution: {integrity: sha512-W4A0uIN4xAzVH6Vwf5ukG8rJpCeIwQZcpZPrEBWsqY5YcHZcLTFGMHcNmxyeG0qoXpXoxtvHyXXhgGU0BY5ZEw==} + /@unocss/astro@0.53.4(rollup@3.26.0)(vite@4.3.9): + resolution: {integrity: sha512-fR1F0mNktoN79R+t4GD4y3cvfHUVxtV0+9/6vraZTw3SOXTOMdHeisdxDLjJb3N1yer7XoKX+2GHrKCt873IUA==} dependencies: - '@unocss/core': 0.53.5 - '@unocss/reset': 0.53.5 - '@unocss/vite': 0.53.5(rollup@3.26.2)(vite@4.4.3) + '@unocss/core': 0.53.4 + '@unocss/reset': 0.53.4 + '@unocss/vite': 0.53.4(rollup@3.26.0)(vite@4.3.9) transitivePeerDependencies: - rollup - vite dev: true - /@unocss/cli@0.53.5(rollup@2.79.1): - resolution: {integrity: sha512-UKi+9BAKh3X5eM4pPQviXMOtN8JkQWKdGy/056rRLQysPB07VBwWr5gYAlJMMJ2wFAIthag43X5I8btQAicFkg==} + /@unocss/cli@0.53.4(rollup@2.79.1): + resolution: {integrity: sha512-nRlmEcApzFbRkvkOauq6z46dcYJaWfkK7VdavSgXbLWCSoKWXY7JkEAON1Zhmk4O8F4zW7hnxTfqZI5jfy09Rw==} engines: {node: '>=14'} hasBin: true dependencies: '@ampproject/remapping': 2.2.1 '@rollup/pluginutils': 5.0.2(rollup@2.79.1) - '@unocss/config': 0.53.5 - '@unocss/core': 0.53.5 - '@unocss/preset-uno': 0.53.5 + '@unocss/config': 0.53.4 + '@unocss/core': 0.53.4 + '@unocss/preset-uno': 0.53.4 cac: 6.7.14 chokidar: 3.5.3 colorette: 2.0.20 - consola: 3.2.3 + consola: 3.1.0 fast-glob: 3.3.0 magic-string: 0.30.1 pathe: 1.1.1 @@ -8317,20 +9291,20 @@ packages: - rollup dev: true - /@unocss/cli@0.53.5(rollup@3.26.2): - resolution: {integrity: sha512-UKi+9BAKh3X5eM4pPQviXMOtN8JkQWKdGy/056rRLQysPB07VBwWr5gYAlJMMJ2wFAIthag43X5I8btQAicFkg==} + /@unocss/cli@0.53.4(rollup@3.26.0): + resolution: {integrity: sha512-nRlmEcApzFbRkvkOauq6z46dcYJaWfkK7VdavSgXbLWCSoKWXY7JkEAON1Zhmk4O8F4zW7hnxTfqZI5jfy09Rw==} engines: {node: '>=14'} hasBin: true dependencies: '@ampproject/remapping': 2.2.1 - '@rollup/pluginutils': 5.0.2(rollup@3.26.2) - '@unocss/config': 0.53.5 - '@unocss/core': 0.53.5 - '@unocss/preset-uno': 0.53.5 + '@rollup/pluginutils': 5.0.2(rollup@3.26.0) + '@unocss/config': 0.53.4 + '@unocss/core': 0.53.4 + '@unocss/preset-uno': 0.53.4 cac: 6.7.14 chokidar: 3.5.3 colorette: 2.0.20 - consola: 3.2.3 + consola: 3.1.0 fast-glob: 3.3.0 magic-string: 0.30.1 pathe: 1.1.1 @@ -8339,178 +9313,178 @@ packages: - rollup dev: true - /@unocss/config@0.53.5: - resolution: {integrity: sha512-YtpWoIFB1V8Dp3KcVQqislQYQSSBYbjTpoVIkUGrpupwOz9+W1tfL2yKEENDiZc11crJSneGr04wsP2dI1ld0w==} + /@unocss/config@0.53.4: + resolution: {integrity: sha512-xcawSTpo/+yXUsmfQE0FNAkTS6k2sSSWXQD1grCpeZPY9YNVZTFIJvQXC3xMTgRRBRTBThuGDiUC9YF/XAOcZw==} engines: {node: '>=14'} dependencies: - '@unocss/core': 0.53.5 + '@unocss/core': 0.53.4 unconfig: 0.3.9 dev: true - /@unocss/core@0.53.5: - resolution: {integrity: sha512-jBvk4FeUAALAomGfMFFmrXLy01/5DjugdnWgawFAQpSToFTxbMHS7x+pXKu/18cq+YLS8uyl9S0Ywy1jNbfS3Q==} + /@unocss/core@0.53.4: + resolution: {integrity: sha512-JvmpuFOiJ8NkGzRmh0dCUmNdYjr8MmMtCX+czCmSnX2kvKyQjJIw3RIu84/DQbd/M/yxZmPjle8DrcZ1Ql86rQ==} dev: true - /@unocss/extractor-arbitrary-variants@0.53.5: - resolution: {integrity: sha512-rSS3Q8/+lEwxXfXzEOFuhAQGMpaaZcBAYDiNCYS/9BqKrTzhSYG82Qy80ISpqSZr0BTLET4X3dC6B6Rd4GU5vQ==} + /@unocss/extractor-arbitrary-variants@0.53.4: + resolution: {integrity: sha512-ydkfObZALqRqe/M68hBsIfT6KsUFm3nBD/4xUf4hvOiIySwptzUWYliVSoPHqhEq8L122oAEG1i5Yg8kQUUJZQ==} dependencies: - '@unocss/core': 0.53.5 + '@unocss/core': 0.53.4 dev: true - /@unocss/inspector@0.53.5: - resolution: {integrity: sha512-gWUhgsoB3LyjIAdw6n/eMcLGmUNwuSTrgwcRubIDFhHOC5/E6ppdUQmS8a4oH4qjunfvBgoTHwcGlXvlvb3S5w==} + /@unocss/inspector@0.53.4: + resolution: {integrity: sha512-PW5+dAYKCipOmqtT3W407JZmjswcxQvifFEzdamhxjYrH0aFi5xhbH4PX5ArXeywebdg6inm343K0Gg/4I6GuA==} dependencies: gzip-size: 6.0.0 sirv: 2.0.3 dev: true - /@unocss/postcss@0.53.5(postcss@8.4.25): - resolution: {integrity: sha512-IfZl4GxrpegP/861bp3e0X3VcQJ9/M3VxC9UQ7zzxkOz/E8R09iMpbnznVLrTiLp2r96p5k/ggXLoadFm1FxGA==} + /@unocss/postcss@0.53.4(postcss@8.4.24): + resolution: {integrity: sha512-G7ZWqUszJiXrQVOzLBzOFZwGIVGwH695lE75NufQi8tXQF9QphGKT0t7AX1NRxA3IZpZW2Twxa/tZYRh2PJQAg==} engines: {node: '>=14'} peerDependencies: postcss: ^8.4.21 dependencies: - '@unocss/config': 0.53.5 - '@unocss/core': 0.53.5 + '@unocss/config': 0.53.4 + '@unocss/core': 0.53.4 css-tree: 2.3.1 fast-glob: 3.3.0 magic-string: 0.30.1 - postcss: 8.4.25 + postcss: 8.4.24 dev: true - /@unocss/preset-attributify@0.53.5: - resolution: {integrity: sha512-0TJD9hVUWu0T4dtdURApyFiliqbckYYGZe2PZBgUrHCypbI0zq7k3MdXFYmIuYxqDPErJVm8rO9lwMpKfTsvuA==} + /@unocss/preset-attributify@0.53.4: + resolution: {integrity: sha512-/lYH0SHFEkROOMHJ5td3txHnR93RRt/ZtsJ4brH3ptJixiEiShl5oNGS8cHBV/jV/KYsBW4gqeVomzUGCGWu9w==} dependencies: - '@unocss/core': 0.53.5 + '@unocss/core': 0.53.4 dev: true - /@unocss/preset-icons@0.53.5: - resolution: {integrity: sha512-zlO0fLJiJtITta3BnE3y5Yc0hajjovCB/woos4MR5gvcFXHW9Hfy7pXuj90GvHLfaRj0JRWXa1WRaqJXS4tzOw==} + /@unocss/preset-icons@0.53.4: + resolution: {integrity: sha512-PSc1svzDq/o7lKLrZohFIMf0ZqOypYdBY1Wvfp+Gd6Zc4uybnCTVme3pnlgYIcjSO24ilt/PeWgx3SxD8ypMcw==} dependencies: '@iconify/utils': 2.1.7 - '@unocss/core': 0.53.5 + '@unocss/core': 0.53.4 ofetch: 1.1.1 transitivePeerDependencies: - supports-color dev: true - /@unocss/preset-mini@0.53.5: - resolution: {integrity: sha512-aeVctTW0M41RXyCyQvhRawIh+ylhl7mlWfAjv7cP3ALvIRWbB6jUw1C8Ke6rU2vg0s0yaJKRuFPFmLMqGwzoSg==} + /@unocss/preset-mini@0.53.4: + resolution: {integrity: sha512-m9SMA9m1VhC0xAXtw07lke9GltuLTZONWlad79KkYi/2YaywZsJAk8Y4+MVo4B4azh1Jxz2LOtEEBgqIYhbqJg==} dependencies: - '@unocss/core': 0.53.5 - '@unocss/extractor-arbitrary-variants': 0.53.5 + '@unocss/core': 0.53.4 + '@unocss/extractor-arbitrary-variants': 0.53.4 dev: true - /@unocss/preset-tagify@0.53.5: - resolution: {integrity: sha512-0HpWU85Pz1RbFqf/QtlP992ISSqWZ3JT2rWI7ekBLai463ptdBUks/PfH22M+uBSwPig5XNJ0DtyS7hm8TEWhg==} + /@unocss/preset-tagify@0.53.4: + resolution: {integrity: sha512-ucdYjSdop2MZcnZ56+ViQweVaZatYaAAnD33C++nJn8d/GK2e96PHZJjtpq5/Oh00izr7/5bQJ5c4uhKAmSmUA==} dependencies: - '@unocss/core': 0.53.5 + '@unocss/core': 0.53.4 dev: true - /@unocss/preset-typography@0.53.5: - resolution: {integrity: sha512-roZXiJ14wuXcpLN5YodAN1wKYlwCDJ8L/TQlUphyM487i0QbKwXAZg8dA1SWCQIl5V9Qcq/3EXAQmLnhRdwBMA==} + /@unocss/preset-typography@0.53.4: + resolution: {integrity: sha512-I15PCD7gomoewyub8iVt7x6hCXiPk/2Qt6QeWC4r0UgSq8wtQQlHm2T9E6jv03F00ISwMB5VYYivnHOxnrmm8w==} dependencies: - '@unocss/core': 0.53.5 - '@unocss/preset-mini': 0.53.5 + '@unocss/core': 0.53.4 + '@unocss/preset-mini': 0.53.4 dev: true - /@unocss/preset-uno@0.53.5: - resolution: {integrity: sha512-DRJMBkSqfz0EOzf5cwefkPF8J6lNvrhBp4ztw9blewDc2wTQqL/lAj/I/nbyOdXhJUOxhj/qj7gJjsNZctud0A==} + /@unocss/preset-uno@0.53.4: + resolution: {integrity: sha512-3VWdc0kOZnOO1HGHwVbIzRjUvn4IfxZPwdohgCpISeUCIGI1ohYRsrzlJgSrHXD4BmD9UInRZHymb1ytrKRLgA==} dependencies: - '@unocss/core': 0.53.5 - '@unocss/preset-mini': 0.53.5 - '@unocss/preset-wind': 0.53.5 + '@unocss/core': 0.53.4 + '@unocss/preset-mini': 0.53.4 + '@unocss/preset-wind': 0.53.4 dev: true - /@unocss/preset-web-fonts@0.53.5: - resolution: {integrity: sha512-yVkOOECyOQqahRGSefcBKtNYAUnYFqqFedGy0SBBjadPWn80vjVg7ojljKlJsgSQdrpcJ38wwWr3Oh4UWwBuQQ==} + /@unocss/preset-web-fonts@0.53.4: + resolution: {integrity: sha512-4qqhUjzP5NbLNnRU9WaN2SLBjwY+qtvN4JN2vKD1o9HOPauIzGWq3SyaR8VoviQ9D8vg/L80Fl/pqGAvV/xvaw==} dependencies: - '@unocss/core': 0.53.5 + '@unocss/core': 0.53.4 ofetch: 1.1.1 dev: true - /@unocss/preset-wind@0.53.5: - resolution: {integrity: sha512-hSMF11Gx8oMDtePvXLmpArSNpQRHb098P8+qYpwvyNfS29i6agfjGBuIDk/f+j8mhqcfrEEuEmPIl2yojT9nxA==} + /@unocss/preset-wind@0.53.4: + resolution: {integrity: sha512-8PF3wZW8MvzjN562wOCfZzxlhqyd9f4Ay/wQborYY+P3BfIm5ORZ6GIdXsA7do+CE+yXytQ5NmtkBdd5eHdMdA==} dependencies: - '@unocss/core': 0.53.5 - '@unocss/preset-mini': 0.53.5 + '@unocss/core': 0.53.4 + '@unocss/preset-mini': 0.53.4 dev: true - /@unocss/reset@0.53.5: - resolution: {integrity: sha512-tH8K4jw76mbWA67UUHKV6zxiwOsiG+byrHoG3lz8hr+cm6OgEJ3WjNNp7dZINmr7S7ylWO6igbxGQpsAuIQZCw==} + /@unocss/reset@0.53.4: + resolution: {integrity: sha512-NMqntd9CE9EpdtI2ELGCZg9Z2ySMdo/ljepP8QwfRmWbYaXUf3T/GJsOTqewbhNgJUGYinbs1OtiN0yG5xZjJQ==} dev: true - /@unocss/scope@0.53.5: - resolution: {integrity: sha512-KBwemWNJIbu3+BWp0X4o5ERN0/nzF7hXBnjYNSb0s8phrydC6oJrp52XYlIHHTe7O4KzwkqGgf/xOMXMFpviDg==} + /@unocss/scope@0.53.4: + resolution: {integrity: sha512-vomyjd6i27V5G2awPoo9FoUit6qYyDyO0kroLzYPPNgq5M5jQFrZuQYc24dQ+JeJAQ3hlCGl8VM2v3Aj0PyUFg==} dev: true - /@unocss/transformer-attributify-jsx-babel@0.53.5: - resolution: {integrity: sha512-z9ar2IaZmcNVTZhK9ZuRUd3LqA/iUG/JMF0OA92RNclo8SazWdu7eJAdV86SHXqAf7eSB/t0evsde14DtEREjA==} + /@unocss/transformer-attributify-jsx-babel@0.53.4: + resolution: {integrity: sha512-XR+u21GoZsdUDZXMgToH087uJCPJMIGLEv+ISb3fE40wOTiah+4wzTSjJpjzj8ReNG9lvrw5H6NBQcX0db1XCQ==} dependencies: - '@unocss/core': 0.53.5 + '@unocss/core': 0.53.4 dev: true - /@unocss/transformer-attributify-jsx@0.53.5: - resolution: {integrity: sha512-ynAElIi9DxtHyKCW+OXPcLxje2ghVzKo80eaAVRAdVpyawsjtE4iHWjHRbESkiTsHW5CiJupdXo2vx1obXFLnQ==} + /@unocss/transformer-attributify-jsx@0.53.4: + resolution: {integrity: sha512-JYhwv3bZnFldXLfNKq7bmOLqNkFbvG/FyCojUz9G8+oj9jhQicwE33hDGddtbmoBUO660sBtqqLOtp8DlIY/oA==} dependencies: - '@unocss/core': 0.53.5 + '@unocss/core': 0.53.4 dev: true - /@unocss/transformer-compile-class@0.53.5: - resolution: {integrity: sha512-7Z0/40T4EuHMGpXb2XlamkResaASMRm07csCl7REGUTg9ccDRWlnSLzGD8UUgKoygsmqXp2cxKMJLMb5YJ9LLA==} + /@unocss/transformer-compile-class@0.53.4: + resolution: {integrity: sha512-Eq9dD7eWbhNpOF5WY69uYtfGSKlBWjTN2+m+KpOBvtxwe++VIHoRXHwDWC0gKEPaWTvhfRa+RdSCXVRLOygYFg==} dependencies: - '@unocss/core': 0.53.5 + '@unocss/core': 0.53.4 dev: true - /@unocss/transformer-directives@0.53.5: - resolution: {integrity: sha512-u1OIZZUAXux9Q0mb58X3infxY2Iq6pY7uJB7IhMc2I1ntpyx875spwyvvfUHqOgIPTNR4XxfxKFGPHpjPNbNeQ==} + /@unocss/transformer-directives@0.53.4: + resolution: {integrity: sha512-21dCt3u0WHqXFMfRkkPgjKGyDtghhqItCInr/vB9uKnJFLUdFWlqJu/wRHCUDVypeykwtaLVeCPwpvphCP+VHg==} dependencies: - '@unocss/core': 0.53.5 + '@unocss/core': 0.53.4 css-tree: 2.3.1 dev: true - /@unocss/transformer-variant-group@0.53.5: - resolution: {integrity: sha512-+xDx6JojGkcKwx87sX0y4xM/RuTI0QyPJAKebXUSyuKnctXrTH/p+WNGFIVWiY8suUMnnMesAZpw6O2Oln921w==} + /@unocss/transformer-variant-group@0.53.4: + resolution: {integrity: sha512-ir3FMZV1PQ1oUZU0mYTZ5kIrsn68vwUJtOiCcqq2XMSAM4NK8EBdqRqd0mg7he3AjhPzd//Rdx8XpfVFbw7EVw==} dependencies: - '@unocss/core': 0.53.5 + '@unocss/core': 0.53.4 dev: true - /@unocss/vite@0.53.5(rollup@2.79.1)(vite@4.4.3): - resolution: {integrity: sha512-ez0MVRatewLUQq79LI+XRAVRbXWaGbK1K1ht2B8vGyL9OrL6uieEwzxjHV7+rUa8i+FEHfD4Ntmtdpb3WuQSAA==} + /@unocss/vite@0.53.4(rollup@2.79.1)(vite@4.3.9): + resolution: {integrity: sha512-s2t7Es2L788MSyPAJUksUaiTLBGyISiyESelyGxBwDpAR6ddHiKB9LU2MVLTU289rmnhebWHFvw7lbE+Trs/Dw==} peerDependencies: vite: ^2.9.0 || ^3.0.0-0 || ^4.0.0 dependencies: '@ampproject/remapping': 2.2.1 '@rollup/pluginutils': 5.0.2(rollup@2.79.1) - '@unocss/config': 0.53.5 - '@unocss/core': 0.53.5 - '@unocss/inspector': 0.53.5 - '@unocss/scope': 0.53.5 - '@unocss/transformer-directives': 0.53.5 + '@unocss/config': 0.53.4 + '@unocss/core': 0.53.4 + '@unocss/inspector': 0.53.4 + '@unocss/scope': 0.53.4 + '@unocss/transformer-directives': 0.53.4 chokidar: 3.5.3 fast-glob: 3.3.0 magic-string: 0.30.1 - vite: 4.4.3(@types/node@18.16.19) + vite: 4.3.9(@types/node@18.16.19) transitivePeerDependencies: - rollup dev: true - /@unocss/vite@0.53.5(rollup@3.26.2)(vite@4.4.3): - resolution: {integrity: sha512-ez0MVRatewLUQq79LI+XRAVRbXWaGbK1K1ht2B8vGyL9OrL6uieEwzxjHV7+rUa8i+FEHfD4Ntmtdpb3WuQSAA==} + /@unocss/vite@0.53.4(rollup@3.26.0)(vite@4.3.9): + resolution: {integrity: sha512-s2t7Es2L788MSyPAJUksUaiTLBGyISiyESelyGxBwDpAR6ddHiKB9LU2MVLTU289rmnhebWHFvw7lbE+Trs/Dw==} peerDependencies: vite: ^2.9.0 || ^3.0.0-0 || ^4.0.0 dependencies: '@ampproject/remapping': 2.2.1 - '@rollup/pluginutils': 5.0.2(rollup@3.26.2) - '@unocss/config': 0.53.5 - '@unocss/core': 0.53.5 - '@unocss/inspector': 0.53.5 - '@unocss/scope': 0.53.5 - '@unocss/transformer-directives': 0.53.5 + '@rollup/pluginutils': 5.0.2(rollup@3.26.0) + '@unocss/config': 0.53.4 + '@unocss/core': 0.53.4 + '@unocss/inspector': 0.53.4 + '@unocss/scope': 0.53.4 + '@unocss/transformer-directives': 0.53.4 chokidar: 3.5.3 fast-glob: 3.3.0 magic-string: 0.30.1 - vite: 4.4.3(@types/node@18.16.19) + vite: 4.3.9(@types/node@18.16.19) transitivePeerDependencies: - rollup dev: true @@ -8522,8 +9496,8 @@ packages: dependencies: cac: 6.7.14 colorette: 2.0.20 - consola: 3.2.3 - sharp: 0.32.2 + consola: 3.1.0 + sharp: 0.32.1 sharp-ico: 0.1.5 unconfig: 0.3.9 dev: true @@ -8533,18 +9507,18 @@ packages: peerDependencies: vite-plugin-pwa: '>=0.16.3 <1' dependencies: - vite-plugin-pwa: 0.16.4(vite@4.4.3)(workbox-build@7.0.0)(workbox-window@7.0.0) + vite-plugin-pwa: 0.16.4(vite@4.3.9)(workbox-build@7.0.0)(workbox-window@7.0.0) dev: true /@vitejs/plugin-react@1.3.2: resolution: {integrity: sha512-aurBNmMo0kz1O4qRoY+FM4epSA39y3ShWGuqfLRA/3z0oEJAdtoSfgA3aO98/PCCHAqMaduLxIxErWrVKIFzXA==} engines: {node: '>=12.0.0'} dependencies: - '@babel/core': 7.22.8 - '@babel/plugin-transform-react-jsx': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-react-jsx-development': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-react-jsx-self': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-react-jsx-source': 7.22.5(@babel/core@7.22.8) + '@babel/core': 7.22.5 + '@babel/plugin-transform-react-jsx': 7.18.10(@babel/core@7.22.5) + '@babel/plugin-transform-react-jsx-development': 7.18.6(@babel/core@7.22.5) + '@babel/plugin-transform-react-jsx-self': 7.22.5(@babel/core@7.22.5) + '@babel/plugin-transform-react-jsx-source': 7.22.5(@babel/core@7.22.5) '@rollup/pluginutils': 4.2.1 react-refresh: 0.13.0 resolve: 1.22.2 @@ -8552,56 +9526,56 @@ packages: - supports-color dev: true - /@vitejs/plugin-react@4.0.3(vite@4.4.3): + /@vitejs/plugin-react@4.0.3(vite@4.3.9): resolution: {integrity: sha512-pwXDog5nwwvSIzwrvYYmA2Ljcd/ZNlcsSG2Q9CNDBwnsd55UGAyr2doXtB5j+2uymRCnCfExlznzzSFbBRcoCg==} engines: {node: ^14.18.0 || >=16.0.0} peerDependencies: vite: ^4.2.0 dependencies: - '@babel/core': 7.22.8 - '@babel/plugin-transform-react-jsx-self': 7.22.5(@babel/core@7.22.8) - '@babel/plugin-transform-react-jsx-source': 7.22.5(@babel/core@7.22.8) + '@babel/core': 7.22.5 + '@babel/plugin-transform-react-jsx-self': 7.22.5(@babel/core@7.22.5) + '@babel/plugin-transform-react-jsx-source': 7.22.5(@babel/core@7.22.5) react-refresh: 0.14.0 - vite: 4.4.3(@types/node@20.4.1) + vite: 4.3.9(@types/node@20.4.1) transitivePeerDependencies: - supports-color dev: true - /@vitejs/plugin-vue-jsx@3.0.1(vite@4.4.3)(vue@3.3.4): + /@vitejs/plugin-vue-jsx@3.0.1(vite@4.3.9)(vue@3.3.4): resolution: {integrity: sha512-+Jb7ggL48FSPS1uhPnJbJwWa9Sr90vQ+d0InW+AhBM22n+cfuYqJZDckBc+W3QSHe1WDvewMZfa4wZOtk5pRgw==} engines: {node: ^14.18.0 || >=16.0.0} peerDependencies: vite: ^4.0.0 vue: ^3.0.0 dependencies: - '@babel/core': 7.22.8 - '@babel/plugin-transform-typescript': 7.22.5(@babel/core@7.22.8) - '@vue/babel-plugin-jsx': 1.1.5(@babel/core@7.22.8) - vite: 4.4.3(@types/node@18.16.19) + '@babel/core': 7.22.5 + '@babel/plugin-transform-typescript': 7.21.3(@babel/core@7.22.5) + '@vue/babel-plugin-jsx': 1.1.1(@babel/core@7.22.5) + vite: 4.3.9(@types/node@18.16.19) vue: 3.3.4 transitivePeerDependencies: - supports-color dev: true - /@vitejs/plugin-vue2@1.1.2(vite@4.4.3)(vue@2.7.14): + /@vitejs/plugin-vue2@1.1.2(vite@4.3.9)(vue@2.7.10): resolution: {integrity: sha512-y6OEA+2UdJ0xrEQHodq20v9r3SpS62IOHrgN92JPLvVpNkhcissu7yvD5PXMzMESyazj0XNWGsc8UQk8+mVrjQ==} engines: {node: '>=14.6.0'} peerDependencies: vite: '>=2.5.10' vue: ^2.7.0-0 dependencies: - vite: 4.4.3(@types/node@18.16.19) - vue: 2.7.14 + vite: 4.3.9(@types/node@18.16.19) + vue: 2.7.10 dev: true - /@vitejs/plugin-vue@4.2.3(vite@4.4.3)(vue@3.3.4): + /@vitejs/plugin-vue@4.2.3(vite@4.3.9)(vue@3.3.4): resolution: {integrity: sha512-R6JDUfiZbJA9cMiguQ7jxALsgiprjBeHL5ikpXfJCH62pPHtI+JdJ5xWj6Ev73yXSlYl86+blXn1kZHQ7uElxw==} engines: {node: ^14.18.0 || >=16.0.0} peerDependencies: vite: ^4.0.0 vue: ^3.2.25 dependencies: - vite: 4.4.3(@types/node@18.16.19) + vite: 4.3.9(@types/node@18.16.19) vue: 3.3.4 dev: true @@ -8620,7 +9594,7 @@ packages: /@volar/typescript-faster@0.40.13: resolution: {integrity: sha512-uy+TlcFkKoNlKEnxA4x5acxdxLyVDIXGSc8cYDNXpPKjBKXrQaetzCzlO3kVBqu1VLMxKNGJMTKn35mo+ILQmw==} dependencies: - semver: 7.5.4 + semver: 7.5.2 dev: true /@volar/vue-language-core@0.40.13: @@ -8643,54 +9617,80 @@ packages: '@volar/vue-language-core': 0.40.13 dev: true - /@vue/babel-helper-vue-transform-on@1.1.5: - resolution: {integrity: sha512-SgUymFpMoAyWeYWLAY+MkCK3QEROsiUnfaw5zxOVD/M64KQs8D/4oK6Q5omVA2hnvEOE0SCkH2TZxs/jnnUj7w==} + /@vue/babel-helper-vue-transform-on@1.0.2: + resolution: {integrity: sha512-hz4R8tS5jMn8lDq6iD+yWL6XNB699pGIVLk7WSJnn1dbpjaazsjZQkieJoRX6gW5zpYSCFqQ7jUquPNY65tQYA==} dev: true - /@vue/babel-plugin-jsx@1.1.5(@babel/core@7.22.8): - resolution: {integrity: sha512-nKs1/Bg9U1n3qSWnsHhCVQtAzI6aQXqua8j/bZrau8ywT1ilXQbK4FwEJGmU8fV7tcpuFvWmmN7TMmV1OBma1g==} - peerDependencies: - '@babel/core': ^7.0.0-0 + /@vue/babel-plugin-jsx@1.1.1(@babel/core@7.22.5): + resolution: {integrity: sha512-j2uVfZjnB5+zkcbc/zsOc0fSNGCMMjaEXP52wdwdIfn0qjFfEYpYZBFKFg+HHnQeJCVrjOeO0YxgaL7DMrym9w==} dependencies: - '@babel/core': 7.22.8 '@babel/helper-module-imports': 7.22.5 - '@babel/plugin-syntax-jsx': 7.22.5(@babel/core@7.22.8) + '@babel/plugin-syntax-jsx': 7.18.6(@babel/core@7.22.5) '@babel/template': 7.22.5 - '@babel/traverse': 7.22.8 + '@babel/traverse': 7.22.5 '@babel/types': 7.22.5 - '@vue/babel-helper-vue-transform-on': 1.1.5 + '@vue/babel-helper-vue-transform-on': 1.0.2 camelcase: 6.3.0 - html-tags: 3.3.1 + html-tags: 3.2.0 svg-tags: 1.0.0 transitivePeerDependencies: + - '@babel/core' - supports-color dev: true + /@vue/compiler-core@3.2.39: + resolution: {integrity: sha512-mf/36OWXqWn0wsC40nwRRGheR/qoID+lZXbIuLnr4/AngM0ov8Xvv8GHunC0rKRIkh60bTqydlqTeBo49rlbqw==} + dependencies: + '@babel/parser': 7.22.5 + '@vue/shared': 3.2.39 + estree-walker: 2.0.2 + source-map: 0.6.1 + /@vue/compiler-core@3.3.4: resolution: {integrity: sha512-cquyDNvZ6jTbf/+x+AgM2Arrp6G4Dzbb0R64jiG804HRMfRiFXWI6kqUVqZ6ZR0bQhIoQjB4+2bhNtVwndW15g==} dependencies: - '@babel/parser': 7.22.7 + '@babel/parser': 7.22.5 '@vue/shared': 3.3.4 estree-walker: 2.0.2 source-map-js: 1.0.2 + /@vue/compiler-dom@3.2.39: + resolution: {integrity: sha512-HMFI25Be1C8vLEEv1hgEO1dWwG9QQ8LTTPmCkblVJY/O3OvWx6r1+zsox5mKPMGvqYEZa6l8j+xgOfUspgo7hw==} + dependencies: + '@vue/compiler-core': 3.2.39 + '@vue/shared': 3.2.39 + /@vue/compiler-dom@3.3.4: resolution: {integrity: sha512-wyM+OjOVpuUukIq6p5+nwHYtj9cFroz9cwkfmP9O1nzH68BenTTv0u7/ndggT8cIQlnBeOo6sUT/gvHcIkLA5w==} dependencies: '@vue/compiler-core': 3.3.4 '@vue/shared': 3.3.4 - /@vue/compiler-sfc@2.7.14: - resolution: {integrity: sha512-aNmNHyLPsw+sVvlQFQ2/8sjNuLtK54TC6cuKnVzAY93ks4ZBrvwQSnkkIh7bsbNhum5hJBS00wSDipQ937f5DA==} + /@vue/compiler-sfc@2.7.10: + resolution: {integrity: sha512-55Shns6WPxlYsz4WX7q9ZJBL77sKE1ZAYNYStLs6GbhIOMrNtjMvzcob6gu3cGlfpCR4bT7NXgyJ3tly2+Hx8Q==} + dependencies: + '@babel/parser': 7.22.5 + postcss: 8.4.24 + source-map: 0.6.1 + + /@vue/compiler-sfc@3.2.39: + resolution: {integrity: sha512-fqAQgFs1/BxTUZkd0Vakn3teKUt//J3c420BgnYgEOoVdTwYpBTSXCMJ88GOBCylmUBbtquGPli9tVs7LzsWIA==} dependencies: - '@babel/parser': 7.22.7 - postcss: 8.4.25 + '@babel/parser': 7.22.5 + '@vue/compiler-core': 3.2.39 + '@vue/compiler-dom': 3.2.39 + '@vue/compiler-ssr': 3.2.39 + '@vue/reactivity-transform': 3.2.39 + '@vue/shared': 3.2.39 + estree-walker: 2.0.2 + magic-string: 0.25.9 + postcss: 8.4.24 source-map: 0.6.1 /@vue/compiler-sfc@3.3.4: resolution: {integrity: sha512-6y/d8uw+5TkCuzBkgLS0v3lSM3hJDntFEiUORM11pQ/hKvkhSKZrXW6i69UyXlJQisJxuUEJKAWEqWbWsLeNKQ==} dependencies: - '@babel/parser': 7.22.7 + '@babel/parser': 7.22.5 '@vue/compiler-core': 3.3.4 '@vue/compiler-dom': 3.3.4 '@vue/compiler-ssr': 3.3.4 @@ -8698,9 +9698,15 @@ packages: '@vue/shared': 3.3.4 estree-walker: 2.0.2 magic-string: 0.30.1 - postcss: 8.4.25 + postcss: 8.4.24 source-map-js: 1.0.2 + /@vue/compiler-ssr@3.2.39: + resolution: {integrity: sha512-EoGCJ6lincKOZGW+0Ky4WOKsSmqL7hp1ZYgen8M7u/mlvvEQUaO9tKKOy7K43M9U2aA3tPv0TuYYQFrEbK2eFQ==} + dependencies: + '@vue/compiler-dom': 3.2.39 + '@vue/shared': 3.2.39 + /@vue/compiler-ssr@3.3.4: resolution: {integrity: sha512-m0v6oKpup2nMSehwA6Uuu+j+wEwcy7QmwMkVNVfrV9P2qE5KshC6RwOCq8fjGS/Eak/uNb8AaWekfiXxbBB6gQ==} dependencies: @@ -8711,10 +9717,19 @@ packages: resolution: {integrity: sha512-o9KfBeaBmCKl10usN4crU53fYtC1r7jJwdGKjPT24t348rHxgfpZ0xL3Xm/gLUYnc0oTp8LAmrxOeLyu6tbk2Q==} dev: true + /@vue/reactivity-transform@3.2.39: + resolution: {integrity: sha512-HGuWu864zStiWs9wBC6JYOP1E00UjMdDWIG5W+FpUx28hV3uz9ODOKVNm/vdOy/Pvzg8+OcANxAVC85WFBbl3A==} + dependencies: + '@babel/parser': 7.22.5 + '@vue/compiler-core': 3.2.39 + '@vue/shared': 3.2.39 + estree-walker: 2.0.2 + magic-string: 0.25.9 + /@vue/reactivity-transform@3.3.4: resolution: {integrity: sha512-MXgwjako4nu5WFLAjpBnCj/ieqcjE2aJBINUNQzkZQfzIZA4xn+0fV1tIYBJvvva3N3OvKGofRLvQIwEQPpaXw==} dependencies: - '@babel/parser': 7.22.7 + '@babel/parser': 7.22.5 '@vue/compiler-core': 3.3.4 '@vue/shared': 3.3.4 estree-walker: 2.0.2 @@ -8726,17 +9741,35 @@ packages: '@vue/shared': 3.2.38 dev: true + /@vue/reactivity@3.2.39: + resolution: {integrity: sha512-vlaYX2a3qMhIZfrw3Mtfd+BuU+TZmvDrPMa+6lpfzS9k/LnGxkSuf0fhkP0rMGfiOHPtyKoU9OJJJFGm92beVQ==} + dependencies: + '@vue/shared': 3.2.39 + /@vue/reactivity@3.3.4: resolution: {integrity: sha512-kLTDLwd0B1jG08NBF3R5rqULtv/f8x3rOFByTDz4J53ttIQEDmALqKqXY0J+XQeN0aV2FBxY8nJDf88yvOPAqQ==} dependencies: '@vue/shared': 3.3.4 + /@vue/runtime-core@3.2.39: + resolution: {integrity: sha512-xKH5XP57JW5JW+8ZG1khBbuLakINTgPuINKL01hStWLTTGFOrM49UfCFXBcFvWmSbci3gmJyLl2EAzCaZWsx8g==} + dependencies: + '@vue/reactivity': 3.2.39 + '@vue/shared': 3.2.39 + /@vue/runtime-core@3.3.4: resolution: {integrity: sha512-R+bqxMN6pWO7zGI4OMlmvePOdP2c93GsHFM/siJI7O2nxFRzj55pLwkpCedEY+bTMgp5miZ8CxfIZo3S+gFqvA==} dependencies: '@vue/reactivity': 3.3.4 '@vue/shared': 3.3.4 + /@vue/runtime-dom@3.2.39: + resolution: {integrity: sha512-4G9AEJP+sLhsqf5wXcyKVWQKUhI+iWfy0hWQgea+CpaTD7BR0KdQzvoQdZhwCY6B3oleSyNLkLAQwm0ya/wNoA==} + dependencies: + '@vue/runtime-core': 3.2.39 + '@vue/shared': 3.2.39 + csstype: 2.6.20 + /@vue/runtime-dom@3.3.4: resolution: {integrity: sha512-Aj5bTJ3u5sFsUckRghsNjVTtxZQ1OyMWCr5dZRAPijF/0Vy4xEoRCwLyHXcj4D0UFbJ4lbx3gPTgg06K/GnPnQ==} dependencies: @@ -8744,6 +9777,15 @@ packages: '@vue/shared': 3.3.4 csstype: 3.1.2 + /@vue/server-renderer@3.2.39(vue@3.2.39): + resolution: {integrity: sha512-1yn9u2YBQWIgytFMjz4f/t0j43awKytTGVptfd3FtBk76t1pd8mxbek0G/DrnjJhd2V7mSTb5qgnxMYt8Z5iSQ==} + peerDependencies: + vue: 3.2.39 + dependencies: + '@vue/compiler-ssr': 3.2.39 + '@vue/shared': 3.2.39 + vue: 3.2.39 + /@vue/server-renderer@3.3.4(vue@3.3.4): resolution: {integrity: sha512-Q6jDDzR23ViIb67v+vM1Dqntu+HUexQcsWKhhQa4ARVzxOY2HbC7QRW/ggkDBd5BU+uM1sV6XOAP0b216o34JQ==} peerDependencies: @@ -8757,11 +9799,14 @@ packages: resolution: {integrity: sha512-dTyhTIRmGXBjxJE+skC8tTWCGLCVc4wQgRRLt8+O9p5ewBAjoBwtCAkLPrtToSr1xltoe3st21Pv953aOZ7alg==} dev: true + /@vue/shared@3.2.39: + resolution: {integrity: sha512-D3dl2ZB9qE6mTuWPk9RlhDeP1dgNRUKC3NJxji74A4yL8M2MwlhLKUC/49WHjrNzSPug58fWx/yFbaTzGAQSBw==} + /@vue/shared@3.3.4: resolution: {integrity: sha512-7OjdcV8vQ74eiz1TZLzZP4JwqM5fA94K6yntPS5Z25r9HDuGNzaGdgvwKYq6S+MxwF0TFRwe50fIR/MYnakdkQ==} - /@vue/test-utils@1.3.6(vue-template-compiler@2.7.14)(vue@2.7.14): - resolution: {integrity: sha512-udMmmF1ts3zwxUJEIAj5ziioR900reDrt6C9H3XpWPsLBx2lpHKoA4BTdd9HNIYbkGltWw+JjWJ+5O6QBwiyEw==} + /@vue/test-utils@1.3.0(vue-template-compiler@2.7.10)(vue@2.7.10): + resolution: {integrity: sha512-Xk2Xiyj2k5dFb8eYUKkcN9PzqZSppTlx7LaQWBbdA8tqh3jHr/KHX2/YLhNFc/xwDrgeLybqd+4ZCPJSGPIqeA==} peerDependencies: vue: 2.x vue-template-compiler: ^2.x @@ -8769,8 +9814,24 @@ packages: dom-event-types: 1.1.0 lodash: 4.17.21 pretty: 2.0.0 - vue: 2.7.14 - vue-template-compiler: 2.7.14 + vue: 2.7.10 + vue-template-compiler: 2.7.10 + dev: true + + /@vue/test-utils@2.0.0(vue@3.3.4): + resolution: {integrity: sha512-zL5kygNq7hONrO1CzaUGprEAklAX+pH8J1MPMCU3Rd2xtSYkZ+PmKU3oEDRg8VAGdL5lNJHzDgrud5amFPtirw==} + peerDependencies: + vue: ^3.0.1 + dependencies: + vue: 3.3.4 + dev: true + + /@vue/test-utils@2.0.2(vue@3.3.4): + resolution: {integrity: sha512-E2P4oXSaWDqTZNbmKZFVLrNN/siVN78YkEqs7pHryWerrlZR9bBFLWdJwRoguX45Ru6HxIflzKl4vQvwRMwm5g==} + peerDependencies: + vue: ^3.0.1 + dependencies: + vue: 3.3.4 dev: true /@vue/test-utils@2.4.0(vue@3.3.4): @@ -8801,7 +9862,7 @@ packages: - '@vue/composition-api' - vue - /@vueuse/core@8.9.4(vue@3.3.4): + /@vueuse/core@8.9.4(vue@3.2.39): resolution: {integrity: sha512-B/Mdj9TK1peFyWaPof+Zf/mP9XuGAngaJZBwPaXBvU3aCTZlx3ltlrFFFyMV4iGBwsjSCeUCgZrtkEj9dS2Y3Q==} peerDependencies: '@vue/composition-api': ^1.1.0 @@ -8814,12 +9875,12 @@ packages: dependencies: '@types/web-bluetooth': 0.0.14 '@vueuse/metadata': 8.9.4 - '@vueuse/shared': 8.9.4(vue@3.3.4) - vue: 3.3.4 - vue-demi: 0.14.5(vue@3.3.4) + '@vueuse/shared': 8.9.4(vue@3.2.39) + vue: 3.2.39 + vue-demi: 0.14.0(vue@3.2.39) dev: false - /@vueuse/integrations@10.2.1(focus-trap@7.5.2)(vue@3.3.4): + /@vueuse/integrations@10.2.1(focus-trap@7.4.3)(vue@3.3.4): resolution: {integrity: sha512-FDP5lni+z9FjHE9H3xuvwSjoRV9U8jmDvJpmHPCBjUgPGYRynwb60eHWXCFJXLUtb4gSIHy0e+iaEbrKdalCkQ==} peerDependencies: async-validator: '*' @@ -8862,14 +9923,14 @@ packages: dependencies: '@vueuse/core': 10.2.1(vue@3.3.4) '@vueuse/shared': 10.2.1(vue@3.3.4) - focus-trap: 7.5.2 + focus-trap: 7.4.3 vue-demi: 0.14.5(vue@3.3.4) transitivePeerDependencies: - '@vue/composition-api' - vue dev: true - /@vueuse/integrations@8.9.4(axios@0.26.1)(vue@3.3.4): + /@vueuse/integrations@8.9.4(axios@0.26.1)(vue@3.2.39): resolution: {integrity: sha512-Nk7mH0ThTdiuiiuB+1lyC+5ihnywrr+9h9IA4R4Ry8Mli/cZL38zc3qZWIsCVPm66Lr+7kEp3nnHdSxKi7ivrg==} peerDependencies: async-validator: '*' @@ -8904,10 +9965,10 @@ packages: universal-cookie: optional: true dependencies: - '@vueuse/core': 8.9.4(vue@3.3.4) - '@vueuse/shared': 8.9.4(vue@3.3.4) + '@vueuse/core': 8.9.4(vue@3.2.39) + '@vueuse/shared': 8.9.4(vue@3.2.39) axios: 0.26.1 - vue-demi: 0.14.5(vue@3.3.4) + vue-demi: 0.13.11(vue@3.2.39) transitivePeerDependencies: - '@vue/composition-api' - vue @@ -8928,7 +9989,7 @@ packages: - '@vue/composition-api' - vue - /@vueuse/shared@8.9.4(vue@3.3.4): + /@vueuse/shared@8.9.4(vue@3.2.39): resolution: {integrity: sha512-wt+T30c4K6dGRMVqPddexEVLa28YwxW5OFIPmzUHICjphfAuBFTTdDoyqREZNDOFJZ44ARH1WWQNCUK8koJ+Ag==} peerDependencies: '@vue/composition-api': ^1.1.0 @@ -8939,8 +10000,8 @@ packages: vue: optional: true dependencies: - vue: 3.3.4 - vue-demi: 0.14.5(vue@3.3.4) + vue: 3.2.39 + vue-demi: 0.14.0(vue@3.2.39) dev: false /@wdio/config@8.12.1: @@ -8951,8 +10012,8 @@ packages: '@wdio/types': 8.10.4 '@wdio/utils': 8.12.1 decamelize: 6.0.0 - deepmerge-ts: 5.1.0 - glob: 10.3.3 + deepmerge-ts: 5.0.0 + glob: 10.2.7 import-meta-resolve: 3.0.0 read-pkg-up: 9.1.0 dev: true @@ -8961,7 +10022,7 @@ packages: resolution: {integrity: sha512-IsuKSaYi7NKEdgA57h8muzlN/MVp1dQG+V4C//7g4m03YJUnNQLvDhJzLjdeNTfvZy61U7foQSyt+3ktNzZkXA==} engines: {node: ^16.13 || >=18} dependencies: - chalk: 5.3.0 + chalk: 5.2.0 loglevel: 1.8.1 loglevel-plugin-prefix: 0.8.4 strip-ansi: 7.1.0 @@ -8995,11 +10056,11 @@ packages: p-iteration: 1.1.8 dev: true - /@webassemblyjs/ast@1.11.6: - resolution: {integrity: sha512-IN1xI7PwOvLPgjcf180gC1bqn3q/QaOCwYUahIOhbYUu8KA/3tw2RT/T0Gidi1l7Hhj5D/INhJxiICObqpMu4Q==} + /@webassemblyjs/ast@1.11.1: + resolution: {integrity: sha512-ukBh14qFLjxTQNTXocdyksN5QdM28S1CxHt2rdskFyL+xFV7VremuBLVbmCePj+URalXBENx/9Lm7lnhihtCSw==} dependencies: - '@webassemblyjs/helper-numbers': 1.11.6 - '@webassemblyjs/helper-wasm-bytecode': 1.11.6 + '@webassemblyjs/helper-numbers': 1.11.1 + '@webassemblyjs/helper-wasm-bytecode': 1.11.1 dev: true /@webassemblyjs/ast@1.9.0: @@ -9010,24 +10071,24 @@ packages: '@webassemblyjs/wast-parser': 1.9.0 dev: true - /@webassemblyjs/floating-point-hex-parser@1.11.6: - resolution: {integrity: sha512-ejAj9hfRJ2XMsNHk/v6Fu2dGS+i4UaXBXGemOfQ/JfQ6mdQg/WXtwleQRLLS4OvfDhv8rYnVwH27YJLMyYsxhw==} + /@webassemblyjs/floating-point-hex-parser@1.11.1: + resolution: {integrity: sha512-iGRfyc5Bq+NnNuX8b5hwBrRjzf0ocrJPI6GWFodBFzmFnyvrQ83SHKhmilCU/8Jv67i4GJZBMhEzltxzcNagtQ==} dev: true /@webassemblyjs/floating-point-hex-parser@1.9.0: resolution: {integrity: sha512-TG5qcFsS8QB4g4MhrxK5TqfdNe7Ey/7YL/xN+36rRjl/BlGE/NcBvJcqsRgCP6Z92mRE+7N50pRIi8SmKUbcQA==} dev: true - /@webassemblyjs/helper-api-error@1.11.6: - resolution: {integrity: sha512-o0YkoP4pVu4rN8aTJgAyj9hC2Sv5UlkzCHhxqWj8butaLvnpdc2jOwh4ewE6CX0txSfLn/UYaV/pheS2Txg//Q==} + /@webassemblyjs/helper-api-error@1.11.1: + resolution: {integrity: sha512-RlhS8CBCXfRUR/cwo2ho9bkheSXG0+NwooXcc3PAILALf2QLdFyj7KGsKRbVc95hZnhnERon4kW/D3SZpp6Tcg==} dev: true /@webassemblyjs/helper-api-error@1.9.0: resolution: {integrity: sha512-NcMLjoFMXpsASZFxJ5h2HZRcEhDkvnNFOAKneP5RbKRzaWJN36NC4jqQHKwStIhGXu5mUWlUUk7ygdtrO8lbmw==} dev: true - /@webassemblyjs/helper-buffer@1.11.6: - resolution: {integrity: sha512-z3nFzdcp1mb8nEOFFk8DrYLpHvhKC3grJD2ardfKOzmbmJvEf/tPIqCY+sNcwZIY8ZD7IkB2l7/pqhUhqm7hLA==} + /@webassemblyjs/helper-buffer@1.11.1: + resolution: {integrity: sha512-gwikF65aDNeeXa8JxXa2BAk+REjSyhrNC9ZwdT0f8jc4dQQeDQ7G4m0f2QCLPJiMTTO6wfDmRmj/pW0PsUvIcA==} dev: true /@webassemblyjs/helper-buffer@1.9.0: @@ -9050,29 +10111,29 @@ packages: '@webassemblyjs/ast': 1.9.0 dev: true - /@webassemblyjs/helper-numbers@1.11.6: - resolution: {integrity: sha512-vUIhZ8LZoIWHBohiEObxVm6hwP034jwmc9kuq5GdHZH0wiLVLIPcMCdpJzG4C11cHoQ25TFIQj9kaVADVX7N3g==} + /@webassemblyjs/helper-numbers@1.11.1: + resolution: {integrity: sha512-vDkbxiB8zfnPdNK9Rajcey5C0w+QJugEglN0of+kmO8l7lDb77AnlKYQF7aarZuCrv+l0UvqL+68gSDr3k9LPQ==} dependencies: - '@webassemblyjs/floating-point-hex-parser': 1.11.6 - '@webassemblyjs/helper-api-error': 1.11.6 + '@webassemblyjs/floating-point-hex-parser': 1.11.1 + '@webassemblyjs/helper-api-error': 1.11.1 '@xtuc/long': 4.2.2 dev: true - /@webassemblyjs/helper-wasm-bytecode@1.11.6: - resolution: {integrity: sha512-sFFHKwcmBprO9e7Icf0+gddyWYDViL8bpPjJJl0WHxCdETktXdmtWLGVzoHbqUcY4Be1LkNfwTmXOJUFZYSJdA==} + /@webassemblyjs/helper-wasm-bytecode@1.11.1: + resolution: {integrity: sha512-PvpoOGiJwXeTrSf/qfudJhwlvDQxFgelbMqtq52WWiXC6Xgg1IREdngmPN3bs4RoO83PnL/nFrxucXj1+BX62Q==} dev: true /@webassemblyjs/helper-wasm-bytecode@1.9.0: resolution: {integrity: sha512-R7FStIzyNcd7xKxCZH5lE0Bqy+hGTwS3LJjuv1ZVxd9O7eHCedSdrId/hMOd20I+v8wDXEn+bjfKDLzTepoaUw==} dev: true - /@webassemblyjs/helper-wasm-section@1.11.6: - resolution: {integrity: sha512-LPpZbSOwTpEC2cgn4hTydySy1Ke+XEu+ETXuoyvuyezHO3Kjdu90KK95Sh9xTbmjrCsUwvWwCOQQNta37VrS9g==} + /@webassemblyjs/helper-wasm-section@1.11.1: + resolution: {integrity: sha512-10P9No29rYX1j7F3EVPX3JvGPQPae+AomuSTPiF9eBQeChHI6iqjMIwR9JmOJXwpnn/oVGDk7I5IlskuMwU/pg==} dependencies: - '@webassemblyjs/ast': 1.11.6 - '@webassemblyjs/helper-buffer': 1.11.6 - '@webassemblyjs/helper-wasm-bytecode': 1.11.6 - '@webassemblyjs/wasm-gen': 1.11.6 + '@webassemblyjs/ast': 1.11.1 + '@webassemblyjs/helper-buffer': 1.11.1 + '@webassemblyjs/helper-wasm-bytecode': 1.11.1 + '@webassemblyjs/wasm-gen': 1.11.1 dev: true /@webassemblyjs/helper-wasm-section@1.9.0: @@ -9084,8 +10145,8 @@ packages: '@webassemblyjs/wasm-gen': 1.9.0 dev: true - /@webassemblyjs/ieee754@1.11.6: - resolution: {integrity: sha512-LM4p2csPNvbij6U1f19v6WR56QZ8JcHg3QIJTlSwzFcmx6WSORicYj6I63f9yU1kEUtrpG+kjkiIAkevHpDXrg==} + /@webassemblyjs/ieee754@1.11.1: + resolution: {integrity: sha512-hJ87QIPtAMKbFq6CGTkZYJivEwZDbQUgYd3qKSadTNOhVY7p+gfP6Sr0lLRVTaG1JjFj+r3YchoqRYxNH3M0GQ==} dependencies: '@xtuc/ieee754': 1.2.0 dev: true @@ -9096,8 +10157,8 @@ packages: '@xtuc/ieee754': 1.2.0 dev: true - /@webassemblyjs/leb128@1.11.6: - resolution: {integrity: sha512-m7a0FhE67DQXgouf1tbN5XQcdWoNgaAuoULHIfGFIEVKA6tu/edls6XnIlkmS6FrXAquJRPni3ZZKjw6FSPjPQ==} + /@webassemblyjs/leb128@1.11.1: + resolution: {integrity: sha512-BJ2P0hNZ0u+Th1YZXJpzW6miwqQUGcIHT1G/sf72gLVD9DZ5AdYTqPNbHZh6K1M5VmKvFXwGSWZADz+qBWxeRw==} dependencies: '@xtuc/long': 4.2.2 dev: true @@ -9108,25 +10169,25 @@ packages: '@xtuc/long': 4.2.2 dev: true - /@webassemblyjs/utf8@1.11.6: - resolution: {integrity: sha512-vtXf2wTQ3+up9Zsg8sa2yWiQpzSsMyXj0qViVP6xKGCUT8p8YJ6HqI7l5eCnWx1T/FYdsv07HQs2wTFbbof/RA==} + /@webassemblyjs/utf8@1.11.1: + resolution: {integrity: sha512-9kqcxAEdMhiwQkHpkNiorZzqpGrodQQ2IGrHHxCy+Ozng0ofyMA0lTqiLkVs1uzTRejX+/O0EOT7KxqVPuXosQ==} dev: true /@webassemblyjs/utf8@1.9.0: resolution: {integrity: sha512-GZbQlWtopBTP0u7cHrEx+73yZKrQoBMpwkGEIqlacljhXCkVM1kMQge/Mf+csMJAjEdSwhOyLAS0AoR3AG5P8w==} dev: true - /@webassemblyjs/wasm-edit@1.11.6: - resolution: {integrity: sha512-Ybn2I6fnfIGuCR+Faaz7YcvtBKxvoLV3Lebn1tM4o/IAJzmi9AWYIPWpyBfU8cC+JxAO57bk4+zdsTjJR+VTOw==} + /@webassemblyjs/wasm-edit@1.11.1: + resolution: {integrity: sha512-g+RsupUC1aTHfR8CDgnsVRVZFJqdkFHpsHMfJuWQzWU3tvnLC07UqHICfP+4XyL2tnr1amvl1Sdp06TnYCmVkA==} dependencies: - '@webassemblyjs/ast': 1.11.6 - '@webassemblyjs/helper-buffer': 1.11.6 - '@webassemblyjs/helper-wasm-bytecode': 1.11.6 - '@webassemblyjs/helper-wasm-section': 1.11.6 - '@webassemblyjs/wasm-gen': 1.11.6 - '@webassemblyjs/wasm-opt': 1.11.6 - '@webassemblyjs/wasm-parser': 1.11.6 - '@webassemblyjs/wast-printer': 1.11.6 + '@webassemblyjs/ast': 1.11.1 + '@webassemblyjs/helper-buffer': 1.11.1 + '@webassemblyjs/helper-wasm-bytecode': 1.11.1 + '@webassemblyjs/helper-wasm-section': 1.11.1 + '@webassemblyjs/wasm-gen': 1.11.1 + '@webassemblyjs/wasm-opt': 1.11.1 + '@webassemblyjs/wasm-parser': 1.11.1 + '@webassemblyjs/wast-printer': 1.11.1 dev: true /@webassemblyjs/wasm-edit@1.9.0: @@ -9142,14 +10203,14 @@ packages: '@webassemblyjs/wast-printer': 1.9.0 dev: true - /@webassemblyjs/wasm-gen@1.11.6: - resolution: {integrity: sha512-3XOqkZP/y6B4F0PBAXvI1/bky7GryoogUtfwExeP/v7Nzwo1QLcq5oQmpKlftZLbT+ERUOAZVQjuNVak6UXjPA==} + /@webassemblyjs/wasm-gen@1.11.1: + resolution: {integrity: sha512-F7QqKXwwNlMmsulj6+O7r4mmtAlCWfO/0HdgOxSklZfQcDu0TpLiD1mRt/zF25Bk59FIjEuGAIyn5ei4yMfLhA==} dependencies: - '@webassemblyjs/ast': 1.11.6 - '@webassemblyjs/helper-wasm-bytecode': 1.11.6 - '@webassemblyjs/ieee754': 1.11.6 - '@webassemblyjs/leb128': 1.11.6 - '@webassemblyjs/utf8': 1.11.6 + '@webassemblyjs/ast': 1.11.1 + '@webassemblyjs/helper-wasm-bytecode': 1.11.1 + '@webassemblyjs/ieee754': 1.11.1 + '@webassemblyjs/leb128': 1.11.1 + '@webassemblyjs/utf8': 1.11.1 dev: true /@webassemblyjs/wasm-gen@1.9.0: @@ -9162,13 +10223,13 @@ packages: '@webassemblyjs/utf8': 1.9.0 dev: true - /@webassemblyjs/wasm-opt@1.11.6: - resolution: {integrity: sha512-cOrKuLRE7PCe6AsOVl7WasYf3wbSo4CeOk6PkrjS7g57MFfVUF9u6ysQBBODX0LdgSvQqRiGz3CXvIDKcPNy4g==} + /@webassemblyjs/wasm-opt@1.11.1: + resolution: {integrity: sha512-VqnkNqnZlU5EB64pp1l7hdm3hmQw7Vgqa0KF/KCNO9sIpI6Fk6brDEiX+iCOYrvMuBWDws0NkTOxYEb85XQHHw==} dependencies: - '@webassemblyjs/ast': 1.11.6 - '@webassemblyjs/helper-buffer': 1.11.6 - '@webassemblyjs/wasm-gen': 1.11.6 - '@webassemblyjs/wasm-parser': 1.11.6 + '@webassemblyjs/ast': 1.11.1 + '@webassemblyjs/helper-buffer': 1.11.1 + '@webassemblyjs/wasm-gen': 1.11.1 + '@webassemblyjs/wasm-parser': 1.11.1 dev: true /@webassemblyjs/wasm-opt@1.9.0: @@ -9180,15 +10241,15 @@ packages: '@webassemblyjs/wasm-parser': 1.9.0 dev: true - /@webassemblyjs/wasm-parser@1.11.6: - resolution: {integrity: sha512-6ZwPeGzMJM3Dqp3hCsLgESxBGtT/OeCvCZ4TA1JUPYgmhAx38tTPR9JaKy0S5H3evQpO/h2uWs2j6Yc/fjkpTQ==} + /@webassemblyjs/wasm-parser@1.11.1: + resolution: {integrity: sha512-rrBujw+dJu32gYB7/Lup6UhdkPx9S9SnobZzRVL7VcBH9Bt9bCBLEuX/YXOOtBsOZ4NQrRykKhffRWHvigQvOA==} dependencies: - '@webassemblyjs/ast': 1.11.6 - '@webassemblyjs/helper-api-error': 1.11.6 - '@webassemblyjs/helper-wasm-bytecode': 1.11.6 - '@webassemblyjs/ieee754': 1.11.6 - '@webassemblyjs/leb128': 1.11.6 - '@webassemblyjs/utf8': 1.11.6 + '@webassemblyjs/ast': 1.11.1 + '@webassemblyjs/helper-api-error': 1.11.1 + '@webassemblyjs/helper-wasm-bytecode': 1.11.1 + '@webassemblyjs/ieee754': 1.11.1 + '@webassemblyjs/leb128': 1.11.1 + '@webassemblyjs/utf8': 1.11.1 dev: true /@webassemblyjs/wasm-parser@1.9.0: @@ -9213,10 +10274,10 @@ packages: '@xtuc/long': 4.2.2 dev: true - /@webassemblyjs/wast-printer@1.11.6: - resolution: {integrity: sha512-JM7AhRcE+yW2GWYaKeHL5vt4xqee5N2WcezptmgyhNS+ScggqcT1OtXykhAb13Sn5Yas0j2uv9tHgrjwvzAP4A==} + /@webassemblyjs/wast-printer@1.11.1: + resolution: {integrity: sha512-IQboUWM4eKzWW+N/jij2sRatKMh99QEelo3Eb2q0qXkvPRISAj8Qxtmw5itwqK+TTkBuUIE45AxYPToqPtL5gg==} dependencies: - '@webassemblyjs/ast': 1.11.6 + '@webassemblyjs/ast': 1.11.1 '@xtuc/long': 4.2.2 dev: true @@ -9237,7 +10298,7 @@ packages: dependencies: '@wojtekmaj/enzyme-adapter-utils': 0.1.4(react@17.0.2) enzyme: 3.11.0 - enzyme-shallow-equal: 1.0.5 + enzyme-shallow-equal: 1.0.4 has: 1.0.3 prop-types: 15.8.1 react: 17.0.2 @@ -9253,41 +10314,34 @@ packages: dependencies: function.prototype.name: 1.1.5 has: 1.0.3 - object.fromentries: 2.0.6 + object.fromentries: 2.0.5 prop-types: 15.8.1 react: 17.0.2 dev: true - /@wry/context@0.7.3: - resolution: {integrity: sha512-Nl8WTesHp89RF803Se9X3IiHjdmLBrIvPMaJkl+rKVJAYyPsz1TEUbu89943HpvujtSJgDUx9W4vZw3K1Mr3sA==} + /@wry/context@0.6.1: + resolution: {integrity: sha512-LOmVnY1iTU2D8tv4Xf6MVMZZ+juIJ87Kt/plMijjN20NMAXGmH4u8bS1t0uT74cZ5gwpocYueV58YwyI8y+GKw==} engines: {node: '>=8'} dependencies: - tslib: 2.6.0 + tslib: 2.5.3 dev: false - /@wry/equality@0.5.6: - resolution: {integrity: sha512-D46sfMTngaYlrH+OspKf8mIJETntFnf6Hsjb0V41jAXJ7Bx2kB8Rv8RCUujuVWYttFtHkUNp7g+FwxNQAr6mXA==} + /@wry/equality@0.5.3: + resolution: {integrity: sha512-avR+UXdSrsF2v8vIqIgmeTY0UR91UT+IyablCyKe/uk22uOJ8fusKZnH9JH9e1/EtLeNJBtagNmL3eJdnOV53g==} engines: {node: '>=8'} dependencies: - tslib: 2.6.0 + tslib: 2.5.3 dev: false /@wry/trie@0.3.2: resolution: {integrity: sha512-yRTyhWSls2OY/pYLfwff867r8ekooZ4UI+/gxot5Wj8EFwSf2rG+n+Mo/6LoLQm1TKA4GRj2+LCpbfS937dClQ==} engines: {node: '>=8'} dependencies: - tslib: 2.6.0 - dev: false - - /@wry/trie@0.4.3: - resolution: {integrity: sha512-I6bHwH0fSf6RqQcnnXLJKhkSXG45MFral3GxPaY4uAl0LYDZM+YDVDAiU9bYwjTuysy1S0IeecWtmq1SZA3M1w==} - engines: {node: '>=8'} - dependencies: - tslib: 2.6.0 + tslib: 2.5.3 dev: false - /@xmldom/xmldom@0.8.8: - resolution: {integrity: sha512-0LNz4EY8B/8xXY86wMrQ4tz6zEHZv9ehFMJPm8u2gq5lQ71cfRKdaKyxfJAx5aUoyzx0qzgURblTisPGgz3d+Q==} + /@xmldom/xmldom@0.8.6: + resolution: {integrity: sha512-uRjjusqpoqfmRkTaNuLJ2VohVr67Q5YwDATW3VU7PfzTj6IRaihGrYI7zckGZjxQPBIp63nfvJbM+Yu5ICh0Bg==} engines: {node: '>=10.0.0'} dev: true @@ -9346,16 +10400,16 @@ packages: /acorn-globals@7.0.1: resolution: {integrity: sha512-umOSDSDrfHbTNPuNpC2NSnnA3LUrqpevPb4T9jRx4MagXNS0rs+gwiTcAvqCRmsD6utzsrzNt+ebm00SNWiC3Q==} dependencies: - acorn: 8.10.0 + acorn: 8.9.0 acorn-walk: 8.2.0 dev: true - /acorn-import-assertions@1.9.0(acorn@8.10.0): - resolution: {integrity: sha512-cmMwop9x+8KFhxvKrKfPYmN6/pKTYYHBqLa0DfvVZcKMJWNyWLnaqND7dx/qn66R7ewM1UX5XMaDVP5wlVTaVA==} + /acorn-import-assertions@1.8.0(acorn@8.9.0): + resolution: {integrity: sha512-m7VZ3jwz4eK6A4Vtt8Ew1/mNbP24u0FhdyfA7fSvnJR6LMdfOYnmuIrrJAgrYfYJ10F/otaHTtrtrtmHdMNzEw==} peerDependencies: acorn: ^8 dependencies: - acorn: 8.10.0 + acorn: 8.9.0 dev: true /acorn-jsx@5.3.2(acorn@7.4.1): @@ -9366,12 +10420,12 @@ packages: acorn: 7.4.1 dev: true - /acorn-jsx@5.3.2(acorn@8.10.0): + /acorn-jsx@5.3.2(acorn@8.9.0): resolution: {integrity: sha512-rq9s+JNhf0IChjtDXxllJ7g41oZk5SlXtp0LHwyA5cejwn7vKmKp4pPri6YEePv2PU65sAsegbXtIinmDFDXgQ==} peerDependencies: acorn: ^6.0.0 || ^7.0.0 || ^8.0.0 dependencies: - acorn: 8.10.0 + acorn: 8.9.0 dev: true /acorn-walk@7.2.0: @@ -9395,13 +10449,19 @@ packages: hasBin: true dev: true - /acorn@8.10.0: - resolution: {integrity: sha512-F0SAmZ8iUtS//m8DmCTA0jlh6TDKkHQyK6xc6V4KDTyZKA9dnvX9/3sRTVQrWm79glUAZbnmmNcdYwUIHWVybw==} + /acorn@8.8.2: + resolution: {integrity: sha512-xjIYgE8HBrkpd/sJqOGNspf8uHG+NOHGOw6a/Urj8taM2EXfdNAH2oFcPeIFfsv3+kz/mJrS5VuMqbNLjCa2vw==} + engines: {node: '>=0.4.0'} + hasBin: true + dev: true + + /acorn@8.9.0: + resolution: {integrity: sha512-jaVNAFBHNLXspO543WnNNPZFRtavh3skAkITqD0/2aeMkKZTN+254PyhwxFYrk3vQ1xfY+2wbesJMs/JC8/PwQ==} engines: {node: '>=0.4.0'} hasBin: true - /address@1.2.2: - resolution: {integrity: sha512-4B/qKCfeE/ODUaAUpSwfzazo5x29WD4r3vXiWsB7I2mSDAihwEqKO+g8GELZUQSSAo5e1XTYh3ZVfLyxBc12nA==} + /address@1.2.0: + resolution: {integrity: sha512-tNEZYz5G/zYunxFm7sfhAxkXEuLj3K6BKwv6ZURlsF6yiUQ65z0Q2wZW9L5cPUl9ocofGvXOdFYbFHp0+6MOig==} engines: {node: '>= 10.0.0'} dev: true @@ -9429,18 +10489,18 @@ packages: array.prototype.flat: 1.3.1 array.prototype.flatmap: 1.3.1 es5-shim: 4.6.7 - es6-shim: 0.35.8 + es6-shim: 0.35.6 function.prototype.name: 1.1.5 globalthis: 1.0.3 - object.entries: 1.1.6 - object.fromentries: 2.0.6 - object.getownpropertydescriptors: 2.1.6 + object.entries: 1.1.5 + object.fromentries: 2.0.5 + object.getownpropertydescriptors: 2.1.4 object.values: 1.1.6 - promise.allsettled: 1.0.6 - promise.prototype.finally: 3.1.4 - string.prototype.matchall: 4.0.8 - string.prototype.padend: 3.1.4 - string.prototype.padstart: 3.1.4 + promise.allsettled: 1.0.5 + promise.prototype.finally: 3.1.3 + string.prototype.matchall: 4.0.7 + string.prototype.padend: 3.1.3 + string.prototype.padstart: 3.1.3 symbol.prototype.description: 1.0.5 dev: true @@ -9452,7 +10512,7 @@ packages: ajv: 6.12.6 dev: true - /ajv-formats@2.1.1(ajv@8.12.0): + /ajv-formats@2.1.1(ajv@8.11.0): resolution: {integrity: sha512-Wx0Kx52hxE7C18hkMEggYlEifqWZtYaRgouJor+WMdPnQyEK13vgEWyVNup7SoeeoLMsr4kf5h6dOW11I15MUA==} peerDependencies: ajv: ^8.0.0 @@ -9460,7 +10520,7 @@ packages: ajv: optional: true dependencies: - ajv: 8.12.0 + ajv: 8.11.0 dev: true /ajv-keywords@3.5.2(ajv@6.12.6): @@ -9480,8 +10540,8 @@ packages: uri-js: 4.4.1 dev: true - /ajv@8.12.0: - resolution: {integrity: sha512-sRu1kpcO9yLtYxBKvqfTeh9KzZEwO3STyX1HT+4CaDzC6HpTGYhIhPIzj9XuKU7KYDwnaeh5hcOwjy1QuJzBPA==} + /ajv@8.11.0: + resolution: {integrity: sha512-wGgprdCvMalC0BztXvitD2hC04YffAvtsUn93JbGXYLAtCUO4xd17mCCZQxUOItiBwZvJScWo8NIvQMQ71rdpg==} dependencies: fast-deep-equal: 3.1.3 json-schema-traverse: 1.0.0 @@ -9489,23 +10549,23 @@ packages: uri-js: 4.4.1 dev: true - /algoliasearch@4.18.0: - resolution: {integrity: sha512-pCuVxC1SVcpc08ENH32T4sLKSyzoU7TkRIDBMwSLfIiW+fq4znOmWDkAygHZ6pRcO9I1UJdqlfgnV7TRj+MXrA==} + /algoliasearch@4.14.2: + resolution: {integrity: sha512-ngbEQonGEmf8dyEh5f+uOIihv4176dgbuOZspiuhmTTBRBuzWu3KCGHre6uHj5YyuC7pNvQGzB6ZNJyZi0z+Sg==} dependencies: - '@algolia/cache-browser-local-storage': 4.18.0 - '@algolia/cache-common': 4.18.0 - '@algolia/cache-in-memory': 4.18.0 - '@algolia/client-account': 4.18.0 - '@algolia/client-analytics': 4.18.0 - '@algolia/client-common': 4.18.0 - '@algolia/client-personalization': 4.18.0 - '@algolia/client-search': 4.18.0 - '@algolia/logger-common': 4.18.0 - '@algolia/logger-console': 4.18.0 - '@algolia/requester-browser-xhr': 4.18.0 - '@algolia/requester-common': 4.18.0 - '@algolia/requester-node-http': 4.18.0 - '@algolia/transporter': 4.18.0 + '@algolia/cache-browser-local-storage': 4.14.2 + '@algolia/cache-common': 4.14.2 + '@algolia/cache-in-memory': 4.14.2 + '@algolia/client-account': 4.14.2 + '@algolia/client-analytics': 4.14.2 + '@algolia/client-common': 4.14.2 + '@algolia/client-personalization': 4.14.2 + '@algolia/client-search': 4.14.2 + '@algolia/logger-common': 4.14.2 + '@algolia/logger-console': 4.14.2 + '@algolia/requester-browser-xhr': 4.14.2 + '@algolia/requester-common': 4.14.2 + '@algolia/requester-node-http': 4.14.2 + '@algolia/transporter': 4.14.2 dev: true /ansi-align@3.0.1: @@ -9619,8 +10679,8 @@ packages: - supports-color dev: true - /anymatch@3.1.3: - resolution: {integrity: sha512-KMReFUr0B4t+D+OBkjR3KYqvocp2XaSzO55UcB6mgQMd3KbcE+mWTyvVV7D/zsdEbNnV6acZUutkiHQXvTr1Rw==} + /anymatch@3.1.2: + resolution: {integrity: sha512-P43ePfOAIupkguHUycrc4qJ9kz8ZiuOUijaETwX7THt0Y/GNK7v0aa8rY816xWjZ7rJdA5XdMcpVFTKMq+RvWg==} engines: {node: '>= 8'} dependencies: normalize-path: 3.0.0 @@ -9652,7 +10712,7 @@ packages: engines: {node: '>= 6'} dependencies: glob: 7.2.3 - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 lazystream: 1.0.1 lodash.defaults: 4.2.0 lodash.difference: 4.5.0 @@ -9660,7 +10720,7 @@ packages: lodash.isplainobject: 4.0.6 lodash.union: 4.6.0 normalize-path: 3.0.0 - readable-stream: 2.3.8 + readable-stream: 2.3.7 dev: true /archiver@5.3.1: @@ -9670,8 +10730,8 @@ packages: archiver-utils: 2.1.0 async: 3.2.4 buffer-crc32: 0.2.13 - readable-stream: 3.6.2 - readdir-glob: 1.1.3 + readable-stream: 3.6.0 + readdir-glob: 1.1.2 tar-stream: 2.2.0 zip-stream: 4.1.0 dev: true @@ -9685,7 +10745,7 @@ packages: engines: {node: '>=10'} dependencies: delegates: 1.0.0 - readable-stream: 3.6.2 + readable-stream: 3.6.0 dev: true /arg@4.1.3: @@ -9702,10 +10762,15 @@ packages: resolution: {integrity: sha512-8+9WqebbFzpX9OR+Wa6O29asIogeRMzcGtAINdpMHHyAg10f05aSFVBbcEqGf/PXw1EjAZ+q2/bEBg3DvurK3Q==} dev: true + /aria-query@5.0.2: + resolution: {integrity: sha512-eigU3vhqSO+Z8BKDnVLN/ompjhf3pYzecKXz8+whRy+9gZu8n1TCGfwzQUUPnqdHl9ax1Hr9031orZ+UOEYr7Q==} + engines: {node: '>=6.0'} + dev: true + /aria-query@5.1.3: resolution: {integrity: sha512-R5iJ5lkuHybztUfuOAznmboyjWq8O6sqNqtK7CLOqdydi54VNbORp49mb14KbWgG1QD3JFO9hJdZ+y4KutfdOQ==} dependencies: - deep-equal: 2.2.2 + deep-equal: 2.2.1 dev: true /aria-query@5.3.0: @@ -9751,8 +10816,8 @@ packages: dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.21.2 - get-intrinsic: 1.2.1 + es-abstract: 1.20.4 + get-intrinsic: 1.2.0 is-string: 1.0.7 dev: true @@ -9778,24 +10843,34 @@ packages: engines: {node: '>=0.10.0'} dev: true - /array.prototype.filter@1.0.2: - resolution: {integrity: sha512-us+UrmGOilqttSOgoWZTpOvHu68vZT2YCjc/H4vhu56vzZpaDFBhB+Se2UwqWzMKbDv7Myq5M5pcZLAtUvTQdQ==} + /array.prototype.filter@1.0.1: + resolution: {integrity: sha512-Dk3Ty7N42Odk7PjU/Ci3zT4pLj20YvuVnneG/58ICM6bt4Ij5kZaJTVQ9TSaWaIECX2sFyz4KItkVZqHNnciqw==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.21.2 + es-abstract: 1.20.4 es-array-method-boxes-properly: 1.0.0 is-string: 1.0.7 dev: true + /array.prototype.flat@1.3.0: + resolution: {integrity: sha512-12IUEkHsAhA4DY5s0FPgNXIdc8VRSqD9Zp78a5au9abH/SOBrsp082JOWFNTjkMozh8mqcdiKuaLGhPeYztxSw==} + engines: {node: '>= 0.4'} + dependencies: + call-bind: 1.0.2 + define-properties: 1.2.0 + es-abstract: 1.20.4 + es-shim-unscopables: 1.0.0 + dev: true + /array.prototype.flat@1.3.1: resolution: {integrity: sha512-roTU0KWIOmJ4DRLmwKd19Otg0/mT3qPNt0Qb3GWW8iObuZXxrjB/pzn0R3hqpRSWg4HCwqx+0vwOnWnvlOyeIA==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.21.2 + es-abstract: 1.20.4 es-shim-unscopables: 1.0.0 dev: true @@ -9805,28 +10880,28 @@ packages: dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.21.2 + es-abstract: 1.20.4 es-shim-unscopables: 1.0.0 dev: true - /array.prototype.map@1.0.5: - resolution: {integrity: sha512-gfaKntvwqYIuC7mLLyv2wzZIJqrRhn5PZ9EfFejSx6a78sV7iDsGpG9P+3oUPtm1Rerqm6nrKS4FYuTIvWfo3g==} + /array.prototype.map@1.0.4: + resolution: {integrity: sha512-Qds9QnX7A0qISY7JT5WuJO0NJPE9CMlC6JzHQfhpqAAQQzufVRoeH7EzUY5GcPTx72voG8LV/5eo+b8Qi8hmhA==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.21.2 + es-abstract: 1.20.4 es-array-method-boxes-properly: 1.0.0 is-string: 1.0.7 dev: true - /array.prototype.reduce@1.0.5: - resolution: {integrity: sha512-kDdugMl7id9COE8R7MHF5jWk7Dqt/fs4Pv+JXoICnYwqpjjjbUurz6w5fT5IG6brLdJhv6/VoHB0H7oyIBXd+Q==} + /array.prototype.reduce@1.0.4: + resolution: {integrity: sha512-WnM+AjG/DvLRLo4DDl+r+SvCzYtD2Jd9oeBYMcEaI7t3fFrHY9M53/wdLcTvmZNQ70IU6Htj0emFkZ5TS+lrdw==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.21.2 + es-abstract: 1.20.4 es-array-method-boxes-properly: 1.0.0 is-string: 1.0.7 dev: true @@ -9880,7 +10955,7 @@ packages: resolution: {integrity: sha512-O0yuUDnZeQDL+ncNGlJ78BiO4jnYI3bvMsD5prT0/nsgijG/LpNBIr63gTjVTNsiGkgQhiyCShTgxt8oXOrklA==} engines: {node: '>=4'} dependencies: - tslib: 2.6.0 + tslib: 2.5.3 dev: true /astral-regex@2.0.0: @@ -9888,8 +10963,8 @@ packages: engines: {node: '>=8'} dev: true - /async-each@1.0.6: - resolution: {integrity: sha512-c646jH1avxr+aVpndVMeAfYw7wAa6idufrlN3LPA4PmKS0QEGp6PIC9nwz0WQkkvBGAMEki3pFdtxaF39J9vvg==} + /async-each@1.0.3: + resolution: {integrity: sha512-z/WhQ5FPySLdvREByI2vZiTWwCnF0moMJ1hK9YQwDTHKh6I7/uSckMetoRGb5UBZPC1z0jlw+n/XCgjeH7y1AQ==} dev: true optional: true @@ -9921,8 +10996,8 @@ packages: resolution: {integrity: sha512-eM9d/swFopRt5gdJ7jrpCwgvEMIayITpojhkkSMRsFHYuH5bkSQ4p/9qTEHtmNudUZh22Tehu7I6CxAW0IXTKA==} hasBin: true dependencies: - browserslist: 4.21.9 - caniuse-lite: 1.0.30001515 + browserslist: 4.21.3 + caniuse-lite: 1.0.30001385 normalize-range: 0.1.2 num2fraction: 1.2.2 picocolors: 0.2.1 @@ -9935,12 +11010,12 @@ packages: engines: {node: '>= 0.4'} dev: true - /avvio@8.2.1: - resolution: {integrity: sha512-TAlMYvOuwGyLK3PfBb5WKBXZmXz2fVCgv23d6zZFdle/q3gPjmxBaeuC0pY0Dzs5PWMSgfqqEZkrye19GlDTgw==} + /avvio@8.2.0: + resolution: {integrity: sha512-bbCQdg7bpEv6kGH41RO/3B2/GMMmJSo2iBK+X8AWN9mujtfUipMDfIjsgHCfpnKqoGEQrrmCDKSa5OQ19+fDmg==} dependencies: archy: 1.0.0 debug: 4.3.4(supports-color@8.1.1) - fastq: 1.15.0 + fastq: 1.13.0 transitivePeerDependencies: - supports-color dev: true @@ -9949,14 +11024,14 @@ packages: resolution: {integrity: sha512-08kcGqnYf/YmjoRhfxyu+CLxBjUtHLXLXX/vUfx9l2LYzG3c1m61nrpyFUZI6zeS+Li/wWMMidD9KgrqtGq3mA==} dev: true - /aws4@1.12.0: - resolution: {integrity: sha512-NmWvPnx0F1SfrQbYwOi7OeaNGokp9XhzNioJ/CSBs8Qa4vxug81mhJEAVZwxXuBmYB5KDRfMq/F3RR0BIU7sWg==} + /aws4@1.11.0: + resolution: {integrity: sha512-xh1Rl34h6Fi1DC2WWKfxUTVqRsNnr6LsKz2+hfwDxQJWmrx8+c7ylaqBMcHfl1U1r2dsifOvKX3LQuLNZ+XSvA==} dev: true /axios@0.26.1: resolution: {integrity: sha512-fPwcX4EvnSHuInCMItEhAGnaSEXRBjtzh9fOtsE6E1G6p7vl7edEeZe11QHf18+6+9gR5PbKV/sGKNaD8YaMeA==} dependencies: - follow-redirects: 1.15.2 + follow-redirects: 1.15.1 transitivePeerDependencies: - debug @@ -9966,57 +11041,53 @@ packages: dequal: 2.0.3 dev: true - /b4a@1.6.4: - resolution: {integrity: sha512-fpWrvyVHEKyeEvbKZTVOeZF3VSKKWtJxFIxX/jaVPf+cLbGUSitjb49pHLqPV2BUNNZ0LcoeEGfE/YCpyDYHIw==} - dev: true - - /babel-jest@27.5.1(@babel/core@7.22.8): + /babel-jest@27.5.1(@babel/core@7.22.5): resolution: {integrity: sha512-cdQ5dXjGRd0IBRATiQ4mZGlGlRE8kJpjPOixdNRdT+m3UcNqmYWN6rK6nvtXYfY3D76cb8s/O1Ss8ea24PIwcg==} engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} peerDependencies: '@babel/core': ^7.8.0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@jest/transform': 27.5.1 '@jest/types': 27.5.1 - '@types/babel__core': 7.20.1 + '@types/babel__core': 7.20.0 babel-plugin-istanbul: 6.1.1 - babel-preset-jest: 27.5.1(@babel/core@7.22.8) + babel-preset-jest: 27.5.1(@babel/core@7.22.5) chalk: 4.1.2 - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 slash: 3.0.0 transitivePeerDependencies: - supports-color dev: true - /babel-loader@8.3.0(@babel/core@7.22.8)(webpack@4.46.0): - resolution: {integrity: sha512-H8SvsMF+m9t15HNLMipppzkC+Y2Yq+v3SonZyU70RBL/h1gxPkH08Ot8pEE9Z4Kd+czyWJClmFS8qzIP9OZ04Q==} + /babel-loader@8.2.5(@babel/core@7.18.13)(webpack@5.74.0): + resolution: {integrity: sha512-OSiFfH89LrEMiWd4pLNqGz4CwJDtbs2ZVc+iGu2HrkRfPxId9F2anQj38IxWpmRfsUY0aBZYi1EFcd3mhtRMLQ==} engines: {node: '>= 8.9'} peerDependencies: '@babel/core': ^7.0.0 webpack: '>=2' dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.18.13 find-cache-dir: 3.3.2 - loader-utils: 2.0.4 + loader-utils: 2.0.2 make-dir: 3.1.0 schema-utils: 2.7.1 - webpack: 4.46.0 + webpack: 5.74.0(esbuild@0.18.11) dev: true - /babel-loader@8.3.0(@babel/core@7.22.8)(webpack@5.88.1): - resolution: {integrity: sha512-H8SvsMF+m9t15HNLMipppzkC+Y2Yq+v3SonZyU70RBL/h1gxPkH08Ot8pEE9Z4Kd+czyWJClmFS8qzIP9OZ04Q==} + /babel-loader@8.2.5(@babel/core@7.22.5)(webpack@4.46.0): + resolution: {integrity: sha512-OSiFfH89LrEMiWd4pLNqGz4CwJDtbs2ZVc+iGu2HrkRfPxId9F2anQj38IxWpmRfsUY0aBZYi1EFcd3mhtRMLQ==} engines: {node: '>= 8.9'} peerDependencies: '@babel/core': ^7.0.0 webpack: '>=2' dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 find-cache-dir: 3.3.2 - loader-utils: 2.0.4 + loader-utils: 2.0.2 make-dir: 3.1.0 schema-utils: 2.7.1 - webpack: 5.88.1(esbuild@0.18.11) + webpack: 4.46.0 dev: true /babel-plugin-add-react-displayname@0.0.5: @@ -10033,6 +11104,12 @@ packages: '@mdx-js/util': 1.6.22 dev: true + /babel-plugin-dynamic-import-node@2.3.3: + resolution: {integrity: sha512-jZVI+s9Zg3IqA/kdi0i6UDCybUI3aSBLnglhYbSSjKlV7yF1F/5LWv8MakQmvYpnbJDS6fcBL2KzHSxNCMtWSQ==} + dependencies: + object.assign: 4.1.4 + dev: true + /babel-plugin-extract-import-names@1.6.22: resolution: {integrity: sha512-yJ9BsJaISua7d8zNT7oRG1ZLBJCIdZ4PZqmH8qa9N5AK01ifk3fnkc98AXhtzE7UkfCsEumvoQWgoYLhOnJ7jQ==} dependencies: @@ -10058,75 +11135,110 @@ packages: dependencies: '@babel/template': 7.22.5 '@babel/types': 7.22.5 - '@types/babel__core': 7.20.1 - '@types/babel__traverse': 7.20.1 + '@types/babel__core': 7.20.0 + '@types/babel__traverse': 7.18.3 dev: true - /babel-plugin-jsx-dom-expressions@0.36.10(@babel/core@7.22.8): - resolution: {integrity: sha512-QA2k/14WGw+RgcGGnEuLWwnu4em6CGhjeXtjvgOYyFHYS2a+CzPeaVQHDOlfuiBcjq/3hWMspHMIMnPEOIzdBg==} + /babel-plugin-jsx-dom-expressions@0.35.6(@babel/core@7.20.5): + resolution: {integrity: sha512-z8VBym+Scol38MiR97iqQGsANjhsDqscRRemk+po+z3TWKV/fb9kux/gdKOJJSC/ARyUL3HExBFVtr+Efd24uw==} peerDependencies: - '@babel/core': ^7.20.12 + '@babel/core': ^7.0.0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-module-imports': 7.18.6 - '@babel/plugin-syntax-jsx': 7.22.5(@babel/core@7.22.8) + '@babel/core': 7.20.5 + '@babel/helper-module-imports': 7.16.0 + '@babel/plugin-syntax-jsx': 7.18.6(@babel/core@7.20.5) '@babel/types': 7.22.5 - html-entities: 2.3.3 - validate-html-nesting: 1.2.2 + html-entities: 2.3.2 dev: true /babel-plugin-macros@3.1.0: resolution: {integrity: sha512-Cg7TFGpIr01vOQNODXOOaGz2NpCU5gl8x1qJFbb6hbZxR7XrcE2vtbAsTAbJ7/xwJtUuJEw8K8Zr/AE0LHlesg==} engines: {node: '>=10', npm: '>=6'} dependencies: - '@babel/runtime': 7.22.6 - cosmiconfig: 7.1.0 + '@babel/runtime': 7.18.9 + cosmiconfig: 7.0.1 resolve: 1.22.2 - /babel-plugin-polyfill-corejs2@0.4.4(@babel/core@7.22.8): - resolution: {integrity: sha512-9WeK9snM1BfxB38goUEv2FLnA6ja07UMfazFHzCXUb3NyDZAwfXvQiURQ6guTTMeHcOsdknULm1PDhs4uWtKyA==} + /babel-plugin-polyfill-corejs2@0.3.2(@babel/core@7.18.13): + resolution: {integrity: sha512-LPnodUl3lS0/4wN3Rb+m+UK8s7lj2jcLRrjho4gLw+OJs+I4bvGXshINesY5xx/apM+biTnQ9reDI8yj+0M5+Q==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/compat-data': 7.22.5 + '@babel/core': 7.18.13 + '@babel/helper-define-polyfill-provider': 0.3.2(@babel/core@7.18.13) + semver: 6.3.0 + transitivePeerDependencies: + - supports-color + dev: true + + /babel-plugin-polyfill-corejs2@0.3.2(@babel/core@7.22.5): + resolution: {integrity: sha512-LPnodUl3lS0/4wN3Rb+m+UK8s7lj2jcLRrjho4gLw+OJs+I4bvGXshINesY5xx/apM+biTnQ9reDI8yj+0M5+Q==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/compat-data': 7.22.6 - '@babel/core': 7.22.8 - '@babel/helper-define-polyfill-provider': 0.4.1(@babel/core@7.22.8) - '@nicolo-ribaudo/semver-v6': 6.3.3 + '@babel/compat-data': 7.22.5 + '@babel/core': 7.22.5 + '@babel/helper-define-polyfill-provider': 0.3.2(@babel/core@7.22.5) + semver: 6.3.0 transitivePeerDependencies: - supports-color dev: true - /babel-plugin-polyfill-corejs3@0.1.7(@babel/core@7.22.8): + /babel-plugin-polyfill-corejs3@0.1.7(@babel/core@7.22.5): resolution: {integrity: sha512-u+gbS9bbPhZWEeyy1oR/YaaSpod/KDT07arZHb80aTpl8H5ZBq+uN1nN9/xtX7jQyfLdPfoqI4Rue/MQSWJquw==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-define-polyfill-provider': 0.1.5(@babel/core@7.22.8) - core-js-compat: 3.31.1 + '@babel/core': 7.22.5 + '@babel/helper-define-polyfill-provider': 0.1.5(@babel/core@7.22.5) + core-js-compat: 3.25.0 + transitivePeerDependencies: + - supports-color + dev: true + + /babel-plugin-polyfill-corejs3@0.5.3(@babel/core@7.18.13): + resolution: {integrity: sha512-zKsXDh0XjnrUEW0mxIHLfjBfnXSMr5Q/goMe/fxpQnLm07mcOZiIZHBNWCMx60HmdvjxfXcalac0tfFg0wqxyw==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.18.13 + '@babel/helper-define-polyfill-provider': 0.3.2(@babel/core@7.18.13) + core-js-compat: 3.25.0 transitivePeerDependencies: - supports-color dev: true - /babel-plugin-polyfill-corejs3@0.8.2(@babel/core@7.22.8): - resolution: {integrity: sha512-Cid+Jv1BrY9ReW9lIfNlNpsI53N+FN7gE+f73zLAUbr9C52W4gKLWSByx47pfDJsEysojKArqOtOKZSVIIUTuQ==} + /babel-plugin-polyfill-corejs3@0.5.3(@babel/core@7.22.5): + resolution: {integrity: sha512-zKsXDh0XjnrUEW0mxIHLfjBfnXSMr5Q/goMe/fxpQnLm07mcOZiIZHBNWCMx60HmdvjxfXcalac0tfFg0wqxyw==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-define-polyfill-provider': 0.4.1(@babel/core@7.22.8) - core-js-compat: 3.31.1 + '@babel/core': 7.22.5 + '@babel/helper-define-polyfill-provider': 0.3.2(@babel/core@7.22.5) + core-js-compat: 3.25.0 transitivePeerDependencies: - supports-color dev: true - /babel-plugin-polyfill-regenerator@0.5.1(@babel/core@7.22.8): - resolution: {integrity: sha512-L8OyySuI6OSQ5hFy9O+7zFjyr4WhAfRjLIOkhQGYl+emwJkd/S4XXT1JpfrgR1jrQ1NcGiOh+yAdGlF8pnC3Jw==} + /babel-plugin-polyfill-regenerator@0.4.0(@babel/core@7.18.13): + resolution: {integrity: sha512-RW1cnryiADFeHmfLS+WW/G431p1PsW5qdRdz0SDRi7TKcUgc7Oh/uXkT7MZ/+tGsT1BkczEAmD5XjUyJ5SWDTw==} peerDependencies: '@babel/core': ^7.0.0-0 dependencies: - '@babel/core': 7.22.8 - '@babel/helper-define-polyfill-provider': 0.4.1(@babel/core@7.22.8) + '@babel/core': 7.18.13 + '@babel/helper-define-polyfill-provider': 0.3.2(@babel/core@7.18.13) + transitivePeerDependencies: + - supports-color + dev: true + + /babel-plugin-polyfill-regenerator@0.4.0(@babel/core@7.22.5): + resolution: {integrity: sha512-RW1cnryiADFeHmfLS+WW/G431p1PsW5qdRdz0SDRi7TKcUgc7Oh/uXkT7MZ/+tGsT1BkczEAmD5XjUyJ5SWDTw==} + peerDependencies: + '@babel/core': ^7.0.0-0 + dependencies: + '@babel/core': 7.22.5 + '@babel/helper-define-polyfill-provider': 0.3.2(@babel/core@7.22.5) transitivePeerDependencies: - supports-color dev: true @@ -10141,44 +11253,44 @@ packages: - supports-color dev: true - /babel-preset-current-node-syntax@1.0.1(@babel/core@7.22.8): + /babel-preset-current-node-syntax@1.0.1(@babel/core@7.22.5): resolution: {integrity: sha512-M7LQ0bxarkxQoN+vz5aJPsLBn77n8QgTFmo8WK0/44auK2xlCXrYcUxHFxgU7qW5Yzw/CjmLRK2uJzaCd7LvqQ==} peerDependencies: '@babel/core': ^7.0.0 dependencies: - '@babel/core': 7.22.8 - '@babel/plugin-syntax-async-generators': 7.8.4(@babel/core@7.22.8) - '@babel/plugin-syntax-bigint': 7.8.3(@babel/core@7.22.8) - '@babel/plugin-syntax-class-properties': 7.12.13(@babel/core@7.22.8) - '@babel/plugin-syntax-import-meta': 7.10.4(@babel/core@7.22.8) - '@babel/plugin-syntax-json-strings': 7.8.3(@babel/core@7.22.8) - '@babel/plugin-syntax-logical-assignment-operators': 7.10.4(@babel/core@7.22.8) - '@babel/plugin-syntax-nullish-coalescing-operator': 7.8.3(@babel/core@7.22.8) - '@babel/plugin-syntax-numeric-separator': 7.10.4(@babel/core@7.22.8) - '@babel/plugin-syntax-object-rest-spread': 7.8.3(@babel/core@7.22.8) - '@babel/plugin-syntax-optional-catch-binding': 7.8.3(@babel/core@7.22.8) - '@babel/plugin-syntax-optional-chaining': 7.8.3(@babel/core@7.22.8) - '@babel/plugin-syntax-top-level-await': 7.14.5(@babel/core@7.22.8) - dev: true - - /babel-preset-jest@27.5.1(@babel/core@7.22.8): + '@babel/core': 7.22.5 + '@babel/plugin-syntax-async-generators': 7.8.4(@babel/core@7.22.5) + '@babel/plugin-syntax-bigint': 7.8.3(@babel/core@7.22.5) + '@babel/plugin-syntax-class-properties': 7.12.13(@babel/core@7.22.5) + '@babel/plugin-syntax-import-meta': 7.10.4(@babel/core@7.22.5) + '@babel/plugin-syntax-json-strings': 7.8.3(@babel/core@7.22.5) + '@babel/plugin-syntax-logical-assignment-operators': 7.10.4(@babel/core@7.22.5) + '@babel/plugin-syntax-nullish-coalescing-operator': 7.8.3(@babel/core@7.22.5) + '@babel/plugin-syntax-numeric-separator': 7.10.4(@babel/core@7.22.5) + '@babel/plugin-syntax-object-rest-spread': 7.8.3(@babel/core@7.22.5) + '@babel/plugin-syntax-optional-catch-binding': 7.8.3(@babel/core@7.22.5) + '@babel/plugin-syntax-optional-chaining': 7.8.3(@babel/core@7.22.5) + '@babel/plugin-syntax-top-level-await': 7.14.5(@babel/core@7.22.5) + dev: true + + /babel-preset-jest@27.5.1(@babel/core@7.22.5): resolution: {integrity: sha512-Nptf2FzlPCWYuJg41HBqXVT8ym6bXOevuCTbhxlUpjwtysGaIWFvDEjp4y+G7fl13FgOdjs7P/DmErqH7da0Ag==} engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} peerDependencies: '@babel/core': ^7.0.0 dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 babel-plugin-jest-hoist: 27.5.1 - babel-preset-current-node-syntax: 1.0.1(@babel/core@7.22.8) + babel-preset-current-node-syntax: 1.0.1(@babel/core@7.22.5) dev: true - /babel-preset-solid@1.7.7(@babel/core@7.22.8): - resolution: {integrity: sha512-tdxVzx3kgcIjNXAOmGRbzIhFBPeJjSakiN9yM+IYdL/+LtXNnbGqb0Va5tJb8Sjbk+QVEriovCyuzB5T7jeTvg==} + /babel-preset-solid@1.6.3(@babel/core@7.20.5): + resolution: {integrity: sha512-AQ6aaKQlDAZc3aAS+nFfXbNBf+NeJwKlRA55clj9PQI+Mkqv8JvTOnAEIGfYa0OW0sntMWhNWx+ih/4PK2s3/w==} peerDependencies: '@babel/core': ^7.0.0 dependencies: - '@babel/core': 7.22.8 - babel-plugin-jsx-dom-expressions: 0.36.10(@babel/core@7.22.8) + '@babel/core': 7.20.5 + babel-plugin-jsx-dom-expressions: 0.35.6(@babel/core@7.20.5) dev: true /bail@1.0.5: @@ -10239,6 +11351,7 @@ packages: /bindings@1.5.0: resolution: {integrity: sha512-p2q/t/mhvuOj/UeLlV6566GD/guowlr0hHxClI0W9m7MWYkL1F0hLo+0Aexs9HSPCtR1SXQ0TD3MMKrXZajbiQ==} + requiresBuild: true dependencies: file-uri-to-path: 1.0.0 dev: true @@ -10252,7 +11365,7 @@ packages: dependencies: buffer: 5.7.1 inherits: 2.0.4 - readable-stream: 3.6.2 + readable-stream: 3.6.0 dev: true /blob-util@2.0.2: @@ -10271,19 +11384,19 @@ packages: resolution: {integrity: sha512-eXRvHzWyYPBuB4NBy0cmYQjGitUrtqwbvlzP3G6VFnNRbsZQIxQ10PbKKHt8gZ/HW/D/747aDl+QkDqg3KQLMQ==} dev: true - /body-parser@1.20.1: - resolution: {integrity: sha512-jWi7abTbYwajOytWCQc37VulmWiRae5RyTpaCyDcS5/lMdtwSz5lOpDE67srw/HYe35f1z3fDQw+3txg7gNtWw==} + /body-parser@1.20.0: + resolution: {integrity: sha512-DfJ+q6EPcGKZD1QWUjSpqp+Q7bDQTsQIF4zfUAtZ6qk+H/3/QRhg9CEp39ss+/T2vw0+HaidC0ecJj/DRLIaKg==} engines: {node: '>= 0.8', npm: 1.2.8000 || >= 1.4.16} dependencies: bytes: 3.1.2 - content-type: 1.0.5 + content-type: 1.0.4 debug: 2.6.9 depd: 2.0.0 destroy: 1.2.0 http-errors: 2.0.0 iconv-lite: 0.4.24 on-finished: 2.4.1 - qs: 6.11.0 + qs: 6.10.3 raw-body: 2.5.1 type-is: 1.6.18 unpipe: 1.0.0 @@ -10359,7 +11472,7 @@ packages: /broadcast-channel@3.7.0: resolution: {integrity: sha512-cIAKJXAxGJceNZGTZSBzMxzyOn72cVgPnKx4dc6LRjQgbaJUQqhy5rzL3zbMxkMWsGKkv2hSFkPRMEXfoMZ2Mg==} dependencies: - '@babel/runtime': 7.22.6 + '@babel/runtime': 7.18.9 detect-node: 2.1.0 js-sha3: 0.8.0 microseconds: 0.2.0 @@ -10400,7 +11513,7 @@ packages: resolution: {integrity: sha512-BioO1xf3hFwz4kc6iBhI3ieDFompMhrMlnDFC4/0/vd5MokpuAc3R+LYbwTA9A5Yc9pq9UYPqffKpW2ObuwX5A==} dependencies: cipher-base: 1.0.4 - des.js: 1.1.0 + des.js: 1.0.1 inherits: 2.0.4 safe-buffer: 5.2.1 dev: true @@ -10422,7 +11535,7 @@ packages: elliptic: 6.5.4 inherits: 2.0.4 parse-asn1: 5.1.6 - readable-stream: 3.6.2 + readable-stream: 3.6.0 safe-buffer: 5.2.1 dev: true @@ -10432,15 +11545,15 @@ packages: pako: 1.0.11 dev: true - /browserslist@4.21.9: - resolution: {integrity: sha512-M0MFoZzbUrRU4KNfCrDLnvyE7gub+peetoTid3TBIqtunaDJyXlwhakT+/VkvSXcfIzFfK/nkCs4nmyTmxdNSg==} + /browserslist@4.21.3: + resolution: {integrity: sha512-898rgRXLAyRkM1GryrrBHGkqA5hlpkV5MhtZwg9QXeiyLUYs2k00Un05aX5l2/yJIOObYKOpS2JNo8nJDE7fWQ==} engines: {node: ^6 || ^7 || ^8 || ^9 || ^10 || ^11 || ^12 || >=13.7} hasBin: true dependencies: - caniuse-lite: 1.0.30001515 - electron-to-chromium: 1.4.457 - node-releases: 2.0.13 - update-browserslist-db: 1.0.11(browserslist@4.21.9) + caniuse-lite: 1.0.30001385 + electron-to-chromium: 1.4.237 + node-releases: 2.0.6 + update-browserslist-db: 1.0.5(browserslist@4.21.3) /bser@2.1.1: resolution: {integrity: sha512-gQxTNE/GAfIIrmHLUE3oJyp5FO6HRBfhjnw4/wMmA63ZGDJnWBmgY/lyQBpnDUkGmAhbSe39tx2d/iTOAfglwQ==} @@ -10475,13 +11588,6 @@ packages: ieee754: 1.2.1 dev: true - /buffer@6.0.3: - resolution: {integrity: sha512-FTiCpNxtwiZZHEZbcbTIcZjERVICn9yq/pDFkTl95/AxzD1naBctN7YO68riM/gLSDY7sdrMby8hofADYuuqOA==} - dependencies: - base64-js: 1.5.1 - ieee754: 1.2.1 - dev: true - /builtin-modules@3.3.0: resolution: {integrity: sha512-zhaCDicdLuWN5UbN5IMnFqNMhNfo919sH85y2/ea+5Yg9TsTkeZxpL+JLbp6cgYFS4sRLp3YV4S6yDuqVWHYOw==} engines: {node: '>=6'} @@ -10494,7 +11600,7 @@ packages: /builtins@5.0.1: resolution: {integrity: sha512-qwVpFEHNfhYJIzNRBvd2C1kyo6jz3ZSMPyyuR47OPdiKWlbYnZNyDWuyR175qDnAJLiCo5fBBqPb3RiXgWlkOQ==} dependencies: - semver: 7.5.4 + semver: 7.5.2 dev: true /bumpp@9.1.1: @@ -10503,23 +11609,23 @@ packages: hasBin: true dependencies: '@jsdevtools/ez-spawn': 3.0.4 - c12: 1.4.2 + c12: 1.4.1 cac: 6.7.14 fast-glob: 3.3.0 prompts: 2.4.2 - semver: 7.5.4 + semver: 7.5.2 transitivePeerDependencies: - supports-color dev: true - /bundle-require@4.0.1(esbuild@0.17.19): + /bundle-require@4.0.1(esbuild@0.17.18): resolution: {integrity: sha512-9NQkRHlNdNpDBGmLpngF3EFDcwodhMUuLz9PaWYciVcQF9SE4LFjM2DB/xV1Li5JiuDMv7ZUWuC3rGbqR0MAXQ==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} peerDependencies: esbuild: '>=0.17' dependencies: - esbuild: 0.17.19 - load-tsconfig: 0.2.5 + esbuild: 0.17.18 + load-tsconfig: 0.2.3 dev: true /busboy@1.6.0: @@ -10539,20 +11645,20 @@ packages: engines: {node: '>= 0.8'} dev: true - /c12@1.4.2: - resolution: {integrity: sha512-3IP/MuamSVRVw8W8+CHWAz9gKN4gd+voF2zm/Ln6D25C2RhytEZ1ABbC8MjKr4BR9rhoV1JQ7jJA158LDiTkLg==} + /c12@1.4.1: + resolution: {integrity: sha512-0x7pWfLZpZsgtyotXtuepJc0rZYE0Aw8PwNAXs0jSG9zq6Sl5xmbWnFqfmRY01ieZLHNbvneSFm9/x88CvzAuw==} dependencies: chokidar: 3.5.3 defu: 6.1.2 - dotenv: 16.3.1 + dotenv: 16.0.3 giget: 1.1.2 - jiti: 1.19.1 + jiti: 1.18.2 mlly: 1.4.0 ohash: 1.1.2 pathe: 1.1.1 - perfect-debounce: 1.0.0 + perfect-debounce: 0.1.3 pkg-types: 1.0.3 - rc9: 2.1.1 + rc9: 2.1.0 transitivePeerDependencies: - supports-color dev: true @@ -10587,7 +11693,7 @@ packages: chownr: 1.1.4 figgy-pudding: 3.5.2 glob: 7.2.3 - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 infer-owner: 1.0.4 lru-cache: 5.1.1 mississippi: 3.0.0 @@ -10611,7 +11717,7 @@ packages: glob: 7.2.3 infer-owner: 1.0.4 lru-cache: 6.0.0 - minipass: 3.3.6 + minipass: 3.3.4 minipass-collect: 1.0.2 minipass-flush: 1.0.5 minipass-pipeline: 1.2.4 @@ -10620,7 +11726,7 @@ packages: promise-inflight: 1.0.1(bluebird@3.7.2) rimraf: 3.0.2 ssri: 8.0.1 - tar: 6.1.15 + tar: 6.1.13 unique-filename: 1.1.1 transitivePeerDependencies: - bluebird @@ -10646,8 +11752,8 @@ packages: engines: {node: '>=14.16'} dev: true - /cacheable-request@10.2.12: - resolution: {integrity: sha512-qtWGB5kn2OLjx47pYUkWicyOpK1vy9XZhq8yRTXOy+KAmjjESSRLx6SiExnnaGGUP1NM6/vmygMu0fGylNh9tw==} + /cacheable-request@10.2.8: + resolution: {integrity: sha512-IDVO5MJ4LItE6HKFQTqT2ocAQsisOoCTUDu1ddCmnhyiwFQjXNPp4081Xj23N4tO+AFEFNzGuNEf/c8Gwwt15A==} engines: {node: '>=14.16'} dependencies: '@types/http-cache-semantics': 4.0.1 @@ -10668,7 +11774,7 @@ packages: resolution: {integrity: sha512-7O+FbCihrB5WGbFYesctwmTKae6rOiIzmz1icreWJ+0aA7LJfuqhEso2T9ncpcFtzMQtzXf2QGGueWJGTYsqrA==} dependencies: function-bind: 1.1.1 - get-intrinsic: 1.2.1 + get-intrinsic: 1.2.0 dev: true /call-me-maybe@1.0.2: @@ -10683,7 +11789,7 @@ packages: resolution: {integrity: sha512-gxGWBrTT1JuMx6R+o5PTXMmUnhnVzLQ9SNutD4YqKtI6ap897t3tKECYla6gCWEkplXnlNybEkZg9GEGxKFCgw==} dependencies: pascal-case: 3.1.2 - tslib: 2.6.0 + tslib: 2.5.3 dev: true /camelcase-css@2.0.1: @@ -10716,8 +11822,8 @@ packages: engines: {node: '>=10'} dev: true - /caniuse-lite@1.0.30001515: - resolution: {integrity: sha512-eEFDwUOZbE24sb+Ecsx3+OvNETqjWIdabMy52oOkIgcUtAsQifjUG9q4U9dgTHJM2mfk4uEPxc0+xuFdJ629QA==} + /caniuse-lite@1.0.30001385: + resolution: {integrity: sha512-MpiCqJGhBkHgpyimE9GWmZTnyHyEEM35u115bD3QBrXpjvL/JgcP8cUhKJshfmg4OtEHFenifcK5sZayEw5tvQ==} /capture-exit@2.0.0: resolution: {integrity: sha512-PiT/hQmTonHhl/HFGN+Lx3JJUznrVYJ3+AQsnthneZbvW7x+f08Tk7yLJTLEOUvBTbduLeeBkxEaYXUOUrRq6g==} @@ -10805,11 +11911,6 @@ packages: engines: {node: ^12.17.0 || ^14.13 || >=16.0.0} dev: true - /chalk@5.3.0: - resolution: {integrity: sha512-dLitG79d+GV1Nb/VYcCDFivJeK1hiukt9QjRNVOsUtTy1rR1YJsmpGGTZ3qJos+uw7WmWF4wUwBd9jxjocFC2w==} - engines: {node: ^12.17.0 || ^14.13 || >=16.0.0} - dev: true - /char-regex@1.0.2: resolution: {integrity: sha512-kWWXztvZ5SBQV+eRgKFeh8q5sLuZY2+8WUIzlxWVTg+oGwY14qylx1KbKzHd8P6ZYkAg0xyIDU9JMHhyJMZ1jw==} engines: {node: '>=10'} @@ -10848,7 +11949,7 @@ packages: css-what: 6.1.0 domelementtype: 2.3.0 domhandler: 5.0.3 - domutils: 3.1.0 + domutils: 3.0.1 dev: true /cheerio@1.0.0-rc.12: @@ -10858,8 +11959,8 @@ packages: cheerio-select: 2.1.0 dom-serializer: 2.0.0 domhandler: 5.0.3 - domutils: 3.1.0 - htmlparser2: 8.0.2 + domutils: 3.0.1 + htmlparser2: 8.0.1 parse5: 7.1.2 parse5-htmlparser2-tree-adapter: 7.0.0 dev: true @@ -10869,7 +11970,7 @@ packages: deprecated: Chokidar 2 does not receive security updates since 2019. Upgrade to chokidar 3 with 15x fewer dependencies dependencies: anymatch: 2.0.0 - async-each: 1.0.6 + async-each: 1.0.3 braces: 2.3.2 glob-parent: 3.1.0 inherits: 2.0.4 @@ -10890,7 +11991,7 @@ packages: resolution: {integrity: sha512-Dr3sfKRP6oTcjf2JmUmFJfeVMvXBdegxB0iVQ5eb2V10uFJUCAS8OByZdVAyVb8xXNz3GjjTgj9kLWsZTqE6kw==} engines: {node: '>= 8.10.0'} dependencies: - anymatch: 3.1.3 + anymatch: 3.1.2 braces: 3.0.2 glob-parent: 5.1.2 is-binary-path: 2.1.0 @@ -10910,15 +12011,15 @@ packages: engines: {node: '>=10'} dev: true - /chrome-launcher@0.15.2: - resolution: {integrity: sha512-zdLEwNo3aUVzIhKhTtXfxhdvZhUghrnmkvcAq2NoDd+LeOHKf03H5jwZ8T/STsAlzyALkBVK552iaG1fGf1xVQ==} + /chrome-launcher@0.15.1: + resolution: {integrity: sha512-UugC8u59/w2AyX5sHLZUHoxBAiSiunUhZa3zZwMH6zPVis0C3dDKiRWyUGIo14tTbZHGVviWxv3PQWZ7taZ4fg==} engines: {node: '>=12.13.0'} hasBin: true dependencies: '@types/node': 20.4.1 escape-string-regexp: 4.0.0 is-wsl: 2.2.0 - lighthouse-logger: 1.4.2 + lighthouse-logger: 1.3.0 transitivePeerDependencies: - supports-color dev: true @@ -10941,6 +12042,11 @@ packages: resolution: {integrity: sha512-5tK7EtrZ0N+OLFMthtqOj4fI2Jeb88C4CAZPu25LDVUgXJ0A3Js4PMGqrn0JU1W0Mh1/Z8wZzYPxqUrXeBboCQ==} dev: true + /ci-info@3.7.0: + resolution: {integrity: sha512-2CpRNYmImPx+RXKLq6jko/L07phmS9I02TyqkcNU20GCF/GgaWvc58hPtjxDX8lPpkdwc9sNh72V9k00S7ezog==} + engines: {node: '>=8'} + dev: true + /ci-info@3.8.0: resolution: {integrity: sha512-eXTggHWSooYhq49F2opQhuHWgzucfF2YgODK4e1566GQs5BIfP30B0oenwBJHfWxAs2fyPB1s7Mg949zLf61Yw==} engines: {node: '>=8'} @@ -10953,8 +12059,8 @@ packages: safe-buffer: 5.2.1 dev: true - /cjs-module-lexer@1.2.3: - resolution: {integrity: sha512-0TNiGstbQmCFwt4akjjBg5pLRTSyj/PkWQ1ZoO2zntmg9yLqSRxwEa4iCfQLGjqhiqBfOJa7W/E8wfGrTDmlZQ==} + /cjs-module-lexer@1.2.2: + resolution: {integrity: sha512-cOU9usZw8/dXIXKtwa8pM0OTJQuJkxMN6w30csNRUerHfeQ5R6U3kkU/FtJeIf3M202OHfY2U8ccInBG7/xogA==} dev: true /class-utils@0.3.6: @@ -10967,8 +12073,8 @@ packages: static-extend: 0.1.2 dev: true - /classnames@2.3.2: - resolution: {integrity: sha512-CSbhY4cFEJRe6/GQzIk5qXZ4Jeg5pcsP7b5peFSDpffpe1cqjASH/n9UTjBwOp6XpMSTwQ8Za2K5V02ueA7Tmw==} + /classnames@2.3.1: + resolution: {integrity: sha512-OlQdbZ7gLfGarSqxesMesDa5uz7KFbID8Kpq/SxIoNGDqY8lSYs0D+hhtBXhcdB3rcbXArFr7vlHheLk1voeNA==} dev: false /clean-css@4.2.4: @@ -11009,13 +12115,13 @@ packages: restore-cursor: 4.0.0 dev: true - /cli-spinners@2.9.0: - resolution: {integrity: sha512-4/aL9X3Wh0yiMQlE+eeRhWP6vclO3QRtw1JHKIT0FFUs5FjpFmESqtMvYZ0+lbzBw900b95mS0hohy+qn2VK/g==} + /cli-spinners@2.7.0: + resolution: {integrity: sha512-qu3pN8Y3qHNgE2AFweciB1IfMnmZ/fsNTEE+NOFjmGB2F/7rLhnhzppvpCnN4FovtP26k8lHyy9ptEbNwWFLzw==} engines: {node: '>=6'} dev: true - /cli-table3@0.6.3: - resolution: {integrity: sha512-w5Jac5SykAeZJKntOxJCrm63Eg5/4dhMWIcuTbo9rpE+brgaSZo0RuNJZeOyMgsUdhDeojvgyQLmjI+K50ZGyg==} + /cli-table3@0.6.2: + resolution: {integrity: sha512-QyavHCaIC80cMivimWu4aWHilIpiDpfm3hGmqAmXVL1UsnbLuBSMd21hTX6VY4ZSDSM73ESLeF8TOYId3rBTbw==} engines: {node: 10.* || >= 12.*} dependencies: string-width: 4.2.3 @@ -11095,7 +12201,7 @@ packages: dependencies: '@jridgewell/sourcemap-codec': 1.4.15 '@types/estree': 1.0.1 - acorn: 8.10.0 + acorn: 8.9.0 estree-walker: 3.0.3 periscopic: 3.1.0 dev: true @@ -11112,8 +12218,8 @@ packages: resolution: {integrity: sha512-jEovNnrhMuqyCcjfEJA56v0Xq8SkIoPKDyaHahwo3POf4qcSXqMYuwNcOTzp74vTsR9Tn08z4MxWqAhcekogkQ==} dev: true - /collect-v8-coverage@1.0.2: - resolution: {integrity: sha512-lHl4d5/ONEbLlJvaJNtsF/Lz+WvB07u2ycqTYbdrq7UypDXailES4valYb2eWiJFxZlVmpGekfqoxQhzyFdT4Q==} + /collect-v8-coverage@1.0.1: + resolution: {integrity: sha512-iBPtljfCNcTKNAto0KEtDfZ3qzjJvqE3aTGZsbhjSBlorqpXJlaWWtPO35D+ZImoC3KWejX64o+yPGxhWSTzfg==} dev: true /collection-visit@1.0.0: @@ -11178,8 +12284,8 @@ packages: resolution: {integrity: sha512-GHuDRO12Sypu2cV70d1dkA2EUmXHgntrzbpvOB+Qy+49ypNfGgFQIC2fhhXbnyrJRynDCAARsT7Ou0M6hirpfw==} dev: true - /commander@10.0.1: - resolution: {integrity: sha512-y4Mg2tXshplEbSGzx7amzPwKKOCGuoSRP/CjEdwwk0FOGlUbq6lKuoyDZTNZkmxHdJtp54hdfY/JUrdL7Xfdug==} + /commander@10.0.0: + resolution: {integrity: sha512-zS5PnTI22FIRM6ylNW8G4Ap0IEOyk62fhLSD0+uHRT9McRCLGpkVNvao4bjimpK/GShynyQkFFxHhwMcETmduA==} engines: {node: '>=14'} dev: true @@ -11225,7 +12331,7 @@ packages: buffer-crc32: 0.2.13 crc32-stream: 4.0.2 normalize-path: 3.0.0 - readable-stream: 3.6.2 + readable-stream: 3.6.0 dev: true /compressible@2.0.18: @@ -11259,7 +12365,7 @@ packages: dependencies: buffer-from: 1.1.2 inherits: 2.0.4 - readable-stream: 2.3.8 + readable-stream: 2.3.7 typedarray: 0.0.6 dev: true @@ -11279,9 +12385,8 @@ packages: proto-list: 1.2.4 dev: true - /consola@3.2.3: - resolution: {integrity: sha512-I5qxpzLv+sJhTVEoLYNcTW+bThDCPsit0vLNKShZx6rLtpilNpmmeTPaeqJb9ZE9dV3DGaeby6Vuhrw38WjeyQ==} - engines: {node: ^14.18.0 || >=16.10.0} + /consola@3.1.0: + resolution: {integrity: sha512-rrrJE6rP0qzl/Srg+C9x/AE5Kxfux7reVm1Wh0wCjuXvih6DqZgqDZe8auTD28fzJ9TF0mHlSDrPpWlujQRo1Q==} dev: true /console-browserify@1.2.0: @@ -11303,11 +12408,16 @@ packages: safe-buffer: 5.2.1 dev: true - /content-type@1.0.5: - resolution: {integrity: sha512-nTjqfcBFEipKdXCv4YDQWCfmcLZKm81ldF0pAopTvyrFGVbcR6P/VAAd5G7N+0tTr8QqiU0tFadD6FK4NtJwOA==} + /content-type@1.0.4: + resolution: {integrity: sha512-hIP3EEPs8tB9AT1L+NUqtwOAps4mk2Zob89MWXMHjHWg9milF/j4osnnQLXBCBFBk/tvIG/tUc9mOUJiPBhPXA==} engines: {node: '>= 0.6'} dev: true + /convert-source-map@1.8.0: + resolution: {integrity: sha512-+OQdjP49zViI/6i7nIJpA8rAl4sV/JdPfU9nZs3VqOwGIgizICvuN2ru6fMd+4llL0tar18UYJXfZ/TWtmhUjA==} + dependencies: + safe-buffer: 5.1.2 + /convert-source-map@1.9.0: resolution: {integrity: sha512-ASFBup0Mz1uyiIjANan1jzLQami9z1PoYSZCiiYW2FczPbenXc45FZdBZLzOT+r6+iciuEModtmCti+hjaAk0A==} @@ -11325,8 +12435,8 @@ packages: engines: {node: '>= 0.6'} dev: true - /cookiejar@2.1.4: - resolution: {integrity: sha512-LDx6oHrK+PhzLKJU9j5S7/Y3jM/mUHvD/DeI1WQmJn652iPC5Y4TBzC9l+5OMOXlyTTA+SmVUPm0HQUwpD5Jqw==} + /cookiejar@2.1.3: + resolution: {integrity: sha512-JxbCBUdrfr6AQjOXrxoTvAMJO4HBTUIlBzslcJPAz+/KT8yk53fXun51u+RenNYvad/+Vc2DIz5o9UxlCDymFQ==} dev: true /copy-concurrently@1.0.5: @@ -11345,19 +12455,20 @@ packages: engines: {node: '>=0.10.0'} dev: true - /core-js-compat@3.31.1: - resolution: {integrity: sha512-wIDWd2s5/5aJSdpOJHfSibxNODxoGoWOBHt8JSPB41NOE94M7kuTPZCYLOlTtuoXTsBPKobpJ6T+y0SSy5L9SA==} + /core-js-compat@3.25.0: + resolution: {integrity: sha512-extKQM0g8/3GjFx9US12FAgx8KJawB7RCQ5y8ipYLbmfzEzmFRWdDjIlxDx82g7ygcNG85qMVUSRyABouELdow==} dependencies: - browserslist: 4.21.9 + browserslist: 4.21.3 + semver: 7.0.0 dev: true - /core-js-pure@3.31.1: - resolution: {integrity: sha512-w+C62kvWti0EPs4KPMCMVv9DriHSXfQOCQ94bGGBiEW5rrbtt/Rz8n5Krhfw9cpFyzXBjf3DB3QnPdEzGDY4Fw==} + /core-js-pure@3.25.0: + resolution: {integrity: sha512-IeHpLwk3uoci37yoI2Laty59+YqH9x5uR65/yiA0ARAJrTrN4YU0rmauLWfvqOuk77SlNJXj2rM6oT/dBD87+A==} requiresBuild: true dev: true - /core-js@3.31.1: - resolution: {integrity: sha512-2sKLtfq1eFST7l7v62zaqXacPc7uG8ZAya8ogijLhTtaKNcpzpB4TMoTw2Si+8GYKRwFPMMtUT0263QFWFfqyQ==} + /core-js@3.25.0: + resolution: {integrity: sha512-CVU1xvJEfJGhyCpBrzzzU1kjCfgsGUxhEvwUV2e/cOedYWHdmluamx+knDnmhqALddMG16fZvIqvs9aijsHHaA==} requiresBuild: true dev: true @@ -11388,8 +12499,8 @@ packages: yaml: 1.10.2 dev: true - /cosmiconfig@7.1.0: - resolution: {integrity: sha512-AdmX6xUzdNASswsFtmwSt7Vj8po9IuqXm0UXz7QKPuEUmPB4XyjGfaAr2PSuELMwkRMVH1EpIkX5bTZGRB3eCA==} + /cosmiconfig@7.0.1: + resolution: {integrity: sha512-a1YWNUV2HwGimB7dU2s1wUMurNKjpx60HxBB6xUM8Re+2s1g1IIfJvFR0/iCF+XHdE0GMTKTuLR32UQff4TEyQ==} engines: {node: '>=10'} dependencies: '@types/parse-json': 4.0.0 @@ -11402,7 +12513,7 @@ packages: resolution: {integrity: sha512-0Cbj7gyvFVApzpK/uhCtQ/9kE9UnYpxMzaq5nQQC/Dh4iaj5fxp7iEFIullrYwzj8nf0qnsI1Qsx34hAeAebvw==} engines: {node: '>=8'} dependencies: - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 make-dir: 3.1.0 nested-error-stacks: 2.1.1 p-event: 4.2.0 @@ -11436,7 +12547,7 @@ packages: engines: {node: '>= 10'} dependencies: crc-32: 1.2.2 - readable-stream: 3.6.2 + readable-stream: 3.6.0 dev: true /create-ecdh@4.0.4: @@ -11477,23 +12588,15 @@ packages: node-fetch: 2.6.7 transitivePeerDependencies: - encoding - dev: true /cross-fetch@3.1.6: resolution: {integrity: sha512-riRvo06crlE8HiqOwIpQhxwdOk4fOeR7FVM/wXoxchFEqMNUjvbs3bfo4OTgMEMHzppd4DxFBDbyySj8Cv781g==} dependencies: - node-fetch: 2.6.12 + node-fetch: 2.6.11 transitivePeerDependencies: - encoding dev: true - /cross-fetch@3.1.8: - resolution: {integrity: sha512-cvA+JwZoU0Xq+h6WkMvAUqPEYy92Obet6UdKLfW60qn99ftItKjB5T+BkyWOFWe2pUyfQ+IJHmpOTznqk1M6Kg==} - dependencies: - node-fetch: 2.6.12 - transitivePeerDependencies: - - encoding - /cross-spawn@5.1.0: resolution: {integrity: sha512-pTgQJ5KC0d2hcY8eyL1IzlBPYjTkyH72XRZPnLyKus2mBfNjQs3klqbJU2VILqZryAZUt9JOb3h/mWMy23/f5A==} dependencies: @@ -11508,7 +12611,7 @@ packages: dependencies: nice-try: 1.0.5 path-key: 2.0.1 - semver: 5.7.2 + semver: 5.7.1 shebang-command: 1.2.0 which: 1.3.1 dev: true @@ -11552,7 +12655,7 @@ packages: camelcase: 5.3.1 cssesc: 3.0.0 icss-utils: 4.1.1 - loader-utils: 1.4.2 + loader-utils: 1.4.0 normalize-path: 3.0.0 postcss: 7.0.39 postcss-modules-extract-imports: 2.0.0 @@ -11561,7 +12664,7 @@ packages: postcss-modules-values: 3.0.0 postcss-value-parser: 4.2.0 schema-utils: 2.7.1 - semver: 6.3.1 + semver: 6.3.0 webpack: 4.46.0 dev: true @@ -11581,7 +12684,7 @@ packages: boolbase: 1.0.0 css-what: 6.1.0 domhandler: 5.0.3 - domutils: 3.1.0 + domutils: 3.0.1 nth-check: 2.1.1 dev: true @@ -11645,6 +12748,12 @@ packages: rrweb-cssom: 0.6.0 dev: true + /csstype@2.6.20: + resolution: {integrity: sha512-/WwNkdXfckNgw6S5R125rrW8ez139lBHWouiBvX8dfMFtcn6V81REDqnH7+CRpRipfYlyU1CmOnOxrmGcFOjeA==} + + /csstype@3.1.0: + resolution: {integrity: sha512-uX1KG+x9h5hIJsaKR9xHUeUraxf8IODOwq9JLNPq6BwB04a/xgpq3rcx47l5BZu5zBPlgD342tdke3Hom/nJRA==} + /csstype@3.1.2: resolution: {integrity: sha512-I7K1Uu0MBPzaFKg4nI5Q7Vs2t+3gWWW648spaF+Rg7pI9ds18Ugn+lvg4SHczUdKlHI5LWBXyqfS8+DufyBsgQ==} @@ -11656,19 +12765,19 @@ packages: dev: true optional: true - /cyclist@1.0.2: - resolution: {integrity: sha512-0sVXIohTfLqVIW3kb/0n6IiWF3Ifj5nm2XaSrLq2DI6fKIGa2fYAZdk917rUneaeLVpYfFcyXE2ft0fe3remsA==} + /cyclist@1.0.1: + resolution: {integrity: sha512-NJGVKPS81XejHcLhaLJS7plab0fK3slPh11mESeeDq2W4ZI5kUKK/LRRdVDvjJseojbPB7ZwjnyOybg3Igea/A==} dev: true - /cypress@12.17.1: - resolution: {integrity: sha512-eKfBgO6t8waEyhegL4gxD7tcI6uTCGttu+ZU7y9Hq8BlpMztd7iLeIF4AJFAnbZH1xjX+wwgg4cRKFNSvv3VWQ==} + /cypress@12.16.0: + resolution: {integrity: sha512-mwv1YNe48hm0LVaPgofEhGCtLwNIQEjmj2dJXnAkY1b4n/NE9OtgPph4TyS+tOtYp5CKtRmDvBzWseUXQTjbTg==} engines: {node: ^14.0.0 || ^16.0.0 || >=18.0.0} hasBin: true requiresBuild: true dependencies: - '@cypress/request': 2.88.11 + '@cypress/request': 2.88.10 '@cypress/xvfb': 1.2.4(supports-color@8.1.1) - '@types/node': 14.18.53 + '@types/node': 14.18.26 '@types/sinonjs__fake-timers': 8.1.1 '@types/sizzle': 2.3.3 arch: 2.2.0 @@ -11679,10 +12788,10 @@ packages: chalk: 4.1.2 check-more-types: 2.24.0 cli-cursor: 3.1.0 - cli-table3: 0.6.3 + cli-table3: 0.6.2 commander: 6.2.1 common-tags: 1.8.2 - dayjs: 1.11.9 + dayjs: 1.11.5 debug: 4.3.4(supports-color@8.1.1) enquirer: 2.3.6 eventemitter2: 6.4.7 @@ -11703,15 +12812,15 @@ packages: pretty-bytes: 5.6.0 proxy-from-env: 1.0.0 request-progress: 3.0.0 - semver: 7.5.4 + semver: 7.5.2 supports-color: 8.1.1 tmp: 0.2.1 untildify: 4.0.0 yauzl: 2.10.0 dev: true - /d3-array@3.2.4: - resolution: {integrity: sha512-tdQAmyA18i4J7wprpYq8ClcxZy3SC31QMeByyCFyRt7BVHdREQZ5lpzoe5mFEYZUWe+oq8HBvk9JjpibyEV4Jg==} + /d3-array@3.2.0: + resolution: {integrity: sha512-3yXFQo0oG3QCxbF06rMPFyGRMGJNS7NvsV1+2joOjbBE+9xvWQ8+GcMJAjRCzw06zQ3/arXeJgbPYcjUCuC+3g==} engines: {node: '>=12'} dependencies: internmap: 2.0.3 @@ -11737,6 +12846,7 @@ packages: /d3-ease@3.0.1: resolution: {integrity: sha512-wR/XK3D3XcLIZwpbvQwQ5fK+8Ykds1ip7A2Txe0yxncXSdq1L9skcG7blcedkOX+ZcgxGAmLX1FrRGbADwzi0w==} engines: {node: '>=12'} + dev: true /d3-force@3.0.0: resolution: {integrity: sha512-zxV/SsA+U4yte8051P4ECydjD/S+qeYtnaIyAs9tgHCqfguma/aAQDjo85A9Z6EKhBirHRJHXIgJUlffT4wdLg==} @@ -11769,8 +12879,8 @@ packages: dependencies: d3-color: 3.1.0 - /d3-path@3.1.0: - resolution: {integrity: sha512-p3KP5HCf/bvjBSSKuXid6Zqijx7wIfNW+J/maPs+iwR35at5JCbLUT0LzF1cnjbCHWhqzQTIN2Jpe8pRebIEFQ==} + /d3-path@3.0.1: + resolution: {integrity: sha512-gq6gZom9AFZby0YLduxT1qmrp4xpBA1YZr19OI717WIdKE2OM5ETq5qrHLb301IgxhLwcuxvGZVLeeWc/k1I6w==} engines: {node: '>=12'} dev: false @@ -11783,10 +12893,10 @@ packages: resolution: {integrity: sha512-GZW464g1SH7ag3Y7hXjf8RoUuAFIqklOAq3MRl4OaWabTFJY9PN/E1YklhXLh+OQ3fM9yS2nOkCoS+WLZ6kvxQ==} engines: {node: '>=12'} dependencies: - d3-array: 3.2.4 + d3-array: 3.2.0 d3-format: 3.1.0 d3-interpolate: 3.0.1 - d3-time: 3.1.0 + d3-time: 3.0.0 d3-time-format: 4.1.0 dev: false @@ -11795,30 +12905,31 @@ packages: engines: {node: '>=12'} dev: true - /d3-shape@3.2.0: - resolution: {integrity: sha512-SaLBuwGm3MOViRq2ABk3eLoxwZELpH6zhl3FbAoJ7Vm1gofKx6El1Ib5z23NUEhF9AsGl7y+dzLe5Cw2AArGTA==} + /d3-shape@3.1.0: + resolution: {integrity: sha512-tGDh1Muf8kWjEDT/LswZJ8WF85yDZLvVJpYU9Nq+8+yW1Z5enxrmXOhTArlkaElU+CTn0OTVNli+/i+HP45QEQ==} engines: {node: '>=12'} dependencies: - d3-path: 3.1.0 + d3-path: 3.0.1 dev: false /d3-time-format@4.1.0: resolution: {integrity: sha512-dJxPBlzC7NugB2PDLwo9Q8JiTR3M3e4/XANkreKSUxF8vvXKqm1Yfq4Q5dl8budlunRVlUUaDUgFt7eA8D6NLg==} engines: {node: '>=12'} dependencies: - d3-time: 3.1.0 + d3-time: 3.0.0 dev: false - /d3-time@3.1.0: - resolution: {integrity: sha512-VqKjzBLejbSMT4IgbmVgDjpkYrNWUYJnbCGo874u7MMKIWsILRX+OpX/gTk8MqjpT1A/c6HY2dCA77ZN0lkQ2Q==} + /d3-time@3.0.0: + resolution: {integrity: sha512-zmV3lRnlaLI08y9IMRXSDshQb5Nj77smnfpnd2LrBa/2K281Jijactokeak14QacHs/kKq0AQ121nidNYlarbQ==} engines: {node: '>=12'} dependencies: - d3-array: 3.2.4 + d3-array: 3.2.0 dev: false /d3-timer@3.0.1: resolution: {integrity: sha512-ndfJ/JxxMd3nw31uyKoY2naivF+r29V+Lc0svZxe1JvvIRmi8hUsrMvdOwgS1o6uBHmiz91geQ0ylPP0aj1VUA==} engines: {node: '>=12'} + dev: true /d3-transition@3.0.1(d3-selection@3.0.0): resolution: {integrity: sha512-ApKvfjsSR6tg06xrL434C0WydLr7JewBB3V+/39RMHsaXTOG0zmt/OAXeng5M5LBm0ojmxJrpomQVZ1aPvBL4w==} @@ -11879,14 +12990,12 @@ packages: whatwg-url: 12.0.1 dev: true - /date-fns@2.30.0: - resolution: {integrity: sha512-fnULvOpxnC5/Vg3NCiWelDsLiUc9bRwAPs/+LfTLNvetFCtCTN+yQz15C/fs4AwX1R9K5GLtLfn8QW+dWisaAw==} + /date-fns@2.29.2: + resolution: {integrity: sha512-0VNbwmWJDS/G3ySwFSJA3ayhbURMTJLtwM2DTxf9CWondCnh6DTNlO9JgRSq6ibf4eD0lfMJNBxUdEAHHix+bA==} engines: {node: '>=0.11'} - dependencies: - '@babel/runtime': 7.22.6 - /dayjs@1.11.9: - resolution: {integrity: sha512-QvzAURSbQ0pKdIye2txOzNaHmxtUBXerpY0FJsFXUMKbIZeFm5ht1LS/jFsrncjnmtv8HsG0W2g6c0zUjZWmpA==} + /dayjs@1.11.5: + resolution: {integrity: sha512-CAdX5Q3YW3Gclyo5Vpqkgpj8fSdLQcRuzfX6mC6Phy0nfJ0eGYOeS7m4mt2plDWLAtA4TqTakvbboHvUxfe4iA==} dev: true /de-indent@1.0.2: @@ -11943,6 +13052,14 @@ packages: resolution: {integrity: sha512-qIMFpTMZmny+MMIitAB6D7iVPEorVw6YQRWkvarTkT4tBeSLLiHzcwj6q0MmYSFCiVpiqPJTJEYIrpcPzVEIvg==} dev: false + /decimal.js@10.4.0: + resolution: {integrity: sha512-Nv6ENEzyPQ6AItkGwLE2PGKinZZ9g59vSh2BeH6NqPu0OTKZ5ruJsVqh/orbAnqXc9pBbgXAIrc2EyaCj8NpGg==} + dev: true + + /decimal.js@10.4.2: + resolution: {integrity: sha512-ic1yEvwT6GuvaYwBLLY6/aFFgjZdySKTE8en/fkU3QICTmRtgtSlFn0u0BXN06InZwtfCelR7j8LRiDI/02iGA==} + dev: true + /decimal.js@10.4.3: resolution: {integrity: sha512-VBBaLc1MgL5XpzgIP7ny5Z6Nx3UrRkIViUkPUdtl9aya5amy3De1gsUUSB1g3+3sExYNjCAsAznmukyxCb1GRA==} dev: true @@ -11964,8 +13081,8 @@ packages: to-data-view: 1.1.0 dev: true - /decode-uri-component@0.2.2: - resolution: {integrity: sha512-FqUYQ+8o158GyGTrMFJms9qh3CqTKvAqgqsTnkLI8sKu0028orqBhxNMFkFen0zGyg6epACD32pjVk58ngIErQ==} + /decode-uri-component@0.2.0: + resolution: {integrity: sha512-hjf+xovcEn31w/EUYdTXQh/8smFL/dzYjohQGEIgjyNavaJfBY2p5F527Bo1VPATxv0VYTUC2bOcXvqFwk78Og==} engines: {node: '>=0.10'} dev: true @@ -11987,13 +13104,13 @@ packages: type-detect: 4.0.8 dev: false - /deep-equal@2.2.2: - resolution: {integrity: sha512-xjVyBf0w5vH0I42jdAZzOKVldmPgSulmiyPRywoyq7HXC9qdgo17kxJE+rdnif5Tz6+pIrpJI8dCpMNLIGkUiA==} + /deep-equal@2.2.1: + resolution: {integrity: sha512-lKdkdV6EOGoVn65XaOsPdH4rMxTZOnmFyuIkMjM1i5HHCbfjC97dawgTAy0deYNfuqUqW+Q5VrVaQYtUpSd6yQ==} dependencies: array-buffer-byte-length: 1.0.0 call-bind: 1.0.2 es-get-iterator: 1.1.3 - get-intrinsic: 1.2.1 + get-intrinsic: 1.2.0 is-arguments: 1.1.1 is-array-buffer: 3.0.2 is-date-object: 1.0.5 @@ -12007,7 +13124,7 @@ packages: side-channel: 1.0.4 which-boxed-primitive: 1.0.2 which-collection: 1.0.1 - which-typed-array: 1.1.10 + which-typed-array: 1.1.9 dev: true /deep-extend@0.6.0: @@ -12019,8 +13136,8 @@ packages: resolution: {integrity: sha512-oIPzksmTg4/MriiaYGO+okXDT7ztn/w3Eptv/+gSIdMdKsJo0u4CfYNFJPy+4SKMuCqGw2wxnA+URMg3t8a/bQ==} dev: true - /deepmerge-ts@5.1.0: - resolution: {integrity: sha512-eS8dRJOckyo9maw9Tu5O5RUi/4inFLrnoLkBe3cPfDMx3WZioXtmOew4TXQaxq7Rhl4xjDtR7c6x8nNTxOvbFw==} + /deepmerge-ts@5.0.0: + resolution: {integrity: sha512-esq9xUO8+CQCG63IlpkoOBNlpm1m4WBm0NRLFrGL/dcgzqWi1tmTLfG7QTvffqYt6T+dS+xaxrHxdexqGWkV1g==} engines: {node: '>=16.0.0'} dev: true @@ -12041,8 +13158,8 @@ packages: dev: true optional: true - /defaults@1.0.4: - resolution: {integrity: sha512-eFuaLoy/Rxalv2kr+lqMlUnrDWV+3j4pljOIJgLIhI058IQfWJ7vXhyEIHu+HtC738klGALYxOKDO0bQP3tg8A==} + /defaults@1.0.3: + resolution: {integrity: sha512-s82itHOnYrN0Ib8r+z7laQz3sdE+4FP3d9Q7VLO7U+KRT+CR0GsWuyHxzdAY82I7cXv0G/twrqomTJLOssO5HA==} dependencies: clone: 1.0.4 dev: true @@ -12110,13 +13227,17 @@ packages: engines: {node: '>=6'} dev: true - /des.js@1.1.0: - resolution: {integrity: sha512-r17GxjhUCjSRy8aiJpr8/UadFIzMzJGexI3Nmz4ADi9LYSFx4gTBp80+NaX/YsXWWLhpZ7v/v/ubEc/bCNfKwg==} + /des.js@1.0.1: + resolution: {integrity: sha512-Q0I4pfFrv2VPd34/vfLrFOoRmlYj3OV50i7fskps1jZWK1kApMWWT9G6RRUeYedLcBDIhnSDaUvJMb3AhUlaEA==} dependencies: inherits: 2.0.4 minimalistic-assert: 1.0.1 dev: true + /destr@1.2.0: + resolution: {integrity: sha512-JG+cG4ZPB1L27sl2C2URg8MIOmIUtTbE5wEx02BpmrTCqg/hXxFKXsYsnODl5PdpqNRaS1KQGUQ56V8jk8XpYQ==} + dev: true + /destr@1.2.2: resolution: {integrity: sha512-lrbCJwD9saUQrqUfXvl6qoM+QN3W7tLV5pAOs+OqOmopCCz/JkE05MHedJR1xfk4IAnZuJXPVuN5+7jNA2ZCiA==} dev: true @@ -12161,12 +13282,13 @@ packages: execa: 5.1.1 dev: true - /detect-port@1.5.1: - resolution: {integrity: sha512-aBzdj76lueB6uUst5iAs7+0H/oOjqI5D16XUWxlWMIMROhcM0rfsNVk93zTngq1dDNpoXRr++Sus7ETAExppAQ==} + /detect-port@1.3.0: + resolution: {integrity: sha512-E+B1gzkl2gqxt1IhUzwjrxBKRqx1UzC3WLONHinn8S3T6lwV/agVCyitiFOsGJ/eYuEUBvD71MZHy3Pv1G9doQ==} + engines: {node: '>= 4.2.1'} hasBin: true dependencies: - address: 1.2.2 - debug: 4.3.4(supports-color@8.1.1) + address: 1.2.0 + debug: 2.6.9 transitivePeerDependencies: - supports-color dev: true @@ -12197,14 +13319,14 @@ packages: '@wdio/protocols': 8.11.0 '@wdio/types': 8.10.4 '@wdio/utils': 8.12.1 - chrome-launcher: 0.15.2 + chrome-launcher: 0.15.1 edge-paths: 3.0.5 import-meta-resolve: 3.0.0 puppeteer-core: 20.3.0(typescript@5.1.6) query-selector-shadow-dom: 1.0.1 - ua-parser-js: 1.0.35 + ua-parser-js: 1.0.34 uuid: 9.0.0 - which: 3.0.1 + which: 3.0.0 transitivePeerDependencies: - bufferutil - encoding @@ -12213,8 +13335,8 @@ packages: - utf-8-validate dev: true - /dezalgo@1.0.4: - resolution: {integrity: sha512-rXSP0bf+5n0Qonsb+SVVfNfIsimO4HEtmnIpPHY8Q1UCzKlQrDMfdobr8nJOOsRgWCyMRqeSBQzmWUMq7zvVig==} + /dezalgo@1.0.3: + resolution: {integrity: sha512-K7i4zNfT2kgQz3GylDw40ot9GAE47sFZ9EXHFSPP6zONLgH6kWXE0KWJchkbQJLBkRazq4APwZ4OwiFFlT95OQ==} dependencies: asap: 2.0.6 wrappy: 1.0.2 @@ -12257,7 +13379,7 @@ packages: dev: true /discontinuous-range@1.0.0: - resolution: {integrity: sha512-c68LpLbO+7kP/b1Hr1qs8/BJ09F5khZGTxqxZuhzxpmwJKOgRFHJWIb9/KmqnqHhLdO55aOxFH/EGBvUQbL/RQ==} + resolution: {integrity: sha1-44Mx8IRLukm5qctxx3FYWqsbxlo=} dev: true /doctrine@2.1.0: @@ -12274,8 +13396,8 @@ packages: esutils: 2.0.3 dev: true - /dom-accessibility-api@0.5.16: - resolution: {integrity: sha512-X7BJ2yElsnOJ30pZF4uIIDfBEVgF4XEBxL9Bxhy6dnrm5hkzqmsWHGTiHqRiITNhMyFLyAiWndIJP7Z1NTteDg==} + /dom-accessibility-api@0.5.14: + resolution: {integrity: sha512-NMt+m9zFMPZe0JcY9gN224Qvk6qLIdqex29clBvc/y75ZBX9YA9wNK3frsYvu2DI1xcCIwxwnX+TlsJ2DSOADg==} dev: true /dom-converter@0.2.0: @@ -12291,13 +13413,13 @@ packages: /dom-helpers@3.4.0: resolution: {integrity: sha512-LnuPJ+dwqKDIyotW1VzmOZ5TONUN7CwkCR5hrgawTUbkBGYdeoNLZo6nNfGkCrjtE1nXXaj7iMMpDa8/d9WoIA==} dependencies: - '@babel/runtime': 7.22.6 + '@babel/runtime': 7.18.9 dev: false /dom-helpers@5.2.1: resolution: {integrity: sha512-nRCa7CK3VTrM2NmGkIy4cbK7IZlgBE/PYMn55rrXefr5xXDP0LdtfPnblFDoVdcAfslJ7or6iqAUnx0CCGIWQA==} dependencies: - '@babel/runtime': 7.22.6 + '@babel/runtime': 7.18.9 csstype: 3.1.2 dev: false @@ -12373,8 +13495,8 @@ packages: domhandler: 4.3.1 dev: true - /domutils@3.1.0: - resolution: {integrity: sha512-H78uMmQtI2AhgDJjWeQmHwJJ2bLPD3GMmO7Zja/ZZh84wkm+4ut+IUnUdRa8uCGX88DiVx1j6FRe1XfxEgjEZA==} + /domutils@3.0.1: + resolution: {integrity: sha512-z08c1l761iKhDFtfXO04C7kTdPBLi41zwOZl00WS8b5eiaebNpY00HKbztwBq+e3vyqWNwWF3mP9YLUeqIrF+Q==} dependencies: dom-serializer: 2.0.0 domelementtype: 2.3.0 @@ -12385,15 +13507,15 @@ packages: resolution: {integrity: sha512-Kv5nKlh6yRrdrGvxeJ2e5y2eRUpkUosIW4A2AS38zwSz27zu7ufDwQPi5Jhs3XAlGNetl3bmnGhQsMtkKJnj3w==} dependencies: no-case: 3.0.4 - tslib: 2.6.0 + tslib: 2.5.3 dev: true /dotenv-expand@5.1.0: resolution: {integrity: sha512-YXQl1DSa4/PQyRfgrv6aoNjhasp/p4qs9FjJ4q4cQk+8m4r6k4ZSiEyytKG8f8W9gi8WsQtIObNmKd+tMzNTmA==} dev: true - /dotenv@16.3.1: - resolution: {integrity: sha512-IPzF4w4/Rd94bA9imS68tZBaYyBWSCE47V1RGuMrB94iyTOIEwRmVL2x/4An+6mETpLrKJ5hQkB8W4kFAadeIQ==} + /dotenv@16.0.3: + resolution: {integrity: sha512-7GO6HghkA5fYG9TYnNxi14/7K9f5occMlp3zXAuSxn7CKCxt9xbNWG7yF8hTCSUchlfWSe3uLmlPfigevRItzQ==} engines: {node: '>=12'} dev: true @@ -12411,7 +13533,7 @@ packages: dependencies: end-of-stream: 1.4.4 inherits: 2.0.4 - readable-stream: 2.3.8 + readable-stream: 2.3.7 stream-shift: 1.0.1 dev: true @@ -12440,24 +13562,24 @@ packages: dependencies: commander: 2.20.3 lru-cache: 4.1.5 - semver: 5.7.2 + semver: 5.7.1 sigmund: 1.0.1 dev: true /ee-first@1.1.1: - resolution: {integrity: sha512-WMwm9LhRUo+WUaRN+vRuETqG89IgZphVSNkdFgeb6sS/E4OrDIN7t48CAewSHXc6C8lefD8KKfr5vY61brQlow==} + resolution: {integrity: sha1-WQxhFWsK4vTwJVcyoViyZrxWsh0=} dev: true - /ejs@3.1.9: - resolution: {integrity: sha512-rC+QVNMJWv+MtPgkt0y+0rVEIdbtxVADApW9JXrUVlzHetgcyczP/E7DJmWJ4fJCZF2cPcBk0laWO9ZHMG3DmQ==} + /ejs@3.1.8: + resolution: {integrity: sha512-/sXZeMlhS0ArkfX2Aw780gJzXSMPnKjtspYZv+f3NiKLlubezAHDU5+9xz6gd3/NhG3txQCo6xlglmTS+oTGEQ==} engines: {node: '>=0.10.0'} hasBin: true dependencies: - jake: 10.8.7 + jake: 10.8.5 dev: true - /electron-to-chromium@1.4.457: - resolution: {integrity: sha512-/g3UyNDmDd6ebeWapmAoiyy+Sy2HyJ+/X8KyvNeHfKRFfHaA2W8oF5fxD5F3tjBDcjpwo0iek6YNgxNXDBoEtA==} + /electron-to-chromium@1.4.237: + resolution: {integrity: sha512-vxVyGJcsgArNOVUJcXm+7iY3PJAfmSapEszQD1HbyPLl0qoCmNQ1o/EX3RI7Et5/88In9oLxX3SGF8J3orkUgA==} /elliptic@6.5.4: resolution: {integrity: sha512-iLhC6ULemrljPZb+QutR5TQGB+pdW6KGD5RSegS+8sorOZT+rdQFbsQFJgvN3eRqNALqJer4oQ16YvJHlU8hzQ==} @@ -12512,16 +13634,16 @@ packages: resolution: {integrity: sha512-Nv9m36S/vxpsI+Hc4/ZGRs0n9mXqSWGGq49zxb/cJfPAQMbUtttJAlNPS4AQzaBdw/pKskw5bMbekT/Y7W/Wlg==} engines: {node: '>=6.9.0'} dependencies: - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 memory-fs: 0.5.0 tapable: 1.1.3 dev: true - /enhanced-resolve@5.15.0: - resolution: {integrity: sha512-LXYT42KJ7lpIKECr2mAXIaMldcNCh/7E0KBKOu4KSfkHmP+mZmSs+8V5gBAqisWBy0OO4W5Oyys0GO1Y8KtdKg==} + /enhanced-resolve@5.10.0: + resolution: {integrity: sha512-T0yTFjdpldGY8PmuXXR0PyQ1ufZpEGiHVrp7zHKB7jdR4qlmZHhONVM5AQOAWXuF/w3dnHbEQVrNptJgt7F+cQ==} engines: {node: '>=10.13.0'} dependencies: - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 tapable: 2.2.1 dev: true @@ -12541,8 +13663,8 @@ packages: engines: {node: '>=0.12'} dev: true - /enzyme-shallow-equal@1.0.5: - resolution: {integrity: sha512-i6cwm7hN630JXenxxJFBKzgLC3hMTafFQXflvzHgPmDhOBhxUWDe8AeRv1qp2/uWJ2Y8z5yLWMzmAfkTOiOCZg==} + /enzyme-shallow-equal@1.0.4: + resolution: {integrity: sha512-MttIwB8kKxypwHvRynuC3ahyNc+cFbR8mjVIltnmzQ0uKGqmsfO4bfBuLxb0beLNPhjblUEYvEbsg+VSygvF1Q==} dependencies: has: 1.0.3 object-is: 1.1.5 @@ -12551,28 +13673,28 @@ packages: /enzyme@3.11.0: resolution: {integrity: sha512-Dw8/Gs4vRjxY6/6i9wU0V+utmQO9kvh9XLnz3LIudviOnVYDEe2ec+0k+NQoMamn1VrjKgCUOWj5jG/5M5M0Qw==} dependencies: - array.prototype.flat: 1.3.1 + array.prototype.flat: 1.3.0 cheerio: 1.0.0-rc.12 - enzyme-shallow-equal: 1.0.5 + enzyme-shallow-equal: 1.0.4 function.prototype.name: 1.1.5 has: 1.0.3 html-element-map: 1.3.1 is-boolean-object: 1.1.2 - is-callable: 1.2.7 + is-callable: 1.2.4 is-number-object: 1.0.7 is-regex: 1.1.4 is-string: 1.0.7 is-subset: 0.1.1 lodash.escape: 4.0.1 lodash.isequal: 4.5.0 - object-inspect: 1.12.3 + object-inspect: 1.12.2 object-is: 1.1.5 object.assign: 4.1.4 - object.entries: 1.1.6 - object.values: 1.1.6 + object.entries: 1.1.5 + object.values: 1.1.5 raf: 3.4.1 rst-selector-parser: 2.2.3 - string.prototype.trim: 1.2.7 + string.prototype.trim: 1.2.6 dev: true /errno@0.1.8: @@ -12593,44 +13715,34 @@ packages: stackframe: 1.3.4 dev: true - /es-abstract@1.21.2: - resolution: {integrity: sha512-y/B5POM2iBnIxCiernH1G7rC9qQoM77lLIMQLuob0zhp8C56Po81+2Nj0WFKnd0pNReDTnkYryc+zhOzpEIROg==} + /es-abstract@1.20.4: + resolution: {integrity: sha512-0UtvRN79eMe2L+UNEF1BwRe364sj/DXhQ/k5FmivgoSdpM90b8Jc0mDzKMGo7QS0BVbOP/bTwBKNnDc9rNzaPA==} engines: {node: '>= 0.4'} dependencies: - array-buffer-byte-length: 1.0.0 - available-typed-arrays: 1.0.5 call-bind: 1.0.2 - es-set-tostringtag: 2.0.1 es-to-primitive: 1.2.1 + function-bind: 1.1.1 function.prototype.name: 1.1.5 - get-intrinsic: 1.2.1 + get-intrinsic: 1.2.0 get-symbol-description: 1.0.0 - globalthis: 1.0.3 - gopd: 1.0.1 has: 1.0.3 has-property-descriptors: 1.0.0 - has-proto: 1.0.1 has-symbols: 1.0.3 internal-slot: 1.0.5 - is-array-buffer: 3.0.2 is-callable: 1.2.7 is-negative-zero: 2.0.2 is-regex: 1.1.4 is-shared-array-buffer: 1.0.2 is-string: 1.0.7 - is-typed-array: 1.1.10 is-weakref: 1.0.2 object-inspect: 1.12.3 object-keys: 1.1.1 object.assign: 4.1.4 regexp.prototype.flags: 1.5.0 safe-regex-test: 1.0.0 - string.prototype.trim: 1.2.7 - string.prototype.trimend: 1.0.6 - string.prototype.trimstart: 1.0.6 - typed-array-length: 1.0.4 + string.prototype.trimend: 1.0.5 + string.prototype.trimstart: 1.0.5 unbox-primitive: 1.0.2 - which-typed-array: 1.1.10 dev: true /es-array-method-boxes-properly@1.0.0: @@ -12641,7 +13753,7 @@ packages: resolution: {integrity: sha512-sPZmqHBe6JIiTfN5q2pEi//TwxmAFHwj/XEuYjTuse78i8KxaqMTTzxPoFKuzRpDpTJ+0NAbpfenkmH2rePtuw==} dependencies: call-bind: 1.0.2 - get-intrinsic: 1.2.1 + get-intrinsic: 1.2.0 has-symbols: 1.0.3 is-arguments: 1.1.1 is-map: 2.0.2 @@ -12655,17 +13767,8 @@ packages: resolution: {integrity: sha512-1HQ2M2sPtxwnvOvT1ZClHyQDiggdNjURWpY2we6aMKCQiUVxTmVs2UYPLIrD84sS+kMdUwfBSylbJPwNnBrnHQ==} dev: true - /es-module-lexer@1.3.0: - resolution: {integrity: sha512-vZK7T0N2CBmBOixhmjdqx2gWVbFZ4DXZ/NyRMZVlJXPa7CyFS+/a4QQsDGDQy9ZfEzxFuNEsMLeQJnKP2p5/JA==} - dev: true - - /es-set-tostringtag@2.0.1: - resolution: {integrity: sha512-g3OMbtlwY3QewlqAiMLI47KywjWZoEytKr8pf6iTC8uJq5bIAH52Z9pnQ8pVL6whrCto53JZDuUIsifGeLorTg==} - engines: {node: '>= 0.4'} - dependencies: - get-intrinsic: 1.2.1 - has: 1.0.3 - has-tostringtag: 1.0.0 + /es-module-lexer@1.1.0: + resolution: {integrity: sha512-fJg+1tiyEeS8figV+fPcPpm8WqJEflG3yPU0NOm5xMvrNkuiy7HzX/Ljng4Y0hAoiw4/3hQTCFYw+ub8+a2pRA==} dev: true /es-shim-unscopables@1.0.0: @@ -12692,8 +13795,8 @@ packages: resolution: {integrity: sha512-SOp9Phqvqn7jtEUxPWdWfWoLmyt2VaJ6MpvP9Comy1MceMXqE6bxvaTu4iaxpYYPzhny28Lc+M87/c2cPK6lDg==} dev: true - /es6-shim@0.35.8: - resolution: {integrity: sha512-Twf7I2v4/1tLoIXMT8HlqaBSS5H2wQTs2wx3MNYCI8K1R1/clXyCazrcVCPm/FuO9cyV8+leEaZOWD5C253NDg==} + /es6-shim@0.35.6: + resolution: {integrity: sha512-EmTr31wppcaIAgblChZiuN/l9Y7DPyw8Xtbg7fIVngn6zMW+IEBJDJngeKC3x6wr0V/vcA2wqeFnaw1bFJbDdA==} dev: true /esbuild-android-64@0.14.54: @@ -12705,6 +13808,15 @@ packages: dev: false optional: true + /esbuild-android-64@0.15.18: + resolution: {integrity: sha512-wnpt3OXRhcjfIDSZu9bnzT4/TNTDsOUvip0foZOUBG7QbSt//w3QV4FInVJxNhKc/ErhUxc5z4QjHtMi7/TbgA==} + engines: {node: '>=12'} + cpu: [x64] + os: [android] + requiresBuild: true + dev: true + optional: true + /esbuild-android-arm64@0.14.54: resolution: {integrity: sha512-F9E+/QDi9sSkLaClO8SOV6etqPd+5DgJje1F9lOWoNncDdOBL2YF59IhsWATSt0TLZbYCf3pNlTHvVV5VfHdvg==} engines: {node: '>=12'} @@ -12714,6 +13826,15 @@ packages: dev: false optional: true + /esbuild-android-arm64@0.15.18: + resolution: {integrity: sha512-G4xu89B8FCzav9XU8EjsXacCKSG2FT7wW9J6hOc18soEHJdtWu03L3TQDGf0geNxfLTtxENKBzMSq9LlbjS8OQ==} + engines: {node: '>=12'} + cpu: [arm64] + os: [android] + requiresBuild: true + dev: true + optional: true + /esbuild-darwin-64@0.14.54: resolution: {integrity: sha512-jtdKWV3nBviOd5v4hOpkVmpxsBy90CGzebpbO9beiqUYVMBtSc0AL9zGftFuBon7PNDcdvNCEuQqw2x0wP9yug==} engines: {node: '>=12'} @@ -12723,6 +13844,15 @@ packages: dev: false optional: true + /esbuild-darwin-64@0.15.18: + resolution: {integrity: sha512-2WAvs95uPnVJPuYKP0Eqx+Dl/jaYseZEUUT1sjg97TJa4oBtbAKnPnl3b5M9l51/nbx7+QAEtuummJZW0sBEmg==} + engines: {node: '>=12'} + cpu: [x64] + os: [darwin] + requiresBuild: true + dev: true + optional: true + /esbuild-darwin-arm64@0.14.54: resolution: {integrity: sha512-OPafJHD2oUPyvJMrsCvDGkRrVCar5aVyHfWGQzY1dWnzErjrDuSETxwA2HSsyg2jORLY8yBfzc1MIpUkXlctmw==} engines: {node: '>=12'} @@ -12732,6 +13862,15 @@ packages: dev: false optional: true + /esbuild-darwin-arm64@0.15.18: + resolution: {integrity: sha512-tKPSxcTJ5OmNb1btVikATJ8NftlyNlc8BVNtyT/UAr62JFOhwHlnoPrhYWz09akBLHI9nElFVfWSTSRsrZiDUA==} + engines: {node: '>=12'} + cpu: [arm64] + os: [darwin] + requiresBuild: true + dev: true + optional: true + /esbuild-freebsd-64@0.14.54: resolution: {integrity: sha512-OKwd4gmwHqOTp4mOGZKe/XUlbDJ4Q9TjX0hMPIDBUWWu/kwhBAudJdBoxnjNf9ocIB6GN6CPowYpR/hRCbSYAg==} engines: {node: '>=12'} @@ -12741,6 +13880,15 @@ packages: dev: false optional: true + /esbuild-freebsd-64@0.15.18: + resolution: {integrity: sha512-TT3uBUxkteAjR1QbsmvSsjpKjOX6UkCstr8nMr+q7zi3NuZ1oIpa8U41Y8I8dJH2fJgdC3Dj3CXO5biLQpfdZA==} + engines: {node: '>=12'} + cpu: [x64] + os: [freebsd] + requiresBuild: true + dev: true + optional: true + /esbuild-freebsd-arm64@0.14.54: resolution: {integrity: sha512-sFwueGr7OvIFiQT6WeG0jRLjkjdqWWSrfbVwZp8iMP+8UHEHRBvlaxL6IuKNDwAozNUmbb8nIMXa7oAOARGs1Q==} engines: {node: '>=12'} @@ -12750,6 +13898,15 @@ packages: dev: false optional: true + /esbuild-freebsd-arm64@0.15.18: + resolution: {integrity: sha512-R/oVr+X3Tkh+S0+tL41wRMbdWtpWB8hEAMsOXDumSSa6qJR89U0S/PpLXrGF7Wk/JykfpWNokERUpCeHDl47wA==} + engines: {node: '>=12'} + cpu: [arm64] + os: [freebsd] + requiresBuild: true + dev: true + optional: true + /esbuild-linux-32@0.14.54: resolution: {integrity: sha512-1ZuY+JDI//WmklKlBgJnglpUL1owm2OX+8E1syCD6UAxcMM/XoWd76OHSjl/0MR0LisSAXDqgjT3uJqT67O3qw==} engines: {node: '>=12'} @@ -12759,6 +13916,15 @@ packages: dev: false optional: true + /esbuild-linux-32@0.15.18: + resolution: {integrity: sha512-lphF3HiCSYtaa9p1DtXndiQEeQDKPl9eN/XNoBf2amEghugNuqXNZA/ZovthNE2aa4EN43WroO0B85xVSjYkbg==} + engines: {node: '>=12'} + cpu: [ia32] + os: [linux] + requiresBuild: true + dev: true + optional: true + /esbuild-linux-64@0.14.54: resolution: {integrity: sha512-EgjAgH5HwTbtNsTqQOXWApBaPVdDn7XcK+/PtJwZLT1UmpLoznPd8c5CxqsH2dQK3j05YsB3L17T8vE7cp4cCg==} engines: {node: '>=12'} @@ -12768,6 +13934,15 @@ packages: dev: false optional: true + /esbuild-linux-64@0.15.18: + resolution: {integrity: sha512-hNSeP97IviD7oxLKFuii5sDPJ+QHeiFTFLoLm7NZQligur8poNOWGIgpQ7Qf8Balb69hptMZzyOBIPtY09GZYw==} + engines: {node: '>=12'} + cpu: [x64] + os: [linux] + requiresBuild: true + dev: true + optional: true + /esbuild-linux-arm64@0.14.54: resolution: {integrity: sha512-WL71L+0Rwv+Gv/HTmxTEmpv0UgmxYa5ftZILVi2QmZBgX3q7+tDeOQNqGtdXSdsL8TQi1vIaVFHUPDe0O0kdig==} engines: {node: '>=12'} @@ -12777,6 +13952,15 @@ packages: dev: false optional: true + /esbuild-linux-arm64@0.15.18: + resolution: {integrity: sha512-54qr8kg/6ilcxd+0V3h9rjT4qmjc0CccMVWrjOEM/pEcUzt8X62HfBSeZfT2ECpM7104mk4yfQXkosY8Quptug==} + engines: {node: '>=12'} + cpu: [arm64] + os: [linux] + requiresBuild: true + dev: true + optional: true + /esbuild-linux-arm@0.14.54: resolution: {integrity: sha512-qqz/SjemQhVMTnvcLGoLOdFpCYbz4v4fUo+TfsWG+1aOu70/80RV6bgNpR2JCrppV2moUQkww+6bWxXRL9YMGw==} engines: {node: '>=12'} @@ -12786,6 +13970,15 @@ packages: dev: false optional: true + /esbuild-linux-arm@0.15.18: + resolution: {integrity: sha512-UH779gstRblS4aoS2qpMl3wjg7U0j+ygu3GjIeTonCcN79ZvpPee12Qun3vcdxX+37O5LFxz39XeW2I9bybMVA==} + engines: {node: '>=12'} + cpu: [arm] + os: [linux] + requiresBuild: true + dev: true + optional: true + /esbuild-linux-mips64le@0.14.54: resolution: {integrity: sha512-qTHGQB8D1etd0u1+sB6p0ikLKRVuCWhYQhAHRPkO+OF3I/iSlTKNNS0Lh2Oc0g0UFGguaFZZiPJdJey3AGpAlw==} engines: {node: '>=12'} @@ -12795,6 +13988,15 @@ packages: dev: false optional: true + /esbuild-linux-mips64le@0.15.18: + resolution: {integrity: sha512-Mk6Ppwzzz3YbMl/ZZL2P0q1tnYqh/trYZ1VfNP47C31yT0K8t9s7Z077QrDA/guU60tGNp2GOwCQnp+DYv7bxQ==} + engines: {node: '>=12'} + cpu: [mips64el] + os: [linux] + requiresBuild: true + dev: true + optional: true + /esbuild-linux-ppc64le@0.14.54: resolution: {integrity: sha512-j3OMlzHiqwZBDPRCDFKcx595XVfOfOnv68Ax3U4UKZ3MTYQB5Yz3X1mn5GnodEVYzhtZgxEBidLWeIs8FDSfrQ==} engines: {node: '>=12'} @@ -12804,6 +14006,15 @@ packages: dev: false optional: true + /esbuild-linux-ppc64le@0.15.18: + resolution: {integrity: sha512-b0XkN4pL9WUulPTa/VKHx2wLCgvIAbgwABGnKMY19WhKZPT+8BxhZdqz6EgkqCLld7X5qiCY2F/bfpUUlnFZ9w==} + engines: {node: '>=12'} + cpu: [ppc64] + os: [linux] + requiresBuild: true + dev: true + optional: true + /esbuild-linux-riscv64@0.14.54: resolution: {integrity: sha512-y7Vt7Wl9dkOGZjxQZnDAqqn+XOqFD7IMWiewY5SPlNlzMX39ocPQlOaoxvT4FllA5viyV26/QzHtvTjVNOxHZg==} engines: {node: '>=12'} @@ -12813,6 +14024,15 @@ packages: dev: false optional: true + /esbuild-linux-riscv64@0.15.18: + resolution: {integrity: sha512-ba2COaoF5wL6VLZWn04k+ACZjZ6NYniMSQStodFKH/Pu6RxzQqzsmjR1t9QC89VYJxBeyVPTaHuBMCejl3O/xg==} + engines: {node: '>=12'} + cpu: [riscv64] + os: [linux] + requiresBuild: true + dev: true + optional: true + /esbuild-linux-s390x@0.14.54: resolution: {integrity: sha512-zaHpW9dziAsi7lRcyV4r8dhfG1qBidQWUXweUjnw+lliChJqQr+6XD71K41oEIC3Mx1KStovEmlzm+MkGZHnHA==} engines: {node: '>=12'} @@ -12822,6 +14042,15 @@ packages: dev: false optional: true + /esbuild-linux-s390x@0.15.18: + resolution: {integrity: sha512-VbpGuXEl5FCs1wDVp93O8UIzl3ZrglgnSQ+Hu79g7hZu6te6/YHgVJxCM2SqfIila0J3k0csfnf8VD2W7u2kzQ==} + engines: {node: '>=12'} + cpu: [s390x] + os: [linux] + requiresBuild: true + dev: true + optional: true + /esbuild-netbsd-64@0.14.54: resolution: {integrity: sha512-PR01lmIMnfJTgeU9VJTDY9ZerDWVFIUzAtJuDHwwceppW7cQWjBBqP48NdeRtoP04/AtO9a7w3viI+PIDr6d+w==} engines: {node: '>=12'} @@ -12831,6 +14060,15 @@ packages: dev: false optional: true + /esbuild-netbsd-64@0.15.18: + resolution: {integrity: sha512-98ukeCdvdX7wr1vUYQzKo4kQ0N2p27H7I11maINv73fVEXt2kyh4K4m9f35U1K43Xc2QGXlzAw0K9yoU7JUjOg==} + engines: {node: '>=12'} + cpu: [x64] + os: [netbsd] + requiresBuild: true + dev: true + optional: true + /esbuild-openbsd-64@0.14.54: resolution: {integrity: sha512-Qyk7ikT2o7Wu76UsvvDS5q0amJvmRzDyVlL0qf5VLsLchjCa1+IAvd8kTBgUxD7VBUUVgItLkk609ZHUc1oCaw==} engines: {node: '>=12'} @@ -12840,6 +14078,15 @@ packages: dev: false optional: true + /esbuild-openbsd-64@0.15.18: + resolution: {integrity: sha512-yK5NCcH31Uae076AyQAXeJzt/vxIo9+omZRKj1pauhk3ITuADzuOx5N2fdHrAKPxN+zH3w96uFKlY7yIn490xQ==} + engines: {node: '>=12'} + cpu: [x64] + os: [openbsd] + requiresBuild: true + dev: true + optional: true + /esbuild-sunos-64@0.14.54: resolution: {integrity: sha512-28GZ24KmMSeKi5ueWzMcco6EBHStL3B6ubM7M51RmPwXQGLe0teBGJocmWhgwccA1GeFXqxzILIxXpHbl9Q/Kw==} engines: {node: '>=12'} @@ -12849,6 +14096,15 @@ packages: dev: false optional: true + /esbuild-sunos-64@0.15.18: + resolution: {integrity: sha512-On22LLFlBeLNj/YF3FT+cXcyKPEI263nflYlAhz5crxtp3yRG1Ugfr7ITyxmCmjm4vbN/dGrb/B7w7U8yJR9yw==} + engines: {node: '>=12'} + cpu: [x64] + os: [sunos] + requiresBuild: true + dev: true + optional: true + /esbuild-windows-32@0.14.54: resolution: {integrity: sha512-T+rdZW19ql9MjS7pixmZYVObd9G7kcaZo+sETqNH4RCkuuYSuv9AGHUVnPoP9hhuE1WM1ZimHz1CIBHBboLU7w==} engines: {node: '>=12'} @@ -12858,13 +14114,31 @@ packages: dev: false optional: true + /esbuild-windows-32@0.15.18: + resolution: {integrity: sha512-o+eyLu2MjVny/nt+E0uPnBxYuJHBvho8vWsC2lV61A7wwTWC3jkN2w36jtA+yv1UgYkHRihPuQsL23hsCYGcOQ==} + engines: {node: '>=12'} + cpu: [ia32] + os: [win32] + requiresBuild: true + dev: true + optional: true + /esbuild-windows-64@0.14.54: resolution: {integrity: sha512-AoHTRBUuYwXtZhjXZbA1pGfTo8cJo3vZIcWGLiUcTNgHpJJMC1rVA44ZereBHMJtotyN71S8Qw0npiCIkW96cQ==} engines: {node: '>=12'} cpu: [x64] os: [win32] requiresBuild: true - dev: false + dev: false + optional: true + + /esbuild-windows-64@0.15.18: + resolution: {integrity: sha512-qinug1iTTaIIrCorAUjR0fcBk24fjzEedFYhhispP8Oc7SFvs+XeW3YpAKiKp8dRpizl4YYAhxMjlftAMJiaUw==} + engines: {node: '>=12'} + cpu: [x64] + os: [win32] + requiresBuild: true + dev: true optional: true /esbuild-windows-arm64@0.14.54: @@ -12876,6 +14150,15 @@ packages: dev: false optional: true + /esbuild-windows-arm64@0.15.18: + resolution: {integrity: sha512-q9bsYzegpZcLziq0zgUi5KqGVtfhjxGbnksaBFYmWLxeV/S1fK4OLdq2DFYnXcLMjlZw2L0jLsk1eGoB522WXQ==} + engines: {node: '>=12'} + cpu: [arm64] + os: [win32] + requiresBuild: true + dev: true + optional: true + /esbuild@0.14.54: resolution: {integrity: sha512-Cy9llcy8DvET5uznocPyqL3BFRrFXSVqbgpMJ9Wz8oVjZlh/zUSNbPRbov0VX7VxN2JH1Oa0uNxZ7eLRb62pJA==} engines: {node: '>=12'} @@ -12905,35 +14188,64 @@ packages: esbuild-windows-arm64: 0.14.54 dev: false - /esbuild@0.17.19: - resolution: {integrity: sha512-XQ0jAPFkK/u3LcVRcvVHQcTIqD6E2H1fvZMA5dQPSOWb3suUbWbfbRf94pjc0bNzRYLfIrDRQXr7X+LHIm5oHw==} + /esbuild@0.15.18: + resolution: {integrity: sha512-x/R72SmW3sSFRm5zrrIjAhCeQSAWoni3CmHEqfQrZIQTM3lVCdehdwuIqaOtfC2slvpdlLa62GYoN8SxT23m6Q==} engines: {node: '>=12'} hasBin: true requiresBuild: true optionalDependencies: - '@esbuild/android-arm': 0.17.19 - '@esbuild/android-arm64': 0.17.19 - '@esbuild/android-x64': 0.17.19 - '@esbuild/darwin-arm64': 0.17.19 - '@esbuild/darwin-x64': 0.17.19 - '@esbuild/freebsd-arm64': 0.17.19 - '@esbuild/freebsd-x64': 0.17.19 - '@esbuild/linux-arm': 0.17.19 - '@esbuild/linux-arm64': 0.17.19 - '@esbuild/linux-ia32': 0.17.19 - '@esbuild/linux-loong64': 0.17.19 - '@esbuild/linux-mips64el': 0.17.19 - '@esbuild/linux-ppc64': 0.17.19 - '@esbuild/linux-riscv64': 0.17.19 - '@esbuild/linux-s390x': 0.17.19 - '@esbuild/linux-x64': 0.17.19 - '@esbuild/netbsd-x64': 0.17.19 - '@esbuild/openbsd-x64': 0.17.19 - '@esbuild/sunos-x64': 0.17.19 - '@esbuild/win32-arm64': 0.17.19 - '@esbuild/win32-ia32': 0.17.19 - '@esbuild/win32-x64': 0.17.19 - dev: true + '@esbuild/android-arm': 0.15.18 + '@esbuild/linux-loong64': 0.15.18 + esbuild-android-64: 0.15.18 + esbuild-android-arm64: 0.15.18 + esbuild-darwin-64: 0.15.18 + esbuild-darwin-arm64: 0.15.18 + esbuild-freebsd-64: 0.15.18 + esbuild-freebsd-arm64: 0.15.18 + esbuild-linux-32: 0.15.18 + esbuild-linux-64: 0.15.18 + esbuild-linux-arm: 0.15.18 + esbuild-linux-arm64: 0.15.18 + esbuild-linux-mips64le: 0.15.18 + esbuild-linux-ppc64le: 0.15.18 + esbuild-linux-riscv64: 0.15.18 + esbuild-linux-s390x: 0.15.18 + esbuild-netbsd-64: 0.15.18 + esbuild-openbsd-64: 0.15.18 + esbuild-sunos-64: 0.15.18 + esbuild-windows-32: 0.15.18 + esbuild-windows-64: 0.15.18 + esbuild-windows-arm64: 0.15.18 + dev: true + + /esbuild@0.17.18: + resolution: {integrity: sha512-z1lix43jBs6UKjcZVKOw2xx69ffE2aG0PygLL5qJ9OS/gy0Ewd1gW/PUQIOIQGXBHWNywSc0floSKoMFF8aK2w==} + engines: {node: '>=12'} + hasBin: true + requiresBuild: true + optionalDependencies: + '@esbuild/android-arm': 0.17.18 + '@esbuild/android-arm64': 0.17.18 + '@esbuild/android-x64': 0.17.18 + '@esbuild/darwin-arm64': 0.17.18 + '@esbuild/darwin-x64': 0.17.18 + '@esbuild/freebsd-arm64': 0.17.18 + '@esbuild/freebsd-x64': 0.17.18 + '@esbuild/linux-arm': 0.17.18 + '@esbuild/linux-arm64': 0.17.18 + '@esbuild/linux-ia32': 0.17.18 + '@esbuild/linux-loong64': 0.17.18 + '@esbuild/linux-mips64el': 0.17.18 + '@esbuild/linux-ppc64': 0.17.18 + '@esbuild/linux-riscv64': 0.17.18 + '@esbuild/linux-s390x': 0.17.18 + '@esbuild/linux-x64': 0.17.18 + '@esbuild/netbsd-x64': 0.17.18 + '@esbuild/openbsd-x64': 0.17.18 + '@esbuild/sunos-x64': 0.17.18 + '@esbuild/win32-arm64': 0.17.18 + '@esbuild/win32-ia32': 0.17.18 + '@esbuild/win32-x64': 0.17.18 /esbuild@0.18.11: resolution: {integrity: sha512-i8u6mQF0JKJUlGR3OdFLKldJQMMs8OqM9Cc3UCi9XXziJ9WERM5bfkHaEAy0YAvPRMgqSW55W7xYn84XtEFTtA==} @@ -12963,6 +14275,7 @@ packages: '@esbuild/win32-arm64': 0.18.11 '@esbuild/win32-ia32': 0.18.11 '@esbuild/win32-x64': 0.18.11 + dev: true /escalade@3.1.1: resolution: {integrity: sha512-k0er2gUkLf8O0zKJiAhmkTnJlTvINGv7ygDNPbeIsX/TJjGJZHuh9B2UxbsaEkmlEo9MfhrSzmhIlhRlI2GXnw==} @@ -12990,14 +14303,15 @@ packages: engines: {node: '>=12'} dev: true - /escodegen@2.1.0: - resolution: {integrity: sha512-2NlIDTwUWJN0mRPQOdtQBzbUHvdGY2P1VXSyU83Q3xKxM7WHX2Ql8dKq782Q9TgQUNOLEzEYu9bzLNj1q88I5w==} + /escodegen@2.0.0: + resolution: {integrity: sha512-mmHKys/C8BFUGI+MAWNcSYoORYLMdPzjrknd2Vc+bUsjN5bXcr8EhrNB+UTqfL1y3I9c4fw2ihgtMPQLBRiQxw==} engines: {node: '>=6.0'} hasBin: true dependencies: esprima: 4.0.1 estraverse: 5.3.0 esutils: 2.0.3 + optionator: 0.8.3 optionalDependencies: source-map: 0.6.1 dev: true @@ -13012,7 +14326,7 @@ packages: - supports-color dev: true - /eslint-module-utils@2.8.0(@typescript-eslint/parser@5.62.0)(eslint-import-resolver-node@0.3.7)(eslint@8.44.0): + /eslint-module-utils@2.8.0(@typescript-eslint/parser@5.60.0)(eslint-import-resolver-node@0.3.7)(eslint@8.44.0): resolution: {integrity: sha512-aWajIYfsqCKRDgUfjEXNN/JlrzauMuSEy5sbd7WXbtW3EH6A6MpwEh42c7qD+MqQo9QMJ6fWLAeIJynx0g6OAw==} engines: {node: '>=4'} peerDependencies: @@ -13033,7 +14347,7 @@ packages: eslint-import-resolver-webpack: optional: true dependencies: - '@typescript-eslint/parser': 5.62.0(eslint@8.44.0)(typescript@5.1.6) + '@typescript-eslint/parser': 5.60.0(eslint@8.44.0)(typescript@5.1.6) debug: 3.2.7(supports-color@8.1.1) eslint: 8.44.0 eslint-import-resolver-node: 0.3.7 @@ -13041,24 +14355,24 @@ packages: - supports-color dev: true - /eslint-plugin-antfu@0.39.7(eslint@8.44.0)(typescript@5.1.6): - resolution: {integrity: sha512-z+xqVTnneKogHuJLTSmIbFb8Ll0TVGeghufz56hAVa6JCKOsVpvqOkVjJDZ+R/JGnzqvA+GTBh1fugxlspq3Rw==} + /eslint-plugin-antfu@0.39.6(eslint@8.44.0)(typescript@5.1.6): + resolution: {integrity: sha512-ecZ+tfk4OrkrHVfJT+li89ZRsxaAWRcFwB9SqqN+NBMaZxP4+pjtRIngcX8dto+BF/L/o50oGePoK6kapxt6aw==} dependencies: - '@typescript-eslint/utils': 5.62.0(eslint@8.44.0)(typescript@5.1.6) + '@typescript-eslint/utils': 5.60.0(eslint@8.44.0)(typescript@5.1.6) transitivePeerDependencies: - eslint - supports-color - typescript dev: true - /eslint-plugin-es-x@7.1.0(eslint@8.44.0): - resolution: {integrity: sha512-AhiaF31syh4CCQ+C5ccJA0VG6+kJK8+5mXKKE7Qs1xcPRg02CDPOj3mWlQxuWS/AYtg7kxrDNgW9YW3vc0Q+Mw==} + /eslint-plugin-es-x@6.2.1(eslint@8.44.0): + resolution: {integrity: sha512-uR34zUhZ9EBoiSD2DdV5kHLpydVEvwWqjteUr9sXRgJknwbKZJZhdJ7uFnaTtd+Nr/2G3ceJHnHXrFhJ67n3Tw==} engines: {node: ^14.18.0 || >=16.0.0} peerDependencies: eslint: '>=8' dependencies: '@eslint-community/eslint-utils': 4.4.0(eslint@8.44.0) - '@eslint-community/regexpp': 4.5.1 + '@eslint-community/regexpp': 4.5.0 eslint: 8.44.0 dev: true @@ -13070,16 +14384,16 @@ packages: dependencies: escape-string-regexp: 1.0.5 eslint: 8.44.0 - ignore: 5.2.4 + ignore: 5.2.0 dev: true /eslint-plugin-html@7.1.0: resolution: {integrity: sha512-fNLRraV/e6j8e3XYOC9xgND4j+U7b1Rq+OygMlLcMg+wI/IpVbF+ubQa3R78EjKB9njT6TQOlcK5rFKBVVtdfg==} dependencies: - htmlparser2: 8.0.2 + htmlparser2: 8.0.1 dev: true - /eslint-plugin-i@2.27.5-3(@typescript-eslint/parser@5.62.0)(eslint@8.44.0): + /eslint-plugin-i@2.27.5-3(@typescript-eslint/parser@5.60.0)(eslint@8.44.0): resolution: {integrity: sha512-fxJkCgJmJ1j/4fQwoonVtXT9nwF/MZ5GTUm9bzFvJQIauJgkkaPblqiMox+2pFjXN+2F7xUeq+UzCDJGBJ+vOA==} engines: {node: '>=4'} peerDependencies: @@ -13092,7 +14406,7 @@ packages: doctrine: 2.1.0 eslint: 8.44.0 eslint-import-resolver-node: 0.3.7 - eslint-module-utils: 2.8.0(@typescript-eslint/parser@5.62.0)(eslint-import-resolver-node@0.3.7)(eslint@8.44.0) + eslint-module-utils: 2.8.0(@typescript-eslint/parser@5.60.0)(eslint-import-resolver-node@0.3.7)(eslint@8.44.0) get-tsconfig: 4.6.2 has: 1.0.3 is-core-module: 2.12.1 @@ -13100,7 +14414,7 @@ packages: minimatch: 3.1.2 object.values: 1.1.6 resolve: 1.22.3 - semver: 6.3.1 + semver: 6.3.0 transitivePeerDependencies: - '@typescript-eslint/parser' - eslint-import-resolver-typescript @@ -13108,8 +14422,8 @@ packages: - supports-color dev: true - /eslint-plugin-jest@27.2.2(@typescript-eslint/eslint-plugin@5.62.0)(eslint@8.44.0)(typescript@5.1.6): - resolution: {integrity: sha512-euzbp06F934Z7UDl5ZUaRPLAc9MKjh0rMPERrHT7UhlCEwgb25kBj37TvMgWeHZVkR5I9CayswrpoaqZU1RImw==} + /eslint-plugin-jest@27.2.1(@typescript-eslint/eslint-plugin@5.60.0)(eslint@8.44.0)(typescript@5.1.6): + resolution: {integrity: sha512-l067Uxx7ZT8cO9NJuf+eJHvt6bqJyz2Z29wykyEdz/OtmcELQl2MQGQLX8J94O1cSJWAwUSEvCjwjA7KEK3Hmg==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} peerDependencies: '@typescript-eslint/eslint-plugin': ^5.0.0 @@ -13121,8 +14435,8 @@ packages: jest: optional: true dependencies: - '@typescript-eslint/eslint-plugin': 5.62.0(@typescript-eslint/parser@5.62.0)(eslint@8.44.0)(typescript@5.1.6) - '@typescript-eslint/utils': 5.62.0(eslint@8.44.0)(typescript@5.1.6) + '@typescript-eslint/eslint-plugin': 5.60.0(@typescript-eslint/parser@5.60.0)(eslint@8.44.0)(typescript@5.1.6) + '@typescript-eslint/utils': 5.60.0(eslint@8.44.0)(typescript@5.1.6) eslint: 8.44.0 transitivePeerDependencies: - supports-color @@ -13153,8 +14467,8 @@ packages: - supports-color dev: true - /eslint-plugin-n@16.0.1(eslint@8.44.0): - resolution: {integrity: sha512-CDmHegJN0OF3L5cz5tATH84RPQm9kG+Yx39wIqIwPR2C0uhBGMWfbbOtetR83PQjjidA5aXMu+LEFw1jaSwvTA==} + /eslint-plugin-n@16.0.0(eslint@8.44.0): + resolution: {integrity: sha512-akkZTE3hsHBrq6CwmGuYCzQREbVUrA855kzcHqe6i0FLBkeY7Y/6tThCVkjUnjhvRBAlc+8lILcSe5QvvDpeZQ==} engines: {node: '>=16.0.0'} peerDependencies: eslint: '>=7.0.0' @@ -13162,12 +14476,12 @@ packages: '@eslint-community/eslint-utils': 4.4.0(eslint@8.44.0) builtins: 5.0.1 eslint: 8.44.0 - eslint-plugin-es-x: 7.1.0(eslint@8.44.0) - ignore: 5.2.4 + eslint-plugin-es-x: 6.2.1(eslint@8.44.0) + ignore: 5.2.0 is-core-module: 2.12.1 minimatch: 3.1.2 resolve: 1.22.2 - semver: 7.5.4 + semver: 7.5.2 dev: true /eslint-plugin-no-only-tests@3.1.0: @@ -13202,14 +14516,14 @@ packages: lodash: 4.17.21 pluralize: 8.0.0 read-pkg-up: 7.0.1 - regexp-tree: 0.1.27 + regexp-tree: 0.1.24 regjsparser: 0.10.0 safe-regex: 2.1.1 - semver: 7.5.4 + semver: 7.5.2 strip-indent: 3.0.0 dev: true - /eslint-plugin-unused-imports@2.0.0(@typescript-eslint/eslint-plugin@5.62.0)(eslint@8.44.0): + /eslint-plugin-unused-imports@2.0.0(@typescript-eslint/eslint-plugin@5.60.0)(eslint@8.44.0): resolution: {integrity: sha512-3APeS/tQlTrFa167ThtP0Zm0vctjr4M44HMpeg1P4bK6wItarumq0Ma82xorMKdFsWpphQBlRPzw/pxiVELX1A==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} peerDependencies: @@ -13219,13 +14533,13 @@ packages: '@typescript-eslint/eslint-plugin': optional: true dependencies: - '@typescript-eslint/eslint-plugin': 5.62.0(@typescript-eslint/parser@5.62.0)(eslint@8.44.0)(typescript@5.1.6) + '@typescript-eslint/eslint-plugin': 5.60.0(@typescript-eslint/parser@5.60.0)(eslint@8.44.0)(typescript@5.1.6) eslint: 8.44.0 eslint-rule-composer: 0.3.0 dev: true - /eslint-plugin-vue@9.15.1(eslint@8.44.0): - resolution: {integrity: sha512-CJE/oZOslvmAR9hf8SClTdQ9JLweghT6JCBQNrT2Iel1uVw0W0OLJxzvPd6CxmABKCvLrtyDnqGV37O7KQv6+A==} + /eslint-plugin-vue@9.15.0(eslint@8.44.0): + resolution: {integrity: sha512-XYzpK6e2REli100+6iCeBA69v6Sm0D/yK2FZP+fCeNt0yH/m82qZQq+ztseyV0JsKdhFysuSEzeE1yCmSC92BA==} engines: {node: ^14.17.0 || >=16.0.0} peerDependencies: eslint: ^6.2.0 || ^7.0.0 || ^8.0.0 @@ -13234,8 +14548,8 @@ packages: eslint: 8.44.0 natural-compare: 1.4.0 nth-check: 2.1.1 - postcss-selector-parser: 6.0.13 - semver: 7.5.4 + postcss-selector-parser: 6.0.10 + semver: 7.5.2 vue-eslint-parser: 9.3.1(eslint@8.44.0) xml-name-validator: 4.0.0 transitivePeerDependencies: @@ -13323,14 +14637,14 @@ packages: eslint-scope: 7.2.0 eslint-utils: 3.0.0(eslint@8.4.1) eslint-visitor-keys: 3.4.1 - espree: 9.2.0 + espree: 9.5.2 esquery: 1.5.0 esutils: 2.0.3 fast-deep-equal: 3.1.3 file-entry-cache: 6.0.1 functional-red-black-tree: 1.0.1 glob-parent: 6.0.2 - globals: 13.20.0 + globals: 13.19.0 ignore: 4.0.6 import-fresh: 3.3.0 imurmurhash: 0.1.4 @@ -13341,10 +14655,10 @@ packages: lodash.merge: 4.6.2 minimatch: 3.1.2 natural-compare: 1.4.0 - optionator: 0.9.3 + optionator: 0.9.1 progress: 2.0.3 regexpp: 3.2.0 - semver: 7.5.4 + semver: 7.5.2 strip-ansi: 6.0.1 strip-json-comments: 3.1.1 text-table: 0.2.0 @@ -13359,7 +14673,7 @@ packages: hasBin: true dependencies: '@eslint-community/eslint-utils': 4.4.0(eslint@8.44.0) - '@eslint-community/regexpp': 4.5.1 + '@eslint-community/regexpp': 4.5.0 '@eslint/eslintrc': 2.1.0 '@eslint/js': 8.44.0 '@humanwhocodes/config-array': 0.11.10 @@ -13380,9 +14694,9 @@ packages: file-entry-cache: 6.0.1 find-up: 5.0.0 glob-parent: 6.0.2 - globals: 13.20.0 + globals: 13.19.0 graphemer: 1.4.0 - ignore: 5.2.4 + ignore: 5.2.0 import-fresh: 3.3.0 imurmurhash: 0.1.4 is-glob: 4.0.3 @@ -13409,15 +14723,24 @@ packages: resolution: {integrity: sha512-6slSBEV1lMKcX13DBifvnDFpNno5WXhw4j/ff7RI0y51BZiDqEe5dNhhjhIQ3iCOQuzsm2MbVzmwqbN78BBhPg==} hasBin: true dependencies: - tsx: 3.12.7 + tsx: 3.11.0 dev: true /espree@9.2.0: resolution: {integrity: sha512-oP3utRkynpZWF/F2x/HZJ+AGtnIclaR7z1pYPxy7NYM2fSO6LgK/Rkny8anRSPK/VwEA1eqm2squui0T7ZMOBg==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dependencies: - acorn: 8.10.0 - acorn-jsx: 5.3.2(acorn@8.10.0) + acorn: 8.9.0 + acorn-jsx: 5.3.2(acorn@8.9.0) + eslint-visitor-keys: 3.4.1 + dev: true + + /espree@9.5.2: + resolution: {integrity: sha512-7OASN1Wma5fum5SrNhFMAMJxOUAbhyfQ8dQ//PJaJbNw0URTPWqIghHWt1MmAANKhHZIYOHruW4Kw4ruUWOdGw==} + engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} + dependencies: + acorn: 8.9.0 + acorn-jsx: 5.3.2(acorn@8.9.0) eslint-visitor-keys: 3.4.1 dev: true @@ -13425,8 +14748,8 @@ packages: resolution: {integrity: sha512-1FH/IiruXZ84tpUlm0aCUEwMl2Ho5ilqVh0VvQXw+byAz/4SAciyHLlfmL5WYqsvD38oymdUwBss0LtK8m4s/A==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dependencies: - acorn: 8.10.0 - acorn-jsx: 5.3.2(acorn@8.10.0) + acorn: 8.9.0 + acorn-jsx: 5.3.2(acorn@8.9.0) eslint-visitor-keys: 3.4.1 dev: true @@ -13471,7 +14794,7 @@ packages: resolution: {integrity: sha512-YNF+mZ/Wu2FU/gvmzuWtYc8rloubL7wfXCTgouFrnjGVXPA/EeYYA7pupXWrb3Iv1cTBeSSxxJIbK23l4MRNqg==} engines: {node: '>=8.3.0'} dependencies: - '@babel/traverse': 7.22.8 + '@babel/traverse': 7.22.5 '@babel/types': 7.22.5 c8: 7.14.0 transitivePeerDependencies: @@ -13596,7 +14919,7 @@ packages: dependencies: cross-spawn: 7.0.3 get-stream: 6.0.1 - human-signals: 4.3.1 + human-signals: 4.3.0 is-stream: 3.0.0 merge-stream: 2.0.0 npm-run-path: 5.1.0 @@ -13652,27 +14975,26 @@ packages: jest-message-util: 27.5.1 dev: true - /expect@29.6.1: - resolution: {integrity: sha512-XEdDLonERCU1n9uR56/Stx9OqojaLAQtZf9PrCHH9Hl8YXiEIka3H4NXJ3NOIBmQJTg7+j7buh34PMHfJujc8g==} + /expect@29.0.1: + resolution: {integrity: sha512-yQgemsjLU+1S8t2A7pXT3Sn/v5/37LY8J+tocWtKEA0iEYYc6gfKbbJJX2fxHZmd7K9WpdbQqXUpmYkq1aewYg==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: - '@jest/expect-utils': 29.6.1 - '@types/node': 20.4.1 - jest-get-type: 29.4.3 - jest-matcher-utils: 29.6.1 - jest-message-util: 29.6.1 - jest-util: 29.6.1 + '@jest/expect-utils': 29.0.1 + jest-get-type: 29.0.0 + jest-matcher-utils: 29.0.1 + jest-message-util: 29.0.1 + jest-util: 29.0.1 dev: true - /express@4.18.2: - resolution: {integrity: sha512-5/PsL6iGPdfQ/lKM1UuielYgv3BUoJfz1aUwU9vHZ+J7gyvwdQXFEBIEIaxeGf0GIcreATNyBExtalisDbuMqQ==} + /express@4.18.1: + resolution: {integrity: sha512-zZBcOX9TfehHQhtupq57OF8lFZ3UZi08Y97dwFCkD8p9d/d2Y3M+ykKcwaMDEL+4qyUolgBDX6AblpR3fL212Q==} engines: {node: '>= 0.10.0'} dependencies: accepts: 1.3.8 array-flatten: 1.1.1 - body-parser: 1.20.1 + body-parser: 1.20.0 content-disposition: 0.5.4 - content-type: 1.0.5 + content-type: 1.0.4 cookie: 0.5.0 cookie-signature: 1.0.6 debug: 2.6.9 @@ -13689,7 +15011,7 @@ packages: parseurl: 1.3.3 path-to-regexp: 0.1.7 proxy-addr: 2.0.7 - qs: 6.11.0 + qs: 6.10.3 range-parser: 1.2.1 safe-buffer: 5.2.1 send: 0.18.0 @@ -13774,10 +15096,6 @@ packages: engines: {'0': node >=0.6.0} dev: true - /fast-decode-uri-component@1.0.1: - resolution: {integrity: sha512-WKgKWg5eUxvRZGwW8FvfbaH7AXSh2cL+3j5fMGzUMCxWBJ3dV3a7Wz8y2f/uQ0e3B6WmodD3oS54jTQ9HVTIIg==} - dev: true - /fast-deep-equal@2.0.1: resolution: {integrity: sha512-bCK/2Z4zLidyB4ReuIsvALH6w31YfAQDmXMqMx6FyfHqvBxtjC0eRumeSu4Bs3XtXwpyIywtSTrVT99BxY1f9w==} dev: true @@ -13786,15 +15104,10 @@ packages: resolution: {integrity: sha512-f3qQ9oQy9j2AhBe/H9VC91wLmKBCCU/gDOnKNAYG5hswO7BLKj09Hc5HYNz9cGI++xlpDCIgDaitVs03ATR84Q==} dev: true - /fast-equals@5.0.1: - resolution: {integrity: sha512-WF1Wi8PwwSY7/6Kx0vKXtw8RwuSGoM1bvDaJbu7MxDlR1vovZjIAKrnzyrThgAjm6JDTu0fVgWXDlMGspodfoQ==} - engines: {node: '>=6.0.0'} + /fast-equals@2.0.4: + resolution: {integrity: sha512-caj/ZmjHljPrZtbzJ3kfH5ia/k4mTJe/qSiXAGzxZWRZgsgDV0cvNaQULqUX8t0/JVlzzEdYOwCN5DmzTxoD4w==} dev: false - /fast-fifo@1.3.0: - resolution: {integrity: sha512-IgfweLvEpwyA4WgiQe9Nx6VV2QkML2NkvZnk1oKnIzXgXdWxuhF7zw4DvLTPZJn6PIUneiAXPF24QmoEqHTjyw==} - dev: true - /fast-glob@2.2.7: resolution: {integrity: sha512-g1KuQwHOZAmOZMuBtHdxDtju+T2RT8jgCC9aANsbpdiDDTSnjgfuVsIBNKbUeJI3oKMRExcfNDtJl4OhbffMsw==} engines: {node: '>=4.0.0'} @@ -13827,14 +15140,14 @@ packages: resolution: {integrity: sha512-lhd/wF+Lk98HZoTCtlVraHtfh5XYijIjalXck7saUtuanSDyLMxnHhSXEDJqHxD7msR8D0uCmqlkwjCV8xvwHw==} dev: true - /fast-json-stringify@5.7.0: - resolution: {integrity: sha512-sBVPTgnAZseLu1Qgj6lUbQ0HfjFhZWXAmpZ5AaSGkyLh5gAXBga/uPJjQPHpDFjC9adWIpdOcCLSDTgrZ7snoQ==} + /fast-json-stringify@5.2.0: + resolution: {integrity: sha512-u5jtrcAK9RINW15iuDKnsuuhqmqre4AmDMp3crRTjUMdAuHMpQUt3IfoMm5wlJm59b74PcajqOl3SjgnC5FPmw==} dependencies: - '@fastify/deepmerge': 1.3.0 - ajv: 8.12.0 - ajv-formats: 2.1.1(ajv@8.12.0) + '@fastify/deepmerge': 1.1.0 + ajv: 8.11.0 + ajv-formats: 2.1.1(ajv@8.11.0) fast-deep-equal: 3.1.3 - fast-uri: 2.2.0 + fast-uri: 2.1.0 rfdc: 1.3.0 dev: true @@ -13842,14 +15155,8 @@ packages: resolution: {integrity: sha512-DCXu6Ifhqcks7TZKY3Hxp3y6qphY5SJZmrWMDrKcERSOXWQdMhU9Ig/PYrzyw/ul9jOIyh0N4M0tbC5hodg8dw==} dev: true - /fast-querystring@1.1.2: - resolution: {integrity: sha512-g6KuKWmFXc0fID8WWH0jit4g0AGBoJhCkJMb1RmbsSEUNvQ+ZC8D6CUZ+GtF8nMzSPXnhiePyyqqipzNNEnHjg==} - dependencies: - fast-decode-uri-component: 1.0.1 - dev: true - - /fast-redact@3.2.0: - resolution: {integrity: sha512-zaTadChr+NekyzallAMXATXLOR8MNx3zqpZ0MUF2aGf4EathnG0f32VLODNlY8IuGY3HoRO2L6/6fSzNsLaHIw==} + /fast-redact@3.1.2: + resolution: {integrity: sha512-+0em+Iya9fKGfEQGcd62Yv6onjBmmhV1uh86XVfOU8VwAe6kaFdQCWI9s0/Nnugx5Vd9tdbZ7e6gE2tR9dzXdw==} engines: {node: '>=6'} dev: true @@ -13857,38 +15164,38 @@ packages: resolution: {integrity: sha512-W+KJc2dmILlPplD/H4K9l9LcAHAfPtP6BY84uVLXQ6Evcz9Lcg33Y2z1IVblT6xdY54PXYVHEv+0Wpq8Io6zkA==} dev: true - /fast-uri@2.2.0: - resolution: {integrity: sha512-cIusKBIt/R/oI6z/1nyfe2FvGKVTohVRfvkOhvx0nCEW+xf5NoCXjAHcWp93uOUBchzYcsvPlrapAdX1uW+YGg==} + /fast-uri@2.1.0: + resolution: {integrity: sha512-qKRta6N7BWEFVlyonVY/V+BMLgFqktCUV0QjT259ekAIlbVrMaFnFLxJ4s/JPl4tou56S1BzPufI60bLe29fHA==} dev: true /fastify@4.5.3: resolution: {integrity: sha512-Q8Zvkmg7GnioMCDX1jT2Q7iRqjywlnDZ1735D2Ipf7ashCM/3/bqPKv2Jo1ZF2iDExct2eP1C/tdhcj0GG/OuQ==} dependencies: - '@fastify/ajv-compiler': 3.5.0 - '@fastify/error': 3.3.0 - '@fastify/fast-json-stringify-compiler': 4.3.0 + '@fastify/ajv-compiler': 3.2.0 + '@fastify/error': 3.0.0 + '@fastify/fast-json-stringify-compiler': 4.1.0 abstract-logging: 2.0.1 - avvio: 8.2.1 - find-my-way: 7.6.2 - light-my-request: 5.10.0 - pino: 8.14.1 - process-warning: 2.2.0 + avvio: 8.2.0 + find-my-way: 7.0.1 + light-my-request: 5.5.1 + pino: 8.5.0 + process-warning: 2.0.0 proxy-addr: 2.0.7 rfdc: 1.3.0 - secure-json-parse: 2.7.0 - semver: 7.5.4 + secure-json-parse: 2.5.0 + semver: 7.3.7 tiny-lru: 8.0.2 transitivePeerDependencies: - supports-color dev: true - /fastq@1.15.0: - resolution: {integrity: sha512-wBrocU2LCXXa+lWBt8RoIRD89Fi8OdABODa/kEnyeyjS5aZO5/GNvI5sEINADqP/h8M29UHTHUb53sUu5Ihqdw==} + /fastq@1.13.0: + resolution: {integrity: sha512-YpkpUnK8od0o1hmeSc7UUs/eB/vIPWJYjKck2QKIzAf71Vm1AAQ3EbuZB3g2JIy+pg+ERD0vqI79KyZiB2e2Nw==} dependencies: reusify: 1.0.4 - /fb-watchman@2.0.2: - resolution: {integrity: sha512-p5161BqbuCaSnB8jIbzQHOlpgsPmK5rJVDfDKO91Axs5NC1uu3HRQm6wt9cd9/+GtQQIO53JdGXXoyDpTAsgYA==} + /fb-watchman@2.0.1: + resolution: {integrity: sha512-DkPJKQeY6kKwmuMretBhr7G6Vodr7bFwDYTXIkfG1gjvNpaxBTQV3PbXg6bR1c1UP4jPOX0jHUbbHANL9vRjVg==} dependencies: bser: 2.1.1 dev: true @@ -13899,8 +15206,8 @@ packages: pend: 1.2.0 dev: true - /fetch-retry@5.0.6: - resolution: {integrity: sha512-3yurQZ2hD9VISAhJJP9bpYFNQrHHBXE2JxxjY5aLEcDi46RmAzJE2OC9FAde0yis5ElW0jTTzs0zfg/Cca4XqQ==} + /fetch-retry@5.0.3: + resolution: {integrity: sha512-uJQyMrX5IJZkhoEUBQ3EjxkeiZkppBd5jS/fMTJmfZxLSiaQjv2zD0kTvuvkSH89uFvgSlB6ueGpjD3HWN7Bxw==} dev: true /fflate@0.8.0: @@ -13939,8 +15246,8 @@ packages: peerDependencies: webpack: ^4.0.0 || ^5.0.0 dependencies: - loader-utils: 2.0.4 - schema-utils: 3.3.0 + loader-utils: 2.0.2 + schema-utils: 3.1.1 webpack: 4.46.0 dev: true @@ -13951,22 +15258,16 @@ packages: ramda: 0.28.0 dev: true - /file-system-cache@2.3.0: - resolution: {integrity: sha512-l4DMNdsIPsVnKrgEXbJwDJsA5mB8rGwHYERMgqQx/xAUtChPJMre1bXBzDEqqVbWv9AIbFezXMxeEkZDSrXUOQ==} - dependencies: - fs-extra: 11.1.1 - ramda: 0.29.0 - dev: true - /file-uri-to-path@1.0.0: resolution: {integrity: sha512-0Zt+s3L7Vf1biwWZ29aARiVYLx7iMGnEUl9x33fbB/j3jR81u/O2LbqK+Bm1CDSNDKVtJ/YjwY7TUd5SkeLQLw==} + requiresBuild: true dev: true optional: true /filelist@1.0.4: resolution: {integrity: sha512-w1cEuf3S+DrLCQL7ET6kz+gmlJdbq9J7yXCSjK/OZCPA+qEN1WyF4ZAf0YYJa4/shHJra2t/d/r8SV4Ji+x+8Q==} dependencies: - minimatch: 5.1.6 + minimatch: 5.1.1 dev: true /fill-range@4.0.0: @@ -14018,12 +15319,11 @@ packages: pkg-dir: 4.2.0 dev: true - /find-my-way@7.6.2: - resolution: {integrity: sha512-0OjHn1b1nCX3eVbm9ByeEHiscPYiHLfhei1wOUU9qffQkk98wE0Lo8VrVYfSGMgnSnDh86DxedduAnBf4nwUEw==} + /find-my-way@7.0.1: + resolution: {integrity: sha512-w05SaOPg54KqBof/RDA+75n1R48V7ZZNPL3nR17jJJs5dgZpR3ivfrMWOyx7BVFQgCLhYRG05hfgFCohYvSUXA==} engines: {node: '>=14'} dependencies: fast-deep-equal: 3.1.3 - fast-querystring: 1.1.2 safe-regex2: 2.0.0 dev: true @@ -14067,7 +15367,7 @@ packages: resolution: {integrity: sha512-v2ZsoEuVHYy8ZIlYqwPe/39Cy+cFDzp4dXPaxNvkEuouymu+2Jbz0PxpKarJHYJTmv2HWT3O382qY8l4jMWthw==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dependencies: - locate-path: 7.2.0 + locate-path: 7.1.1 path-exists: 5.0.0 dev: true @@ -14101,17 +15401,17 @@ packages: resolution: {integrity: sha512-3Z4XhFZ3992uIq0XOqb9AreonueSYphE6oYbpt5+3u06JWklbsPkNv3ZKkP9Bz/r+1MWCaMoSQ28P85+1Yc77w==} dependencies: inherits: 2.0.4 - readable-stream: 2.3.8 + readable-stream: 2.3.7 dev: true - /focus-trap@7.5.2: - resolution: {integrity: sha512-p6vGNNWLDGwJCiEjkSK6oERj/hEyI9ITsSwIUICBoKLlWiTWXJRfQibCwcoi50rTZdbi87qDtUlMCmQwsGSgPw==} + /focus-trap@7.4.3: + resolution: {integrity: sha512-BgSSbK4GPnS2VbtZ50VtOv1Sti6DIkj3+LkVjiWMNjLeAp1SH1UlLx3ULu/DCu4vq5R4/uvTm+zrvsMsuYmGLg==} dependencies: - tabbable: 6.2.0 + tabbable: 6.1.2 dev: true - /follow-redirects@1.15.2: - resolution: {integrity: sha512-VQLG33o04KaQ8uYi2tVNbdrWp1QWxNNea+nmIB4EVM28v0hmP17z7aG1+wAkNzVq4KeXTq3221ye5qTJP91JwA==} + /follow-redirects@1.15.1: + resolution: {integrity: sha512-yLAMQs+k0b2m7cVxpS1VKJVvoz7SS9Td1zss3XRwXj+ZDH00RJgnuLx7E44wx02kQLrdM3aOOy+FpzS7+8OizA==} engines: {node: '>=4.0'} peerDependencies: debug: '*' @@ -14143,14 +15443,14 @@ packages: engines: {node: '>=14'} dependencies: cross-spawn: 7.0.3 - signal-exit: 4.0.2 + signal-exit: 4.0.1 dev: true /forever-agent@0.6.1: resolution: {integrity: sha512-j0KLYPhm6zeac4lz3oJ3o65qvgQCcPubiyotZrXqEaG4hNagNYO8qdlUrX5vwqv9ohqeT/Z3j6+yW067yWWdUw==} dev: true - /fork-ts-checker-webpack-plugin@4.1.6(eslint@8.4.1)(typescript@4.9.5)(webpack@4.46.0): + /fork-ts-checker-webpack-plugin@4.1.6(eslint@8.4.1)(typescript@4.8.4)(webpack@4.46.0): resolution: {integrity: sha512-DUxuQaKoqfNne8iikd14SAkh5uw4+8vNifp6gmA73yYNS6ywLIWSLD/n/mBzHQRpW3J7rbATEakmiA8JvkTyZw==} engines: {node: '>=6.11.5', yarn: '>=1.0.0'} peerDependencies: @@ -14169,17 +15469,17 @@ packages: eslint: 8.4.1 micromatch: 3.1.10 minimatch: 3.1.2 - semver: 5.7.2 + semver: 5.7.1 tapable: 1.1.3 - typescript: 4.9.5 + typescript: 4.8.4 webpack: 4.46.0 worker-rpc: 0.1.1 transitivePeerDependencies: - supports-color dev: true - /fork-ts-checker-webpack-plugin@6.5.3(eslint@8.4.1)(typescript@4.9.5)(webpack@4.46.0): - resolution: {integrity: sha512-SbH/l9ikmMWycd5puHJKTkZJKddF4iRLyW3DeZ08HTI7NGyLS38MXd/KGgeWumQO7YNQbW2u/NtPT2YowbPaGQ==} + /fork-ts-checker-webpack-plugin@6.5.2(eslint@8.4.1)(typescript@4.8.4)(webpack@4.46.0): + resolution: {integrity: sha512-m5cUmF30xkZ7h4tWUgTAcEaKmUW7tfyUyTqNNOz7OxWJ0v1VWKTcOvH8FWHUwSjlW/356Ijc9vi3XfcPstpQKA==} engines: {node: '>=10', yarn: '>=1.0.0'} peerDependencies: eslint: '>= 6' @@ -14193,7 +15493,7 @@ packages: optional: true dependencies: '@babel/code-frame': 7.22.5 - '@types/json-schema': 7.0.12 + '@types/json-schema': 7.0.11 chalk: 4.1.2 chokidar: 3.5.3 cosmiconfig: 6.0.0 @@ -14201,12 +15501,12 @@ packages: eslint: 8.4.1 fs-extra: 9.1.0 glob: 7.2.3 - memfs: 3.5.3 + memfs: 3.4.7 minimatch: 3.1.2 schema-utils: 2.7.0 - semver: 7.5.4 + semver: 7.5.2 tapable: 1.1.3 - typescript: 4.9.5 + typescript: 4.8.4 webpack: 4.46.0 dev: true @@ -14242,13 +15542,13 @@ packages: mime-types: 2.1.35 dev: true - /formidable@2.1.2: - resolution: {integrity: sha512-CM3GuJ57US06mlpQ47YcunuUZ9jpm8Vx+P2CGt2j7HpgkKZO/DJYQ0Bobim8G6PFQmK5lOqOOdUXboU+h73A4g==} + /formidable@2.0.1: + resolution: {integrity: sha512-rjTMNbp2BpfQShhFbR3Ruk3qk2y9jKpvMW78nJgx8QKtxjDVrwbZG+wvDOmVbifHyOUOQJXxqEy6r0faRrPzTQ==} dependencies: - dezalgo: 1.0.4 + dezalgo: 1.0.3 hexoid: 1.0.0 once: 1.4.0 - qs: 6.11.2 + qs: 6.9.3 dev: true /forwarded@0.2.0: @@ -14272,7 +15572,7 @@ packages: resolution: {integrity: sha512-OMcX/4IC/uqEPVgGeyfN22LJk6AZrMkRZHxcHBMBvHScDGgwTm2GT2Wkgtocyd3JfZffjj2kYUDXXII0Fk9W0g==} dependencies: inherits: 2.0.4 - readable-stream: 2.3.8 + readable-stream: 2.3.7 dev: true /fs-constants@1.0.0: @@ -14283,7 +15583,7 @@ packages: resolution: {integrity: sha512-oRXApq54ETRj4eMiFzGnHWGy+zo5raudjuxN0b8H7s/RU2oW0Wvsx9O0ACRN/kRq9E8Vu/ReskGB5o3ji+FzHQ==} engines: {node: '>=12'} dependencies: - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 jsonfile: 6.1.0 universalify: 2.0.0 dev: true @@ -14292,7 +15592,7 @@ packages: resolution: {integrity: sha512-MGIE4HOvQCeUCzmlHs0vXpih4ysz4wg9qiSAu6cd42lVwPbTM1TjV7RusoyQqMmk/95gdQZX72u+YW+c3eEpFQ==} engines: {node: '>=14.14'} dependencies: - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 jsonfile: 6.1.0 universalify: 2.0.0 dev: true @@ -14302,7 +15602,7 @@ packages: engines: {node: '>=10'} dependencies: at-least-node: 1.0.0 - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 jsonfile: 6.1.0 universalify: 2.0.0 dev: true @@ -14311,20 +15611,20 @@ packages: resolution: {integrity: sha512-V/JgOLFCS+R6Vcq0slCuaeWEdNC3ouDlJMNIsacH2VtALiu9mV4LPrHc5cDl8k5aw6J8jwgWWpiTo5RYhmIzvg==} engines: {node: '>= 8'} dependencies: - minipass: 3.3.6 + minipass: 3.3.4 dev: true - /fs-monkey@1.0.4: - resolution: {integrity: sha512-INM/fWAxMICjttnD0DX1rBvinKskj5G1w+oy/pnm9u/tSlnBrzFonJMcalKJ30P8RRsPzKcCG7Q8l0jx5Fh9YQ==} + /fs-monkey@1.0.3: + resolution: {integrity: sha512-cybjIfiiE+pTWicSCLFHSrXZ6EilF30oh91FDP9S2B051prEa7QWfrVTQm10/dDpswBDXZugPa1Ogu8Yh+HV0Q==} dev: true /fs-write-stream-atomic@1.0.10: resolution: {integrity: sha512-gehEzmPn2nAwr39eay+x3X34Ra+M2QlVUTLhkXPjWdeO8RF9kszk116avgBJM3ZyNHgHXBNx+VmPaFC36k0PzA==} dependencies: - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 iferr: 0.1.5 imurmurhash: 0.1.4 - readable-stream: 2.3.8 + readable-stream: 2.3.7 dev: true /fs.realpath@1.0.0: @@ -14338,7 +15638,7 @@ packages: requiresBuild: true dependencies: bindings: 1.5.0 - nan: 2.17.0 + nan: 2.16.0 dev: true optional: true @@ -14358,7 +15658,7 @@ packages: dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.21.2 + es-abstract: 1.20.4 functions-have-names: 1.2.3 dev: true @@ -14398,12 +15698,11 @@ packages: resolution: {integrity: sha512-Hm0ixYtaSZ/V7C8FJrtZIuBBI+iSgL+1Aq82zSu8VQNB4S3Gk8e7Qs3VwBDJAhmRZcFqkl3tQu36g/Foh5I5ig==} dev: false - /get-intrinsic@1.2.1: - resolution: {integrity: sha512-2DcsyfABl+gVHEfCOaTrWgyt+tb6MSEGmKq+kI5HwLbIYgjgmMcV8KQ41uaKz1xxUcn9tJtgFbQUEVcEbd0FYw==} + /get-intrinsic@1.2.0: + resolution: {integrity: sha512-L049y6nFOuom5wGyRc3/gdTLO94dySVKRACj1RmJZBQXlbTMhtNIgkWkUHq+jYmZvKf14EW1EoJnnjbmoHij0Q==} dependencies: function-bind: 1.1.1 has: 1.0.3 - has-proto: 1.0.1 has-symbols: 1.0.3 dev: true @@ -14451,7 +15750,7 @@ packages: engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 - get-intrinsic: 1.2.1 + get-intrinsic: 1.2.0 dev: true /get-tsconfig@4.6.2: @@ -14487,7 +15786,7 @@ packages: mri: 1.2.0 node-fetch-native: 1.2.0 pathe: 1.1.1 - tar: 6.1.15 + tar: 6.1.13 transitivePeerDependencies: - supports-color dev: true @@ -14496,8 +15795,8 @@ packages: resolution: {integrity: sha512-SyHy3T1v2NUXn29OsWdxmK6RwHD+vkj3v8en8AOBZ1wBQ/hCAQ5bAQTD02kW4W9tUp/3Qh6J8r9EvntiyCmOOw==} dev: true - /github-slugger@1.5.0: - resolution: {integrity: sha512-wIh+gKBI9Nshz2o46B0B3f5k/W+WI9ZAv6y5Dn5WJ5SK1t0TnDimB4WE5rmTD05ZAIn8HALCZVmCsvj0w0v0lw==} + /github-slugger@1.4.0: + resolution: {integrity: sha512-w0dzqw/nt51xMVmlaV1+JRzN+oCa1KfcgGEWhxUG16wbdA+Xnt/yoFO8Z8x/V82ZcZ0wy6ln9QDup5avbhiDhQ==} dev: true /givens@1.3.9: @@ -14530,7 +15829,7 @@ packages: peerDependencies: glob: '*' dependencies: - '@types/glob': 8.1.0 + '@types/glob': 8.0.0 glob: 7.2.3 dev: true @@ -14552,16 +15851,16 @@ packages: resolution: {integrity: sha512-lkX1HJXwyMcprw/5YUZc2s7DrpAiHB21/V+E1rHUrVNokkvB6bqMzT0VfV6/86ZNabt1k14YOIaT7nDvOX3Iiw==} dev: true - /glob@10.3.3: - resolution: {integrity: sha512-92vPiMb/iqpmEgsOoIDvTjc50wf9CCCvMzsi6W0JLPeUKE8TWP1a73PgqSrqy7iAZxaSD1YdzU7QZR5LF51MJw==} + /glob@10.2.7: + resolution: {integrity: sha512-jTKehsravOJo8IJxUGfZILnkvVJM/MOfHRs8QcXolVef2zNI9Tqyy5+SeuOAZd3upViEZQLyFpQhYiHLrMUNmA==} engines: {node: '>=16 || 14 >=14.17'} hasBin: true dependencies: foreground-child: 3.1.1 - jackspeak: 2.2.1 + jackspeak: 2.1.1 minimatch: 9.0.3 - minipass: 7.0.2 - path-scurry: 1.10.1 + minipass: 5.0.0 + path-scurry: 1.7.0 dev: true /glob@7.1.6: @@ -14585,19 +15884,19 @@ packages: once: 1.4.0 path-is-absolute: 1.0.1 - /glob@8.1.0: - resolution: {integrity: sha512-r8hpEjiQEYlF2QU0df3dS+nxxSIreXQS1qRhMJM0Q5NDdR386C7jb7Hwwod8Fgiuex+k0GFjgft18yvxm5XoCQ==} + /glob@8.0.3: + resolution: {integrity: sha512-ull455NHSHI/Y1FqGaaYFaLGkNMMJbavMrEGFXG/PGrg6y7sutWHUHrz6gy6WEBH6akM1M414dWKCNs+IhKdiQ==} engines: {node: '>=12'} dependencies: fs.realpath: 1.0.0 inflight: 1.0.6 inherits: 2.0.4 - minimatch: 5.1.6 + minimatch: 5.1.1 once: 1.4.0 dev: true - /global-dirs@3.0.1: - resolution: {integrity: sha512-NBcGGFbBA9s1VzD41QXDG+3++t9Mn5t1FpLdhESY6oKY4gYTFpX4wO3sqGUa0Srjtbfj3szX0RnemmrVRUdULA==} + /global-dirs@3.0.0: + resolution: {integrity: sha512-v8ho2DS5RiCjftj1nD9NmnfaOzTdud7RRnVd9kFNOjqZbISlx5DQ+OrTkywgd0dIt7oFCvKetZSHoHcP3sDdiA==} engines: {node: '>=10'} dependencies: ini: 2.0.0 @@ -14614,8 +15913,8 @@ packages: resolution: {integrity: sha512-WOBp/EEGUiIsJSp7wcv/y6MO+lV9UoncWqxuFfm8eBwzWNgyfBd6Gz+IeKQ9jCmyhoH99g15M3T+QaVHFjizVA==} engines: {node: '>=4'} - /globals@13.20.0: - resolution: {integrity: sha512-Qg5QtVkCy/kv3FUSlu4ukeZDVf9ee0iXLAUYX13gbR17bnejFTzr4iS9bY7kwCf1NztRNm1t91fjOiyx4CSwPQ==} + /globals@13.19.0: + resolution: {integrity: sha512-dkQ957uSRWHw7CFXLUtUHQI3g3aWApYhfNR2O6jn/907riyTYKVBmxYVROkBcY614FSSeSJh7Xm7SrUWCxvJMQ==} engines: {node: '>=8'} dependencies: type-fest: 0.20.2 @@ -14628,6 +15927,10 @@ packages: define-properties: 1.2.0 dev: true + /globalyzer@0.1.0: + resolution: {integrity: sha512-40oNTM9UfG6aBmuKxk/giHn5nQ8RVz/SS4Ir6zgzOv9/qC3kKZ9v4etGTcJbEl/NyVQH7FGU7d+X1egr57Md2Q==} + dev: true + /globby@11.1.0: resolution: {integrity: sha512-jhIXaOzy1sb8IyocaruWSn1TjmnBVs8Ayhcy83rmxNJ8q2uWKCAj3CnJY+KpGSXCueAPc0i05kVvVKtP1t9S3g==} engines: {node: '>=10'} @@ -14635,7 +15938,7 @@ packages: array-union: 2.1.0 dir-glob: 3.0.1 fast-glob: 3.3.0 - ignore: 5.2.4 + ignore: 5.2.0 merge2: 1.4.1 slash: 3.0.0 dev: true @@ -14656,6 +15959,10 @@ packages: - supports-color dev: true + /globrex@0.1.2: + resolution: {integrity: sha512-uHJgbwAMwNFf5mLst7IWLNg14x1CkeqglJb/K3doi4dw6q2IvAAmM/Y81kevy83wP+Sst+nutFTYOGg3d1lsxg==} + dev: true + /glur@1.1.2: resolution: {integrity: sha512-l+8esYHTKOx2G/Aao4lEQ0bnHWg4fWtJbVoZZT9Knxi01pB8C80BR85nONLFwkkQoFRCmXY+BUcGZN3yZ2QsRA==} dev: true @@ -14663,17 +15970,17 @@ packages: /gopd@1.0.1: resolution: {integrity: sha512-d65bNlIadxvpb/A2abVdlqKqV563juRnZ1Wtk6s1sIR8uNsXR70xqIzVqxVf1eTqDunwT2MkczEeaezCKTZhwA==} dependencies: - get-intrinsic: 1.2.1 + get-intrinsic: 1.2.0 dev: true /got@12.6.1: resolution: {integrity: sha512-mThBblvlAF1d4O5oqyvN+ZxLAYwIJK7bpMxgYqPD9okW0C3qm5FFn7k811QrcuEBwaogR3ngOFoCfs6mRv7teQ==} engines: {node: '>=14.16'} dependencies: - '@sindresorhus/is': 5.4.1 + '@sindresorhus/is': 5.3.0 '@szmarczak/http-timer': 5.0.1 cacheable-lookup: 7.0.0 - cacheable-request: 10.2.12 + cacheable-request: 10.2.8 decompress-response: 6.0.0 form-data-encoder: 2.1.4 get-stream: 6.0.1 @@ -14683,8 +15990,8 @@ packages: responselike: 3.0.0 dev: true - /graceful-fs@4.2.11: - resolution: {integrity: sha512-RbJ5/jmFcNNCcDV5o9eTnBLJ/HszWV0P73bc+Ff4nS/rJj+YaS6IGyiOL0VoBYX+l1Wrl3k63h/KrH+nhJ0XvQ==} + /graceful-fs@4.2.10: + resolution: {integrity: sha512-9ByhssR2fPVsNZj478qUUbKfmL0+t5BDVyjShtyZZLiK7ZDAArFFfopyOTj0M05wE2tJPisA4iTnnXl2YoPvOA==} dev: true /grapheme-splitter@1.0.4: @@ -14695,18 +16002,18 @@ packages: resolution: {integrity: sha512-EtKwoO6kxCL9WO5xipiHTZlSzBm7WLT627TqC/uVRd0HKmq8NXyebnNYxDoBi7wt8eTWrUrKXCOVaFq9x1kgag==} dev: true - /graphql-tag@2.12.6(graphql@16.7.1): + /graphql-tag@2.12.6(graphql@16.6.0): resolution: {integrity: sha512-FdSNcu2QQcWnM2VNvSCCDCVS5PpPqpzgFT8+GXzqJuoDd0CBncxCY278u4mhRO7tMgo2JjgJA5aZ+nWSQ/Z+xg==} engines: {node: '>=10'} peerDependencies: graphql: ^0.9.0 || ^0.10.0 || ^0.11.0 || ^0.12.0 || ^0.13.0 || ^14.0.0 || ^15.0.0 || ^16.0.0 dependencies: - graphql: 16.7.1 - tslib: 2.6.0 + graphql: 16.6.0 + tslib: 2.5.3 dev: false - /graphql@16.7.1: - resolution: {integrity: sha512-DRYR9tf+UGU0KOsMcKAlXeFfX89UiiIZ0dRU3mR0yJfu6OjZqUcp68NnFLnqQU5RexygFoDy1EW+ccOYcPfmHg==} + /graphql@16.6.0: + resolution: {integrity: sha512-KPIBPDlW7NxrbT/eh4qPXz5FiFdL5UbaA0XUNz2Rp3Z3hqBSkbj0GVjwFDztsWVauZUWsbKHgMg++sk8UX0bkw==} engines: {node: ^12.22.0 || ^14.16.0 || ^16.0.0 || >=17.0.0} /gzip-size@6.0.0: @@ -14730,7 +16037,7 @@ packages: source-map: 0.6.1 wordwrap: 1.0.0 optionalDependencies: - uglify-js: 3.17.4 + uglify-js: 3.17.0 dev: true /happy-dom@10.1.1: @@ -14784,12 +16091,7 @@ packages: /has-property-descriptors@1.0.0: resolution: {integrity: sha512-62DVLZGoiEBDHQyqG4w9xCuZ7eJEwNmJRWw2VY84Oedb7WFcA27fiEVe8oUQx9hAUJ4ekurquucTGwsyO1XGdQ==} dependencies: - get-intrinsic: 1.2.1 - dev: true - - /has-proto@1.0.1: - resolution: {integrity: sha512-7qE+iP+O+bgF9clE5+UoBFzE65mlBiVj3tKCrlNQ0Ogwm0BjpT/gK4SlLYDMybDh5I3TCTKnPPa0oMG7JDYrhg==} - engines: {node: '>= 0.4'} + get-intrinsic: 1.2.0 dev: true /has-symbols@1.0.3: @@ -14850,7 +16152,7 @@ packages: engines: {node: '>=4'} dependencies: inherits: 2.0.4 - readable-stream: 3.6.2 + readable-stream: 3.6.0 safe-buffer: 5.2.1 dev: true @@ -14864,7 +16166,7 @@ packages: /hast-to-hyperscript@9.0.1: resolution: {integrity: sha512-zQgLKqF+O2F72S1aa4y2ivxzSlko3MAvxkwG8ehGmNiqd98BIN3JM1rAJPmplEyLmGLO2QZYJtIneOSZ2YbJuA==} dependencies: - '@types/unist': 2.0.7 + '@types/unist': 2.0.6 comma-separated-tokens: 1.0.8 property-information: 5.6.0 space-separated-tokens: 1.1.5 @@ -14891,7 +16193,7 @@ packages: /hast-util-raw@6.0.1: resolution: {integrity: sha512-ZMuiYA+UF7BXBtsTBNcLBF5HzXzkyE6MLzJnL605LKE8GJylNjGc4jjxazAHUtcwT5/CEt6afRKViYB4X66dig==} dependencies: - '@types/hast': 2.3.5 + '@types/hast': 2.3.4 hast-util-from-parse5: 6.0.1 hast-util-to-parse5: 6.0.0 html-void-elements: 1.0.5 @@ -14916,7 +16218,7 @@ packages: /hastscript@6.0.0: resolution: {integrity: sha512-nDM6bvd7lIqDUiYEiu5Sl/+6ReP0BMk/2f4U/Rooccxkj0P5nm+acM5PrGJ/t5I8qPGiqZSE6hVAwZEdZIvP4w==} dependencies: - '@types/hast': 2.3.5 + '@types/hast': 2.3.4 comma-separated-tokens: 1.0.8 hast-util-parse-selector: 2.2.5 property-information: 5.6.0 @@ -14940,7 +16242,7 @@ packages: /history@5.3.0: resolution: {integrity: sha512-ZqaKwjjrAYUYfLG+htGaIIZ4nioX2L70ZUMIFysS3xvBsSG4x/n1V6TXV3N8ZYNuFGlDirFg32T7B6WOUPDYcQ==} dependencies: - '@babel/runtime': 7.22.6 + '@babel/runtime': 7.18.9 /hmac-drbg@1.0.1: resolution: {integrity: sha512-Tti3gMqLdZfhOQY1Mzf/AanLiqh1WTiJgEj26ZuYQ9fbkLomzGchCws4FyrSd4VkpBfiNhaE1On+lOz894jvXg==} @@ -14972,14 +16274,14 @@ packages: dependencies: inherits: 2.0.4 obuf: 1.1.2 - readable-stream: 2.3.8 + readable-stream: 2.3.7 wbuf: 1.7.3 dev: true /html-element-map@1.3.1: resolution: {integrity: sha512-6XMlxrAFX4UEEGxctfFnmrFaaZFNf9i5fNuV5wZ3WWQ4FVaNP1aX1LkX9j2mfEx1NpjeE/rL3nmgEn23GdFmrg==} dependencies: - array.prototype.filter: 1.0.2 + array.prototype.filter: 1.0.1 call-bind: 1.0.2 dev: true @@ -14997,12 +16299,12 @@ packages: whatwg-encoding: 2.0.0 dev: true - /html-entities@2.3.3: - resolution: {integrity: sha512-DV5Ln36z34NNTDgnz0EWGBLZENelNAtkiFA4kyNOG2tDI6Mz1uSWiq1wAKdyjnJwyDiDO7Fa2SO1CTxPXL8VxA==} + /html-entities@2.3.2: + resolution: {integrity: sha512-c3Ab/url5ksaT0WyleslpBEthOzWhrjQbg75y7XUsfSzi3Dgzt0l8w5e7DylRn15MTlMMD58dTfzddNS2kcAjQ==} dev: true - /html-entities@2.4.0: - resolution: {integrity: sha512-igBTJcNNNhvZFRtm8uA6xMY6xYleeDwn3PeBCkDz7tHttv4F2hsDI2aPgNERWzvRcNYHNT3ymRaQzllmXj4YsQ==} + /html-entities@2.3.3: + resolution: {integrity: sha512-DV5Ln36z34NNTDgnz0EWGBLZENelNAtkiFA4kyNOG2tDI6Mz1uSWiq1wAKdyjnJwyDiDO7Fa2SO1CTxPXL8VxA==} dev: true /html-escaper@2.0.2: @@ -15022,8 +16324,8 @@ packages: terser: 4.8.1 dev: true - /html-tags@3.3.1: - resolution: {integrity: sha512-ztqyC3kLto0e9WbNp0aeP+M3kTt+nbaIveGmUxAtZa+8iFgKLUOD4YKM5j+f3QD89bra7UeumolZHKuOXnTmeQ==} + /html-tags@3.2.0: + resolution: {integrity: sha512-vy7ClnArOZwCnqZgvv+ddgHgJiAFXe3Ge9ML5/mBctVJoUoYPCdxVucOywjDARn6CVoh3dRSFdPHy2sX80L0Wg==} engines: {node: '>=8'} dev: true @@ -15039,9 +16341,9 @@ packages: dependencies: '@types/html-minifier-terser': 5.1.2 '@types/tapable': 1.0.8 - '@types/webpack': 4.41.33 + '@types/webpack': 4.41.32 html-minifier-terser: 5.1.1 - loader-utils: 1.4.2 + loader-utils: 1.4.0 lodash: 4.17.21 pretty-error: 2.1.2 tapable: 1.1.3 @@ -15067,12 +16369,12 @@ packages: entities: 2.2.0 dev: true - /htmlparser2@8.0.2: - resolution: {integrity: sha512-GYdjWKDkbRLkZ5geuHs5NY1puJ+PXwP7+fHPRz06Eirsb9ugf6d8kkXav6ADhcODhFFPMIXyxkxSuMf3D6NCFA==} + /htmlparser2@8.0.1: + resolution: {integrity: sha512-4lVbmc1diZC7GUJQtRQ5yBAeUCL1exyMwmForWkRLnwyzWBFxN633SALPMGYaWZvKe9j1pRZJpauvmxENSp/EA==} dependencies: domelementtype: 2.3.0 domhandler: 5.0.3 - domutils: 3.1.0 + domutils: 3.0.1 entities: 4.5.0 dev: true @@ -15145,9 +16447,9 @@ packages: appdata-path: 1.0.0 compression: 1.7.4 cors: 2.8.5 - express: 4.18.2 + express: 4.18.1 spdy: 4.0.2 - uglify-js: 3.17.4 + uglify-js: 3.17.0 transitivePeerDependencies: - supports-color dev: true @@ -15177,8 +16479,8 @@ packages: engines: {node: '>=12.20.0'} dev: true - /human-signals@4.3.1: - resolution: {integrity: sha512-nZXjEF2nbo7lIw3mgYjItAfgQXog3OjJogSbKa2CQIIvSGWcKgeJnQlNXip6NglNzYH45nSRiEVimMvYL8DDqQ==} + /human-signals@4.3.0: + resolution: {integrity: sha512-zyzVyMjpGBX2+6cDVZeFPCdtOtdsxOeseRhB9tkQ6xXmGUNrcnBzdEKPy3VPNYz+4gy1oukVOXcrJCunSyc6QQ==} engines: {node: '>=14.18.0'} dev: true @@ -15221,7 +16523,7 @@ packages: hasBin: true dependencies: cross-spawn: 5.1.0 - semver: 5.7.2 + semver: 5.7.1 dev: true /iferr@0.1.5: @@ -15233,8 +16535,8 @@ packages: engines: {node: '>= 4'} dev: true - /ignore@5.2.4: - resolution: {integrity: sha512-MAb38BcSbH0eHNBxn7ql2NH/kX33OkB3lZ1BNdh7ENeRChHTYsTvWrMubiIAMNS2llXEEgZ1MUOBtXChP3kaFQ==} + /ignore@5.2.0: + resolution: {integrity: sha512-CmxgYGiEPCLhfLnpPp1MoRmifwEIOgjcHXxOBjv7mY96c+eWScsOP9c112ZyLdWHi0FxHjI+4uVhKYp/gcdRmQ==} engines: {node: '>= 4'} dev: true @@ -15310,12 +16612,12 @@ packages: resolution: {integrity: sha512-7NXolsK4CAS5+xvdj5OMMbI962hU/wvwoxk+LWR9Ek9bVtyuuYScDN6eS0rUm6TxApFpw7CX1o4uJzcd4AyD3Q==} dev: true - /inquirer@8.2.5: - resolution: {integrity: sha512-QAgPDQMEgrDssk1XiwwHoOGYF9BAbUcc1+j+FhEvaOt8/cKRqyLn0U5qA6F74fGhTMGxf92pOvPBeh29jQJDTQ==} + /inquirer@8.2.4: + resolution: {integrity: sha512-nn4F01dxU8VeKfq192IjLsxu0/OmMZ4Lg3xKAns148rCaXP6ntAoEkVYZThWjwON8AlzdZZi6oqnhNbxUG9hVg==} engines: {node: '>=12.0.0'} dependencies: ansi-escapes: 4.3.2 - chalk: 4.1.1 + chalk: 4.1.2 cli-cursor: 3.1.0 cli-width: 3.0.0 external-editor: 3.1.0 @@ -15336,7 +16638,7 @@ packages: engines: {node: '>=14.18.0'} dependencies: ansi-escapes: 4.3.2 - chalk: 5.3.0 + chalk: 5.2.0 cli-cursor: 3.1.0 cli-width: 4.0.0 external-editor: 3.1.0 @@ -15356,7 +16658,7 @@ packages: resolution: {integrity: sha512-Y+R5hJrzs52QCG2laLn4udYVnxsfny9CpOhNhUvk/SSSVyF6T27FzRbF0sroPidSu3X8oEAkOn2K804mjpt6UQ==} engines: {node: '>= 0.4'} dependencies: - get-intrinsic: 1.2.1 + get-intrinsic: 1.2.0 has: 1.0.3 side-channel: 1.0.4 dev: true @@ -15422,7 +16724,7 @@ packages: resolution: {integrity: sha512-y+FyyR/w8vfIRq4eQcM1EYgSTnmHXPqaF+IgzgraytCFq5Xh8lllDVmAZolPJiZttZLeFSINPYMaEJ7/vWUa1w==} dependencies: call-bind: 1.0.2 - get-intrinsic: 1.2.1 + get-intrinsic: 1.2.0 is-typed-array: 1.1.10 dev: true @@ -15478,6 +16780,11 @@ packages: builtin-modules: 3.3.0 dev: true + /is-callable@1.2.4: + resolution: {integrity: sha512-nsuwtxZfMX67Oryl9LCQ+upnC0Z0BgpwntpS89m1H/TLF0zNfzfLMV/9Wa/6MZsj0acpEjAO0KF1xT6ZdLl95w==} + engines: {node: '>= 0.4'} + dev: true + /is-callable@1.2.7: resolution: {integrity: sha512-1BC0BVFhS/p0qtw6enp8e+8OD0UrK0oFLztSjNzhcKA3WDuJxxAPXzPuPtKkjEY9UUoEWlX/8fgKeu2S8i9JTA==} engines: {node: '>= 0.4'} @@ -15627,7 +16934,7 @@ packages: resolution: {integrity: sha512-iwGqO3J21aaSkC7jWnHP/difazwS7SFeIqxv6wEtLU8Y5KlzFTjyqcSIT0d8s4+dDhKytsk9PJZ2BkS5eZwQRQ==} engines: {node: '>=10'} dependencies: - global-dirs: 3.0.1 + global-dirs: 3.0.0 is-path-inside: 3.0.3 dev: true @@ -15649,6 +16956,10 @@ packages: engines: {node: '>= 0.4'} dev: true + /is-node-process@1.0.1: + resolution: {integrity: sha512-5IcdXuf++TTNt3oGl9EBdkvndXA8gmc4bz/Y+mdEpWh3Mcn/+kOw6hI7LD5CocqJWMzeb0I0ClndRVNdEPuJXQ==} + dev: true + /is-node-process@1.2.0: resolution: {integrity: sha512-Vg4o6/fqPxIjtxgUH5QLJhwZ7gW5diGCVlXpuUfELC62CuxM1iHcRe51f2W1FDy04Ai4KJkagKjx3XaqyfRKXw==} dev: true @@ -15823,11 +17134,11 @@ packages: resolution: {integrity: sha512-t2yVvttHkQktwnNNmBQ98AhENLdPUTDTE21uPqAQ0ARwQfGeQKRVS0NNurH7bTf7RrvcVn1OOge45CnBeHCSmg==} dependencies: call-bind: 1.0.2 - get-intrinsic: 1.2.1 + get-intrinsic: 1.2.0 dev: true - /is-what@4.1.15: - resolution: {integrity: sha512-uKua1wfy3Yt+YqsD6mTUEa2zSi3G1oPlqTflgaPJ7z63vUGN5pxFpnQfeSLMFnJDEsdvOtkp1rUWkYjB4YfhgA==} + /is-what@4.1.8: + resolution: {integrity: sha512-yq8gMao5upkPoGEU9LsB2P+K3Kt8Q3fQFCGyNCWOAnJAMzEXVV9drYb0TXr42TTliLLhKIBvulgAXgtLLnwzGA==} engines: {node: '>=12.13'} dev: true @@ -15897,7 +17208,7 @@ packages: /isomorphic-unfetch@3.1.0: resolution: {integrity: sha512-geDJjpoZ8N0kWexiwkX8F9NkTsXhetLPVbZFQ+JTW239QNOwvB0gniuR1Wc6f0AMTn7/mFGyXvHTifrCp/GH8Q==} dependencies: - node-fetch: 2.6.12 + node-fetch: 2.6.11 unfetch: 4.2.0 transitivePeerDependencies: - encoding @@ -15915,11 +17226,11 @@ packages: resolution: {integrity: sha512-pzqtp31nLv/XFOzXGuvhCb8qhjmTVo5vjVk19XE4CRlSWz0KoeJ3bw9XsA7nOp9YBf4qHjwBxkDzKcME/J29Yg==} engines: {node: '>=8'} dependencies: - '@babel/core': 7.22.8 - '@babel/parser': 7.22.7 + '@babel/core': 7.18.13 + '@babel/parser': 7.18.13 '@istanbuljs/schema': 0.1.3 istanbul-lib-coverage: 3.2.0 - semver: 6.3.1 + semver: 6.3.0 transitivePeerDependencies: - supports-color dev: true @@ -15960,17 +17271,17 @@ packages: iterate-iterator: 1.0.2 dev: true - /jackspeak@2.2.1: - resolution: {integrity: sha512-MXbxovZ/Pm42f6cDIDkl3xpwv1AGwObKwfmjs2nQePiy85tP3fatofl3FC1aBsOtP/6fq5SbtgHwWcMsLP+bDw==} + /jackspeak@2.1.1: + resolution: {integrity: sha512-juf9stUEwUaILepraGOWIJTLwg48bUnBmRqd2ln2Os1sW987zeoj/hzhbvRB95oMuS2ZTpjULmdwHNX4rzZIZw==} engines: {node: '>=14'} dependencies: - '@isaacs/cliui': 8.0.2 + cliui: 8.0.1 optionalDependencies: '@pkgjs/parseargs': 0.11.0 dev: true - /jake@10.8.7: - resolution: {integrity: sha512-ZDi3aP+fG/LchyBzUM804VjddnwfSfsdeYkwt8NcbKRvo4rFkjhs456iLFn3k2ZUWvNe4i48WACDbza8fhq2+w==} + /jake@10.8.5: + resolution: {integrity: sha512-sVpxYeuAhWt0OTWITwT98oyV0GsXyMlXCF+3L1SuafBVUIr/uILGRB+NqwkzhgXKvoJpDIpQvqkUALgdmQsQxw==} engines: {node: '>=10'} hasBin: true dependencies: @@ -16010,7 +17321,7 @@ packages: jest-util: 27.5.1 pretty-format: 27.5.1 slash: 3.0.0 - stack-utils: 2.0.6 + stack-utils: 2.0.5 throat: 6.0.2 transitivePeerDependencies: - supports-color @@ -16031,7 +17342,7 @@ packages: '@jest/types': 27.5.1 chalk: 4.1.2 exit: 0.1.2 - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 import-local: 3.1.0 jest-config: 27.5.1(ts-node@10.9.1) jest-util: 27.5.1 @@ -16055,15 +17366,15 @@ packages: ts-node: optional: true dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 '@jest/test-sequencer': 27.5.1 '@jest/types': 27.5.1 - babel-jest: 27.5.1(@babel/core@7.22.8) + babel-jest: 27.5.1(@babel/core@7.22.5) chalk: 4.1.2 ci-info: 3.8.0 deepmerge: 4.3.1 glob: 7.2.3 - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 jest-circus: 27.5.1 jest-environment-jsdom: 27.5.1 jest-environment-node: 27.5.1 @@ -16097,14 +17408,14 @@ packages: pretty-format: 27.5.1 dev: true - /jest-diff@29.6.1: - resolution: {integrity: sha512-FsNCvinvl8oVxpNLttNQX7FAq7vR+gMDGj90tiP7siWw1UdakWUGqrylpsYrpvj908IYckm5Y0Q7azNAozU1Kg==} + /jest-diff@29.0.1: + resolution: {integrity: sha512-l8PYeq2VhcdxG9tl5cU78ClAlg/N7RtVSp0v3MlXURR0Y99i6eFnegmasOandyTmO6uEdo20+FByAjBFEO9nuw==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: chalk: 4.1.2 diff-sequences: 29.4.3 - jest-get-type: 29.4.3 - pretty-format: 29.6.1 + jest-get-type: 29.0.0 + pretty-format: 29.5.0 dev: true /jest-docblock@27.5.1: @@ -16160,8 +17471,8 @@ packages: engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dev: true - /jest-get-type@29.4.3: - resolution: {integrity: sha512-J5Xez4nRRMjk8emnTpWrlkyb9pfRQQanDrvWHhsR1+VUfbwxi30eVcZFlcdGInRibU4G5LwHXpI7IRHU0CY+gg==} + /jest-get-type@29.0.0: + resolution: {integrity: sha512-83X19z/HuLKYXYHskZlBAShO7UfLFXu/vWajw9ZNJASN32li8yHMaVGAQqxFW1RCFOkB7cubaL6FaJVQqqJLSw==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dev: true @@ -16170,11 +17481,11 @@ packages: engines: {node: '>= 10.14.2'} dependencies: '@jest/types': 26.6.2 - '@types/graceful-fs': 4.1.6 + '@types/graceful-fs': 4.1.5 '@types/node': 20.4.1 - anymatch: 3.1.3 - fb-watchman: 2.0.2 - graceful-fs: 4.2.11 + anymatch: 3.1.2 + fb-watchman: 2.0.1 + graceful-fs: 4.2.10 jest-regex-util: 26.0.0 jest-serializer: 26.6.2 jest-util: 26.6.2 @@ -16193,11 +17504,11 @@ packages: engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: '@jest/types': 27.5.1 - '@types/graceful-fs': 4.1.6 + '@types/graceful-fs': 4.1.5 '@types/node': 20.4.1 - anymatch: 3.1.3 - fb-watchman: 2.0.2 - graceful-fs: 4.2.11 + anymatch: 3.1.2 + fb-watchman: 2.0.1 + graceful-fs: 4.2.10 jest-regex-util: 27.5.1 jest-serializer: 27.5.1 jest-util: 27.5.1 @@ -16269,14 +17580,14 @@ packages: pretty-format: 27.5.1 dev: true - /jest-matcher-utils@29.6.1: - resolution: {integrity: sha512-SLaztw9d2mfQQKHmJXKM0HCbl2PPVld/t9Xa6P9sgiExijviSp7TnZZpw2Fpt+OI3nwUO/slJbOfzfUMKKC5QA==} + /jest-matcher-utils@29.0.1: + resolution: {integrity: sha512-/e6UbCDmprRQFnl7+uBKqn4G22c/OmwriE5KCMVqxhElKCQUDcFnq5XM9iJeKtzy4DUjxT27y9VHmKPD8BQPaw==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: chalk: 4.1.2 - jest-diff: 29.6.1 - jest-get-type: 29.4.3 - pretty-format: 29.6.1 + jest-diff: 29.0.1 + jest-get-type: 29.0.0 + pretty-format: 29.5.0 dev: true /jest-message-util@27.5.1: @@ -16287,26 +17598,26 @@ packages: '@jest/types': 27.5.1 '@types/stack-utils': 2.0.1 chalk: 4.1.2 - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 micromatch: 4.0.5 pretty-format: 27.5.1 slash: 3.0.0 - stack-utils: 2.0.6 + stack-utils: 2.0.5 dev: true - /jest-message-util@29.6.1: - resolution: {integrity: sha512-KoAW2zAmNSd3Gk88uJ56qXUWbFk787QKmjjJVOjtGFmmGSZgDBrlIL4AfQw1xyMYPNVD7dNInfIbur9B2rd/wQ==} + /jest-message-util@29.0.1: + resolution: {integrity: sha512-wRMAQt3HrLpxSubdnzOo68QoTfQ+NLXFzU0Heb18ZUzO2S9GgaXNEdQ4rpd0fI9dq2NXkpCk1IUWSqzYKji64A==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: '@babel/code-frame': 7.22.5 - '@jest/types': 29.6.1 + '@jest/types': 29.0.1 '@types/stack-utils': 2.0.1 chalk: 4.1.2 - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 micromatch: 4.0.5 - pretty-format: 29.6.1 + pretty-format: 29.5.0 slash: 3.0.0 - stack-utils: 2.0.6 + stack-utils: 2.0.5 dev: true /jest-mock@27.5.1: @@ -16356,7 +17667,7 @@ packages: dependencies: '@jest/types': 27.5.1 chalk: 4.1.2 - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 jest-haste-map: 27.5.1 jest-pnp-resolver: 1.2.3(jest-resolve@27.5.1) jest-util: 27.5.1 @@ -16378,7 +17689,7 @@ packages: '@types/node': 20.4.1 chalk: 4.1.2 emittery: 0.8.1 - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 jest-docblock: 27.5.1 jest-environment-jsdom: 27.5.1 jest-environment-node: 27.5.1 @@ -16410,11 +17721,11 @@ packages: '@jest/transform': 27.5.1 '@jest/types': 27.5.1 chalk: 4.1.2 - cjs-module-lexer: 1.2.3 - collect-v8-coverage: 1.0.2 + cjs-module-lexer: 1.2.2 + collect-v8-coverage: 1.0.1 execa: 5.1.1 glob: 7.2.3 - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 jest-haste-map: 27.5.1 jest-message-util: 27.5.1 jest-mock: 27.5.1 @@ -16433,7 +17744,7 @@ packages: engines: {node: '>= 10.14.2'} dependencies: '@types/node': 20.4.1 - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 dev: true /jest-serializer@27.5.1: @@ -16441,26 +17752,26 @@ packages: engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: '@types/node': 20.4.1 - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 dev: true /jest-snapshot@27.5.1: resolution: {integrity: sha512-yYykXI5a0I31xX67mgeLw1DZ0bJB+gpq5IpSuCAoyDi0+BhgU/RIrL+RTzDmkNTchvDFWKP8lp+w/42Z3us5sA==} engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: - '@babel/core': 7.22.8 - '@babel/generator': 7.22.7 - '@babel/plugin-syntax-typescript': 7.22.5(@babel/core@7.22.8) - '@babel/traverse': 7.22.8 + '@babel/core': 7.22.5 + '@babel/generator': 7.22.5 + '@babel/plugin-syntax-typescript': 7.20.0(@babel/core@7.22.5) + '@babel/traverse': 7.22.5 '@babel/types': 7.22.5 '@jest/transform': 27.5.1 '@jest/types': 27.5.1 - '@types/babel__traverse': 7.20.1 - '@types/prettier': 2.7.3 - babel-preset-current-node-syntax: 1.0.1(@babel/core@7.22.8) + '@types/babel__traverse': 7.18.3 + '@types/prettier': 2.7.0 + babel-preset-current-node-syntax: 1.0.1(@babel/core@7.22.5) chalk: 4.1.2 expect: 27.5.1 - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 jest-diff: 27.5.1 jest-get-type: 27.5.1 jest-haste-map: 27.5.1 @@ -16469,7 +17780,7 @@ packages: jest-util: 27.5.1 natural-compare: 1.4.0 pretty-format: 27.5.1 - semver: 7.5.4 + semver: 7.5.2 transitivePeerDependencies: - supports-color dev: true @@ -16481,7 +17792,7 @@ packages: '@jest/types': 26.6.2 '@types/node': 20.4.1 chalk: 4.1.2 - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 is-ci: 2.0.0 micromatch: 4.0.5 dev: true @@ -16494,19 +17805,19 @@ packages: '@types/node': 20.4.1 chalk: 4.1.2 ci-info: 3.8.0 - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 picomatch: 2.3.1 dev: true - /jest-util@29.6.1: - resolution: {integrity: sha512-NRFCcjc+/uO3ijUVyNOQJluf8PtGCe/W6cix36+M3cTFgiYqFOOW5MgN4JOOcvbUhcKTYVd1CvHz/LWi8d16Mg==} + /jest-util@29.0.1: + resolution: {integrity: sha512-GIWkgNfkeA9d84rORDHPGGTFBrRD13A38QVSKE0bVrGSnoR1KDn8Kqz+0yI5kezMgbT/7zrWaruWP1Kbghlb2A==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: - '@jest/types': 29.6.1 + '@jest/types': 29.0.1 '@types/node': 20.4.1 chalk: 4.1.2 - ci-info: 3.8.0 - graceful-fs: 4.2.11 + ci-info: 3.7.0 + graceful-fs: 4.2.10 picomatch: 2.3.1 dev: true @@ -16574,8 +17885,8 @@ packages: - utf-8-validate dev: true - /jiti@1.19.1: - resolution: {integrity: sha512-oVhqoRDaBXf7sjkll95LHVS6Myyyb1zaunVwk4Z0+WPSW4gjS0pl01zYKHScTuyEhQsFxV5L4DR5r+YqSyqyyg==} + /jiti@1.18.2: + resolution: {integrity: sha512-QAdOptna2NYiSSpv0O/BwoHBSmz4YhpzJHyi+fnMRTXFjp7B8i/YG5Z8IfusxB1ufjcD2Sre1F3R+nX3fvy7gg==} hasBin: true /joycon@3.1.1: @@ -16590,18 +17901,7 @@ packages: dependencies: config-chain: 1.1.13 editorconfig: 0.15.3 - glob: 8.1.0 - nopt: 6.0.0 - dev: true - - /js-beautify@1.14.8: - resolution: {integrity: sha512-4S7HFeI9YfRvRgKnEweohs0tgJj28InHVIj4Nl8Htf96Y6pHg3+tJrmo4ucAM9f7l4SHbFI3IvFAZ2a1eQPbyg==} - engines: {node: '>=12'} - hasBin: true - dependencies: - config-chain: 1.1.13 - editorconfig: 0.15.3 - glob: 8.1.0 + glob: 8.0.3 nopt: 6.0.0 dev: true @@ -16651,24 +17951,24 @@ packages: optional: true dependencies: abab: 2.0.6 - acorn: 8.10.0 + acorn: 8.9.0 acorn-globals: 6.0.0 cssom: 0.4.4 cssstyle: 2.3.0 data-urls: 2.0.0 decimal.js: 10.4.3 domexception: 2.0.1 - escodegen: 2.1.0 + escodegen: 2.0.0 form-data: 3.0.1 html-encoding-sniffer: 2.0.1 http-proxy-agent: 4.0.1 https-proxy-agent: 5.0.1 is-potential-custom-element-name: 1.0.1 - nwsapi: 2.2.7 + nwsapi: 2.2.4 parse5: 6.0.1 saxes: 5.0.1 symbol-tree: 3.2.4 - tough-cookie: 4.1.3 + tough-cookie: 4.1.2 w3c-hr-time: 1.0.2 w3c-xmlserializer: 2.0.0 webidl-conversions: 6.1.0 @@ -16683,6 +17983,48 @@ packages: - utf-8-validate dev: true + /jsdom@20.0.0: + resolution: {integrity: sha512-x4a6CKCgx00uCmP+QakBDFXwjAJ69IkkIWHmtmjd3wvXPcdOS44hfX2vqkOQrVrq8l9DhNNADZRXaCEWvgXtVA==} + engines: {node: '>=14'} + peerDependencies: + canvas: ^2.5.0 + peerDependenciesMeta: + canvas: + optional: true + dependencies: + abab: 2.0.6 + acorn: 8.9.0 + acorn-globals: 6.0.0 + cssom: 0.5.0 + cssstyle: 2.3.0 + data-urls: 3.0.2 + decimal.js: 10.4.0 + domexception: 4.0.0 + escodegen: 2.0.0 + form-data: 4.0.0 + html-encoding-sniffer: 3.0.0 + http-proxy-agent: 5.0.0 + https-proxy-agent: 5.0.1 + is-potential-custom-element-name: 1.0.1 + nwsapi: 2.2.1 + parse5: 7.0.0 + saxes: 6.0.0 + symbol-tree: 3.2.4 + tough-cookie: 4.1.2 + w3c-hr-time: 1.0.2 + w3c-xmlserializer: 3.0.0 + webidl-conversions: 7.0.0 + whatwg-encoding: 2.0.0 + whatwg-mimetype: 3.0.0 + whatwg-url: 11.0.0 + ws: 8.13.0 + xml-name-validator: 4.0.0 + transitivePeerDependencies: + - bufferutil + - supports-color + - utf-8-validate + dev: true + /jsdom@20.0.3: resolution: {integrity: sha512-SYhBvTh89tTfCD/CRdSOm13mOBa42iTaTyfyEWBdKcGdPxPtLFBXuHR8XHb33YNYaP+lLbmSvBTsnoesCNJEsQ==} engines: {node: '>=14'} @@ -16693,30 +18035,30 @@ packages: optional: true dependencies: abab: 2.0.6 - acorn: 8.10.0 + acorn: 8.8.2 acorn-globals: 7.0.1 cssom: 0.5.0 cssstyle: 2.3.0 data-urls: 3.0.2 - decimal.js: 10.4.3 + decimal.js: 10.4.2 domexception: 4.0.0 - escodegen: 2.1.0 + escodegen: 2.0.0 form-data: 4.0.0 html-encoding-sniffer: 3.0.0 http-proxy-agent: 5.0.0 https-proxy-agent: 5.0.1 is-potential-custom-element-name: 1.0.1 - nwsapi: 2.2.7 - parse5: 7.1.2 + nwsapi: 2.2.2 + parse5: 7.1.1 saxes: 6.0.0 symbol-tree: 3.2.4 - tough-cookie: 4.1.3 + tough-cookie: 4.1.2 w3c-xmlserializer: 4.0.0 webidl-conversions: 7.0.0 whatwg-encoding: 2.0.0 whatwg-mimetype: 3.0.0 whatwg-url: 11.0.0 - ws: 8.13.0 + ws: 8.11.0 xml-name-validator: 4.0.0 transitivePeerDependencies: - bufferutil @@ -16724,8 +18066,8 @@ packages: - utf-8-validate dev: true - /jsdom@21.1.2: - resolution: {integrity: sha512-sCpFmK2jv+1sjff4u7fzft+pUh2KSUbUrEHYHyfSIbGTIcmnjyp83qg6qLwdJ/I3LpTXx33ACxeRL7Lsyc6lGQ==} + /jsdom@21.0.0: + resolution: {integrity: sha512-AIw+3ZakSUtDYvhwPwWHiZsUi3zHugpMEKlNPaurviseYoBqo0zBd3zqoUi3LPCNtPFlEP8FiW9MqCZdjb2IYA==} engines: {node: '>=14'} peerDependencies: canvas: ^2.5.0 @@ -16734,29 +18076,29 @@ packages: optional: true dependencies: abab: 2.0.6 - acorn: 8.10.0 + acorn: 8.9.0 acorn-globals: 7.0.1 - cssstyle: 3.0.0 - data-urls: 4.0.0 + cssom: 0.5.0 + cssstyle: 2.3.0 + data-urls: 3.0.2 decimal.js: 10.4.3 domexception: 4.0.0 - escodegen: 2.1.0 + escodegen: 2.0.0 form-data: 4.0.0 html-encoding-sniffer: 3.0.0 http-proxy-agent: 5.0.0 https-proxy-agent: 5.0.1 is-potential-custom-element-name: 1.0.1 - nwsapi: 2.2.7 + nwsapi: 2.2.4 parse5: 7.1.2 - rrweb-cssom: 0.6.0 saxes: 6.0.0 symbol-tree: 3.2.4 - tough-cookie: 4.1.3 + tough-cookie: 4.1.2 w3c-xmlserializer: 4.0.0 webidl-conversions: 7.0.0 whatwg-encoding: 2.0.0 whatwg-mimetype: 3.0.0 - whatwg-url: 12.0.1 + whatwg-url: 11.0.0 ws: 8.13.0 xml-name-validator: 4.0.0 transitivePeerDependencies: @@ -16784,12 +18126,12 @@ packages: http-proxy-agent: 5.0.0 https-proxy-agent: 5.0.1 is-potential-custom-element-name: 1.0.1 - nwsapi: 2.2.7 + nwsapi: 2.2.4 parse5: 7.1.2 rrweb-cssom: 0.6.0 saxes: 6.0.0 symbol-tree: 3.2.4 - tough-cookie: 4.1.3 + tough-cookie: 4.1.2 w3c-xmlserializer: 4.0.0 webidl-conversions: 7.0.0 whatwg-encoding: 2.0.0 @@ -16850,13 +18192,18 @@ packages: resolution: {integrity: sha512-ZClg6AaYvamvYEE82d3Iyd3vSSIjQ+odgjaTzRuO3s7toCdFKczob2i0zCh7JE8kWn17yvAWhUVxvqGwUalsRA==} dev: true - /json5@1.0.2: - resolution: {integrity: sha512-g1MWMLBiz8FKi1e4w0UyVL3w+iJceWAFBAaBnnGKOpNa5f8TLktkbre1+s6oICydWAm+HRUGTmI+//xv2hvXYA==} + /json5@1.0.1: + resolution: {integrity: sha512-aKS4WQjPenRxiQsC93MNfjx+nbF4PAdYzmd/1JIj8HYzqfbu86beTuNgXDzPknWk0n0uARlyewZo4s++ES36Ow==} hasBin: true dependencies: minimist: 1.2.8 dev: true + /json5@2.2.1: + resolution: {integrity: sha512-1hqLFMSrGHRHxav9q9gNjJ5EXznIxGVO09xQRrwplcS8qs28pZ8s8hupZAmqDwZUmVZ2Qb2jnyPOWcDH8m8dlA==} + engines: {node: '>=6'} + hasBin: true + /json5@2.2.3: resolution: {integrity: sha512-XmOWe7eyHYH14cLdVPoyg+GOH3rYX++KpzrylJwSW98t3Nk+U8XOl8FWKOgwtzdb8lXGf6zYwDUzeHMWfxasyg==} engines: {node: '>=6'} @@ -16866,10 +18213,10 @@ packages: resolution: {integrity: sha512-9xZPKVYp9DxnM3sd1yAsh/d59iIaswDkai8oTxbursfKYbg/ibjX0IzFt35+VZ8iEW453TVTXztnRvYUQlAfUQ==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dependencies: - acorn: 8.10.0 + acorn: 8.9.0 eslint-visitor-keys: 3.4.1 - espree: 9.6.0 - semver: 7.5.4 + espree: 9.5.2 + semver: 7.5.2 dev: true /jsonc-parser@3.2.0: @@ -16880,7 +18227,7 @@ packages: dependencies: universalify: 2.0.0 optionalDependencies: - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 dev: true /jsonpointer@5.0.1: @@ -16943,8 +18290,8 @@ packages: engines: {node: '>=6'} dev: true - /klona@2.0.6: - resolution: {integrity: sha512-dhG34DXATL5hSxJbIexCft8FChFXtmskoZYnoPWjXQuebWYCNkVeV3KkGegCK9CP1oswI/vQibS2GY7Em/sJJA==} + /klona@2.0.5: + resolution: {integrity: sha512-pJiBpiXMbt7dkzXe8Ghj/u4FfXOOa98fPW+bihOJ4SjnoijweJrNThJfd3ifXpXhREjpoF2mZVH1GfS9LV3kHQ==} engines: {node: '>= 8'} dev: true @@ -16966,9 +18313,9 @@ packages: resolution: {integrity: sha512-prXSYk799h3GY3iOWnC6ZigYzMPjxN2svgjJ9shk7oMadSNX3wXy0B6F32PMJv7qtMnrIbUxoEHzbutvxR2LBQ==} engines: {node: '>=6.0.0', npm: '>=6.0.0', yarn: '>=1.0.0'} dependencies: - '@babel/runtime': 7.22.6 + '@babel/runtime': 7.18.9 app-root-dir: 1.0.2 - core-js: 3.31.1 + core-js: 3.25.0 dotenv: 8.6.0 dotenv-expand: 5.1.0 dev: true @@ -16977,7 +18324,7 @@ packages: resolution: {integrity: sha512-b94GiNHQNy6JNTrt5w6zNyffMrNkXZb3KTkCZJb2V1xaEGCk093vkZ2jk3tpaeP33/OiXC+WvK9AxUebnf5nbw==} engines: {node: '>= 0.6.3'} dependencies: - readable-stream: 2.3.8 + readable-stream: 2.3.7 dev: true /leven@3.1.0: @@ -16985,6 +18332,14 @@ packages: engines: {node: '>=6'} dev: true + /levn@0.3.0: + resolution: {integrity: sha512-0OO4y2iOHix2W6ujICbKIaEQXvFQHue65vUG3pb5EUomzPI90z9hsA1VsO/dbIIpC53J8gxM9Q4Oho0jrCM/yA==} + engines: {node: '>= 0.8.0'} + dependencies: + prelude-ls: 1.1.2 + type-check: 0.3.2 + dev: true + /levn@0.4.1: resolution: {integrity: sha512-+bT2uH4E5LGE7h/n3evcS/sQlJXCpIp6ym8OWJ5eV6+67Dsql/LaaT7qJBAt2rzfoa/5QBGBhxDix1dMt2kQKQ==} engines: {node: '>= 0.8.0'} @@ -16993,16 +18348,16 @@ packages: type-check: 0.4.0 dev: true - /light-my-request@5.10.0: - resolution: {integrity: sha512-ZU2D9GmAcOUculTTdH9/zryej6n8TzT+fNGdNtm6SDp5MMMpHrJJkvAdE3c6d8d2chE9i+a//dS9CWZtisknqA==} + /light-my-request@5.5.1: + resolution: {integrity: sha512-Zd4oZjF7axSyc5rYQsbB0qsgY4LFFviZSbEywxf7Vi5UE3y3c7tYF/GeheQjBNYY+pQ55BF8UGGJTjneoxOS1w==} dependencies: cookie: 0.5.0 - process-warning: 2.2.0 - set-cookie-parser: 2.6.0 + process-warning: 2.0.0 + set-cookie-parser: 2.5.1 dev: true - /lighthouse-logger@1.4.2: - resolution: {integrity: sha512-gPWxznF6TKmUHrOQjlVo2UbaL2EJ71mb2CCeRs/2qBpi4L/g4LUVc9+3lKQ6DTUZwJswfM7ainGrLO1+fOqa2g==} + /lighthouse-logger@1.3.0: + resolution: {integrity: sha512-BbqAKApLb9ywUli+0a+PcV04SyJ/N1q/8qgCNe6U97KbPCS1BTksEuHFLYdvc8DltuhfxIUBqDZsC0bBGtl3lA==} dependencies: debug: 2.6.9 marky: 1.2.5 @@ -17025,7 +18380,7 @@ packages: dependencies: chalk: 5.2.0 cli-truncate: 3.1.0 - commander: 10.0.1 + commander: 10.0.0 debug: 4.3.4(supports-color@8.1.1) execa: 7.1.1 lilconfig: 2.1.0 @@ -17034,7 +18389,7 @@ packages: normalize-path: 3.0.0 object-inspect: 1.12.3 pidtree: 0.6.0 - string-argv: 0.3.2 + string-argv: 0.3.1 yaml: 2.3.1 transitivePeerDependencies: - enquirer @@ -17080,33 +18435,32 @@ packages: wrap-ansi: 7.0.0 dev: true - /lit-element@3.3.2: - resolution: {integrity: sha512-xXAeVWKGr4/njq0rGC9dethMnYCq5hpKYrgQZYTzawt9YQhMiXfD+T1RgrdY3NamOxwq2aXlb0vOI6e29CKgVQ==} + /lit-element@3.2.2: + resolution: {integrity: sha512-6ZgxBR9KNroqKb6+htkyBwD90XGRiqKDHVrW/Eh0EZ+l+iC+u+v+w3/BA5NGi4nizAVHGYvQBHUDuSmLjPp7NQ==} dependencies: - '@lit-labs/ssr-dom-shim': 1.1.1 - '@lit/reactive-element': 1.6.2 - lit-html: 2.7.5 + '@lit/reactive-element': 1.4.1 + lit-html: 2.3.1 dev: false - /lit-html@2.7.5: - resolution: {integrity: sha512-YqUzpisJodwKIlbMFCtyrp58oLloKGnnPLMJ1t23cbfIJjg/H9pvLWK4XS69YeubK5HUs1UE4ys9w5dP1zg6IA==} + /lit-html@2.3.1: + resolution: {integrity: sha512-FyKH6LTW6aBdkfNhNSHyZTnLgJSTe5hMk7HFtc/+DcN1w74C215q8B+Cfxc2OuIEpBNcEKxgF64qL8as30FDHA==} dependencies: - '@types/trusted-types': 2.0.3 + '@types/trusted-types': 2.0.2 dev: false - /lit@2.7.6: - resolution: {integrity: sha512-1amFHA7t4VaaDe+vdQejSVBklwtH9svGoG6/dZi9JhxtJBBlqY5D1RV7iLUYY0trCqQc4NfhYYZilZiVHt7Hxg==} + /lit@2.3.1: + resolution: {integrity: sha512-TejktDR4mqG3qB32Y8Lm5Lye3c8SUehqz7qRsxe1PqGYL6me2Ef+jeQAEqh20BnnGncv4Yxy2njEIT0kzK1WCw==} dependencies: - '@lit/reactive-element': 1.6.2 - lit-element: 3.3.2 - lit-html: 2.7.5 + '@lit/reactive-element': 1.4.1 + lit-element: 3.2.2 + lit-html: 2.3.1 dev: false /load-json-file@1.1.0: resolution: {integrity: sha512-cy7ZdNRXdablkXYNI049pthVeXFurRyb9+hA/dZzerZ0pGTx42z+y+ssxBaVV2l70t1muq5IdKhn4UtcoGUY9A==} engines: {node: '>=0.10.0'} dependencies: - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 parse-json: 2.2.0 pify: 2.3.0 pinkie-promise: 2.0.1 @@ -17118,14 +18472,14 @@ packages: resolution: {integrity: sha512-Kx8hMakjX03tiGTLAIdJ+lL0htKnXjEZN6hk/tozf/WOuYGdZBJrZ+rCJRbVCugsjB3jMLn9746NsQIf5VjBMw==} engines: {node: '>=4'} dependencies: - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 parse-json: 4.0.0 pify: 3.0.0 strip-bom: 3.0.0 dev: true - /load-tsconfig@0.2.5: - resolution: {integrity: sha512-IXO6OCs9yg8tMKzfPZ1YmheJbZCiEsnBdcB03l0OcfK9prKnJb96siuHCr5Fl37/yo9DnKU+TLpxzTUspw9shg==} + /load-tsconfig@0.2.3: + resolution: {integrity: sha512-iyT2MXws+dc2Wi6o3grCFtGXpeMvHmJqS27sMPGtV2eUu4PeFnG+33I8BlFK1t1NWMjOpcx9bridn5yxLDX2gQ==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dev: true @@ -17139,17 +18493,17 @@ packages: engines: {node: '>=6.11.5'} dev: true - /loader-utils@1.4.2: - resolution: {integrity: sha512-I5d00Pd/jwMD2QCduo657+YM/6L3KZu++pmX9VFncxaxvHcru9jx1lBaFft+r4Mt2jK0Yhp41XlRAihzPxHNCg==} + /loader-utils@1.4.0: + resolution: {integrity: sha512-qH0WSMBtn/oHuwjy/NucEgbx5dbxxnxup9s4PVXJUDHZBQY+s0NWA9rJf53RBnQZxfch7euUui7hpoAPvALZdA==} engines: {node: '>=4.0.0'} dependencies: big.js: 5.2.2 emojis-list: 3.0.0 - json5: 1.0.2 + json5: 1.0.1 dev: true - /loader-utils@2.0.4: - resolution: {integrity: sha512-xXqpXoINfFhgua9xiqD8fPFHgkoq1mmmpE92WlDbm9rNRd/EbRb+Gqf908T2DMfuHjjJlksiK2RbHVOdD/MqSw==} + /loader-utils@2.0.2: + resolution: {integrity: sha512-TM57VeHptv569d/GKh6TAYdzKblwDNiumOdkFnejjD0XwTH87K90w3O7AiJRqdQoXygvi1VQTJTLGhJl7WqA7A==} engines: {node: '>=8.9.0'} dependencies: big.js: 5.2.2 @@ -17187,8 +18541,8 @@ packages: p-locate: 5.0.0 dev: true - /locate-path@7.2.0: - resolution: {integrity: sha512-gvVijfZvn7R+2qyPX8mAuKcFGDf6Nc61GdvGafQsHL0sBIxfKzA+usWn4GFC/bk+QdwPUD4kWFJLhElipq+0VA==} + /locate-path@7.1.1: + resolution: {integrity: sha512-vJXaRMJgRVD3+cUZs3Mncj2mxpt5mP0EmNOsxRSZRMlbqjvxzDEOIUWXGmavo0ZC9+tNZCBLQ66reA11nbpHZg==} engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dependencies: p-locate: 6.0.0 @@ -17283,7 +18637,7 @@ packages: cli-cursor: 4.0.0 slice-ansi: 5.0.0 strip-ansi: 7.1.0 - wrap-ansi: 8.1.0 + wrap-ansi: 8.0.1 dev: true /loglevel-plugin-prefix@0.8.4: @@ -17319,7 +18673,7 @@ packages: /lower-case@2.0.2: resolution: {integrity: sha512-7fm3l3NAF9WfN6W3JOmf5drwpVqX78JtoGJ3A6W0a6ZnldM41w2fV5D490psKFTpMds8TJse/eHLFFsNHHjHgg==} dependencies: - tslib: 2.6.0 + tslib: 2.5.3 dev: true /lowercase-keys@3.0.0: @@ -17327,11 +18681,6 @@ packages: engines: {node: ^12.20.0 || ^14.13.1 || >=16.0.0} dev: true - /lru-cache@10.0.0: - resolution: {integrity: sha512-svTf/fzsKHffP42sujkO/Rjs37BCIsQVRCeNYIm9WN8rgT7ffoUnRtZCqU+6BqcSBdv8gwJeTz8knJpgACeQMw==} - engines: {node: 14 || >=16.14} - dev: true - /lru-cache@4.1.5: resolution: {integrity: sha512-sWZlbEP2OsHNkXrMl5GYk/jKk70MBng6UU4YI/qGDYbgf6YbP4EvmqISbXCoJiRKs+1bSpFHVgQxvJ17F2li5g==} dependencies: @@ -17351,6 +18700,16 @@ packages: yallist: 4.0.0 dev: true + /lru-cache@9.1.1: + resolution: {integrity: sha512-65/Jky17UwSb0BuB9V+MyDpsOtXKmYwzhyl+cOa9XUiI4uV2Ouy/2voFP3+al0BjZbJgMBD8FojMpAf+Z+qn4A==} + engines: {node: 14 || >=16.14} + dev: true + + /lz-string@1.4.4: + resolution: {integrity: sha512-0ckx7ZHRPqb0oUm8zNr+90mtf9DQB60H1wMCjBtfi62Kl3a7JbHob6gA2bC+xRvZoOL+1hzUK8jeuEIQE8svEQ==} + hasBin: true + dev: true + /lz-string@1.5.0: resolution: {integrity: sha512-h5bgJWpxJNswbU7qCrV0tIKQCaS3blPDrqKWx+QxzuzL1zGUzij9XCWLrSLsJPu5t+eWA/ycetzYAO5IOMcWAQ==} hasBin: true @@ -17360,7 +18719,6 @@ packages: resolution: {integrity: sha512-RmF0AsMzgt25qzqqLc1+MbHmhdx0ojF2Fvs4XnOqz2ZOBXzzkEwc/dJQZCYHAn7v1jbVOjAZfK8msRn4BxO4VQ==} dependencies: sourcemap-codec: 1.4.8 - dev: true /magic-string@0.26.7: resolution: {integrity: sha512-hX9XH3ziStPoPhJxLq1syWuZMxbDvGNbVchfrdCtanC7D13888bMFow61x8axrx+GfHLtVeAx2kxL7tTGRl+Ow==} @@ -17376,6 +18734,13 @@ packages: '@jridgewell/sourcemap-codec': 1.4.15 dev: true + /magic-string@0.30.0: + resolution: {integrity: sha512-LA+31JYDJLs82r2ScLrlz1GjSgu66ZV518eyWT+S8VhyQn/JL0u9MeBOvQMGYiPk1DBiSN9DDMOcXvigJZaViQ==} + engines: {node: '>=12'} + dependencies: + '@jridgewell/sourcemap-codec': 1.4.15 + dev: true + /magic-string@0.30.1: resolution: {integrity: sha512-mbVKXPmS0z0G4XqFDCTllmDQ6coZzn94aMlb0o/A4HEHJCKcanlDZwYJgwnkmgD3jyWhUgj9VsPrfd972yPffA==} engines: {node: '>=12'} @@ -17387,14 +18752,14 @@ packages: engines: {node: '>=6'} dependencies: pify: 4.0.1 - semver: 5.7.2 + semver: 5.7.1 dev: true /make-dir@3.1.0: resolution: {integrity: sha512-g3FeP20LNwhALb/6Cz6Dd4F2ngze0jz7tbzrD2wAV+o9FeNHe4rL+yK2md0J/fiSf1sa1ADhXqi5+oVwOM/eGw==} engines: {node: '>=8'} dependencies: - semver: 6.3.1 + semver: 6.3.0 /make-error@1.3.6: resolution: {integrity: sha512-s8UhlNe7vPKomQhC1qFelMokr/Sc3AgNbso3n74mVPA5LTZwkB9NlXf4XPamLxJE8h0gh73rM94xvwRT2CVInw==} @@ -17443,7 +18808,7 @@ packages: /match-sorter@6.3.1: resolution: {integrity: sha512-mxybbo3pPNuA+ZuCUhm5bwNkXrJTbsk5VWbR5wiwz/GC6LIiegBGn2w3O08UG/jdbYLinw51fSQ5xNU1U3MgBw==} dependencies: - '@babel/runtime': 7.22.6 + '@babel/runtime': 7.18.9 remove-accents: 0.4.2 dev: false @@ -17470,7 +18835,7 @@ packages: /mdast-util-from-markdown@0.8.5: resolution: {integrity: sha512-2hkTXtYYnr+NubD/g6KGBS/0mFmBcifAsI0yIWRiRo0PjVs6SSOSOdtzbp6kSGnShDN6G5aWZpKQ2lWRy27mWQ==} dependencies: - '@types/mdast': 3.0.12 + '@types/mdast': 3.0.10 mdast-util-to-string: 2.0.0 micromark: 2.11.4 parse-entities: 2.0.0 @@ -17482,8 +18847,8 @@ packages: /mdast-util-to-hast@10.0.1: resolution: {integrity: sha512-BW3LM9SEMnjf4HXXVApZMt8gLQWVNXc3jryK0nJu/rOXPOnlkUjmdkDlmxMirpbU9ILncGFIwLH/ubnWBbcdgA==} dependencies: - '@types/mdast': 3.0.12 - '@types/unist': 2.0.7 + '@types/mdast': 3.0.10 + '@types/unist': 2.0.6 mdast-util-definitions: 4.0.0 mdurl: 1.0.1 unist-builder: 2.0.3 @@ -17509,15 +18874,15 @@ packages: dev: true /media-typer@0.3.0: - resolution: {integrity: sha512-dq+qelQ9akHpcOl/gUVRTxVIOkAJ1wR3QAvb4RsVjS8oVoFjDGTc679wJYmUmknUF5HwMLOgb5O+a3KxfWapPQ==} + resolution: {integrity: sha1-hxDXrwqmJvj/+hzgAWhUUmMlV0g=} engines: {node: '>= 0.6'} dev: true - /memfs@3.5.3: - resolution: {integrity: sha512-UERzLsxzllchadvbPs5aolHh65ISpKpM+ccLbOJ8/vvpBKmAWf+la7dXFy7Mr0ySHbdHrFv5kGFCUHHe6GFEmw==} + /memfs@3.4.7: + resolution: {integrity: sha512-ygaiUSNalBX85388uskeCyhSAoOSgzBbtVCr9jA2RROssFL9Q19/ZXFqS+2Th2sr1ewNIWgFdLzLC3Yl1Zv+lw==} engines: {node: '>= 4.0.0'} dependencies: - fs-monkey: 1.0.4 + fs-monkey: 1.0.3 dev: true /memoizerific@1.11.3: @@ -17530,7 +18895,7 @@ packages: resolution: {integrity: sha512-cda4JKCxReDXFXRqOHPQscuIYg1PvxbE2S2GP45rnwfEK+vZaXC8C1OFvdHIbgw0DLzowXGVoxLaAmlgRy14GQ==} dependencies: errno: 0.1.8 - readable-stream: 2.3.8 + readable-stream: 2.3.7 dev: true /memory-fs@0.5.0: @@ -17538,7 +18903,7 @@ packages: engines: {node: '>=4.3.0 <5.0.0 || >=5.10'} dependencies: errno: 0.1.8 - readable-stream: 2.3.8 + readable-stream: 2.3.7 dev: true /memorystream@0.3.1: @@ -17563,15 +18928,15 @@ packages: dev: true optional: true - /merge-anything@5.1.7: - resolution: {integrity: sha512-eRtbOb1N5iyH0tkQDAoQ4Ipsp/5qSR79Dzrz8hEPxRX10RWWR/iQXdoKmBSRCThY1Fh5EhISDtpSc93fpxUniQ==} + /merge-anything@5.1.4: + resolution: {integrity: sha512-7PWKwGOs5WWcpw+/OvbiFiAvEP6bv/QHiicigpqMGKIqPPAtGhBLR8LFJW+Zu6m9TXiR/a8+AiPlGG0ko1ruoQ==} engines: {node: '>=12.13'} dependencies: - is-what: 4.1.15 + is-what: 4.1.8 dev: true /merge-descriptors@1.0.1: - resolution: {integrity: sha512-cCi6g3/Zr1iqQi6ySbseM1Xvooa98N0w31jzUYrXPX2xqObmFGHJ0tQ5u74H3mVh7wLouTseZyYIq39g8cNp1w==} + resolution: {integrity: sha1-sAqqVW3YtEVoFQ7J0blT8/kMu2E=} dev: true /merge-stream@2.0.0: @@ -17714,13 +19079,20 @@ packages: dependencies: brace-expansion: 1.1.11 - /minimatch@5.1.6: - resolution: {integrity: sha512-lKwV/1brpG6mBUFHtb7NUmtABCb2WZZmm2wNiOA5hAb8VdCS4B3dtMWyvcoViccwAW/COERjXLt0zP1zXUN26g==} + /minimatch@5.1.1: + resolution: {integrity: sha512-362NP+zlprccbEt/SkxKfRMHnNY85V74mVnpUpNyr3F35covl09Kec7/sEFLt3RA4oXmewtoaanoIf67SE5Y5g==} engines: {node: '>=10'} dependencies: brace-expansion: 2.0.1 dev: true + /minimatch@9.0.1: + resolution: {integrity: sha512-0jWhJpD/MdhPXwPuiRkCbfYfSKp2qnn2eOc279qI7f+osl/l+prKSrvhg157zSYvx/1nmgn2NqdT6k2Z7zSH9w==} + engines: {node: '>=16 || 14 >=14.17'} + dependencies: + brace-expansion: 2.0.1 + dev: true + /minimatch@9.0.3: resolution: {integrity: sha512-RHiac9mvaRw0x3AYRgDC1CxAP7HTcNrrECeA8YYJeWnpo+2Q5CegtZjaotWTWxDG3UeGA1coE05iH1mPjT/2mg==} engines: {node: '>=16 || 14 >=14.17'} @@ -17728,6 +19100,10 @@ packages: brace-expansion: 2.0.1 dev: true + /minimist@1.2.7: + resolution: {integrity: sha512-bzfL1YUZsP41gmu/qjrEk0Q6i2ix/cVeAhbCbqH9u3zYutS1cLg00qhrD0M2MVdCcx4Sc0UpP2eBWo9rotpq6g==} + dev: true + /minimist@1.2.8: resolution: {integrity: sha512-2yyAR8qBkN3YuheJanUpWC5U3bb5osDywNB8RzDVlDwDHbocAJveqqj1u8+SVD7jkWT4yvsHCpWqqWqAxb0zCA==} dev: true @@ -17736,38 +19112,38 @@ packages: resolution: {integrity: sha512-6T6lH0H8OG9kITm/Jm6tdooIbogG9e0tLgpY6mphXSm/A9u8Nq1ryBG+Qspiub9LjWlBPsPS3tWQ/Botq4FdxA==} engines: {node: '>= 8'} dependencies: - minipass: 3.3.6 + minipass: 3.3.4 dev: true /minipass-flush@1.0.5: resolution: {integrity: sha512-JmQSYYpPUqX5Jyn1mXaRwOda1uQ8HP5KAT/oDSLCzt1BYRhQU0/hDtsB1ufZfEEzMZ9aAVmsBw8+FWsIXlClWw==} engines: {node: '>= 8'} dependencies: - minipass: 3.3.6 + minipass: 3.3.4 dev: true /minipass-pipeline@1.2.4: resolution: {integrity: sha512-xuIq7cIOt09RPRJ19gdi4b+RiNvDFYe5JH+ggNvBqGqpQXcru3PcRmOZuHBKWK1Txf9+cQ+HMVN4d6z46LZP7A==} engines: {node: '>=8'} dependencies: - minipass: 3.3.6 + minipass: 3.3.4 dev: true - /minipass@3.3.6: - resolution: {integrity: sha512-DxiNidxSEK+tHG6zOIklvNOwm3hvCrbUrdtzY74U6HKTJxvIDfOUL5W5P2Ghd3DTkhhKPYGqeNUIh5qcM4YBfw==} + /minipass@3.3.4: + resolution: {integrity: sha512-I9WPbWHCGu8W+6k1ZiGpPu0GkoKBeorkfKNuAFBNS1HNFJvke82sxvI5bzcCNpWPorkOO5QQ+zomzzwRxejXiw==} engines: {node: '>=8'} dependencies: yallist: 4.0.0 dev: true - /minipass@5.0.0: - resolution: {integrity: sha512-3FnjYuehv9k6ovOEbyOswadCDPX1piCfhV8ncmYtHOjuPwylVWsghTLo7rabjC3Rx5xD4HDx8Wm1xnMF7S5qFQ==} + /minipass@4.2.5: + resolution: {integrity: sha512-+yQl7SX3bIT83Lhb4BVorMAHVuqsskxRdlmO9kTpyukp8vsm2Sn/fUOV9xlnG8/a5JsypJzap21lz/y3FBMJ8Q==} engines: {node: '>=8'} dev: true - /minipass@7.0.2: - resolution: {integrity: sha512-eL79dXrE1q9dBbDCLg7xfn/vl7MS4F1gvJAgjJrQli/jbQWdUttuVawphqpffoIYfRdq78LHx6GP4bU/EQ2ATA==} - engines: {node: '>=16 || 14 >=14.17'} + /minipass@5.0.0: + resolution: {integrity: sha512-3FnjYuehv9k6ovOEbyOswadCDPX1piCfhV8ncmYtHOjuPwylVWsghTLo7rabjC3Rx5xD4HDx8Wm1xnMF7S5qFQ==} + engines: {node: '>=8'} dev: true /minisearch@6.1.0: @@ -17778,7 +19154,7 @@ packages: resolution: {integrity: sha512-bAxsR8BVfj60DWXHE3u30oHzfl4G7khkSuPW+qvpd7jFRHm7dLxOjUk1EHACJ/hxLY8phGJ0YhYHZo7jil7Qdg==} engines: {node: '>= 8'} dependencies: - minipass: 3.3.6 + minipass: 3.3.4 yallist: 4.0.0 dev: true @@ -17818,7 +19194,7 @@ packages: resolution: {integrity: sha512-FP+p8RB8OWpF3YZBCrP5gtADmtXApB5AMLn+vdyA+PyxCjrCs00mjyUozssO33cwDeT3wNGdLxJ5M//YqtHAJw==} hasBin: true dependencies: - minimist: 1.2.8 + minimist: 1.2.7 dev: true /mkdirp@1.0.4: @@ -17830,16 +19206,16 @@ packages: /mlly@1.4.0: resolution: {integrity: sha512-ua8PAThnTwpprIaU47EPeZ/bPUVp2QYBbWMphUQpVdBI3Lgqzm5KZQ45Agm3YJedHXaIHl6pBGabaLSUPPSptg==} dependencies: - acorn: 8.10.0 + acorn: 8.9.0 pathe: 1.1.1 pkg-types: 1.0.3 ufo: 1.1.2 - /modern-node-polyfills@0.1.3(rollup@3.26.2): + /modern-node-polyfills@0.1.3(rollup@3.26.0): resolution: {integrity: sha512-/4dB85Sdkt9MjWwtpKnsNTYhh0+fqjFC4ZEgDP4B0e6kyzbGUnX4NDxTUCaVwRLVF9gcEDcRQjol8pn05B3TUQ==} dependencies: '@jspm/core': 2.0.0-beta.24 - '@rollup/pluginutils': 3.1.0(rollup@3.26.2) + '@rollup/pluginutils': 3.1.0(rollup@3.26.0) esbuild: 0.14.54 local-pkg: 0.4.3 transitivePeerDependencies: @@ -17850,8 +19226,8 @@ packages: resolution: {integrity: sha512-5LC9SOxjSc2HF6vO2CyuTDNivEdoz2IvyJJGj6X8DJ0eFyfszE0QiEd+iXmBvUP3WHxSjFH/vIsA0EN00cgr8w==} dev: true - /moo@0.5.2: - resolution: {integrity: sha512-iSAJLHYKnX41mKcJKjqvnAN9sf0LMDTXDEvFv+ffuRR9a1MIuXLjMNL6EsnDHSkKLTWNqQQ5uo61P4EbU4NU+Q==} + /moo@0.5.1: + resolution: {integrity: sha512-I1mnb5xn4fO80BH9BLcF0yLypy2UKl+Cb01Fu0hJRkJjlCRtxZMWkTdAtDd5ZqCOxtCkhmRwyI57vWT+1iZ67w==} dev: true /move-concurrently@1.0.1: @@ -17889,17 +19265,21 @@ packages: resolution: {integrity: sha512-6FlzubTLZG3J2a/NVCAleEhjzq5oxgHyaCU9yYXvcLsvoVaHJq/s5xXI6/XXP6tz7R9xAOtHnSO/tXtF3WRTlA==} dev: true - /msw-storybook-addon@1.8.0(msw@0.49.3): - resolution: {integrity: sha512-dw3vZwqjixmiur0vouRSOax7wPSu9Og2Hspy9JZFHf49bZRjwDiLF0Pfn2NXEkGviYJOJiGxS1ejoTiUwoSg4A==} + /msw-storybook-addon@1.6.3(msw@0.49.2)(react-dom@17.0.2)(react@17.0.2): + resolution: {integrity: sha512-Ps80WdRmXsmenoTwfrgKMNpQD8INUUFyUFyZOecx8QjuqSlL++UYrLaGyACXN2goOn+/VS6rb0ZapbjrasPClg==} peerDependencies: - msw: '>=0.35.0 <2.0.0' + msw: '>=0.35.0 <1.0.0' dependencies: - is-node-process: 1.2.0 - msw: 0.49.3(typescript@4.9.5) + '@storybook/addons': 6.5.10(react-dom@17.0.2)(react@17.0.2) + is-node-process: 1.0.1 + msw: 0.49.2(typescript@4.8.4) + transitivePeerDependencies: + - react + - react-dom dev: true - /msw@0.49.3(typescript@4.9.5): - resolution: {integrity: sha512-kRCbDNbNnRq5LC1H/NUceZlrPAvSrMH6Or0mirIuH69NY84xwDruPn/hkXTovIK1KwDwbk+ZdoSyJlpiekLxEA==} + /msw@0.49.2(typescript@4.8.4): + resolution: {integrity: sha512-70/E10f+POE2UmMw16v8PnKatpZplpkUwVRLBqiIdimpgaC3le7y2yOq9JmOrL15jpwWM5wAcPTOj0f550LI3g==} engines: {node: '>=14'} hasBin: true requiresBuild: true @@ -17910,61 +19290,61 @@ packages: optional: true dependencies: '@mswjs/cookies': 0.2.2 - '@mswjs/interceptors': 0.17.9 + '@mswjs/interceptors': 0.17.6 '@open-draft/until': 1.0.3 '@types/cookie': 0.4.1 '@types/js-levenshtein': 1.1.1 chalk: 4.1.1 chokidar: 3.5.3 cookie: 0.4.2 - graphql: 16.7.1 + graphql: 16.6.0 headers-polyfill: 3.1.2 - inquirer: 8.2.5 - is-node-process: 1.2.0 + inquirer: 8.2.4 + is-node-process: 1.0.1 js-levenshtein: 1.1.6 - node-fetch: 2.6.12 - outvariant: 1.4.0 + node-fetch: 2.6.7 + outvariant: 1.3.0 path-to-regexp: 6.2.1 - strict-event-emitter: 0.4.6 + strict-event-emitter: 0.2.8 type-fest: 2.19.0 - typescript: 4.9.5 - yargs: 17.7.2 + typescript: 4.8.4 + yargs: 17.5.1 transitivePeerDependencies: - encoding - supports-color dev: true - /msw@1.2.2(typescript@5.1.6): - resolution: {integrity: sha512-GsW3PE/Es/a1tYThXcM8YHOZ1S1MtivcS3He/LQbbTCx3rbWJYCtWD5XXyJ53KlNPT7O1VI9sCW3xMtgFe8XpQ==} + /msw@1.2.1(typescript@5.1.6): + resolution: {integrity: sha512-bF7qWJQSmKn6bwGYVPXOxhexTCGD5oJSZg8yt8IBClxvo3Dx/1W0zqE1nX9BSWmzRsCKWfeGWcB/vpqV6aclpw==} engines: {node: '>=14'} hasBin: true requiresBuild: true peerDependencies: - typescript: '>= 4.4.x <= 5.1.x' + typescript: '>= 4.4.x <= 5.0.x' peerDependenciesMeta: typescript: optional: true dependencies: '@mswjs/cookies': 0.2.2 - '@mswjs/interceptors': 0.17.9 + '@mswjs/interceptors': 0.17.6 '@open-draft/until': 1.0.3 '@types/cookie': 0.4.1 '@types/js-levenshtein': 1.1.1 chalk: 4.1.1 chokidar: 3.5.3 cookie: 0.4.2 - graphql: 16.7.1 + graphql: 16.6.0 headers-polyfill: 3.1.2 - inquirer: 8.2.5 + inquirer: 8.2.4 is-node-process: 1.2.0 js-levenshtein: 1.1.6 - node-fetch: 2.6.12 + node-fetch: 2.6.7 outvariant: 1.4.0 path-to-regexp: 6.2.1 strict-event-emitter: 0.4.6 type-fest: 2.19.0 typescript: 5.1.6 - yargs: 17.7.2 + yargs: 17.7.1 transitivePeerDependencies: - encoding - supports-color @@ -17987,13 +19367,14 @@ packages: thenify-all: 1.6.0 dev: true - /nan@2.17.0: - resolution: {integrity: sha512-2ZTgtl0nJsO0KQCjEpxcIr5D+Yv90plTitZt9JBfQvVJDS5seMl3FOvsh3+9CoYWXf/1l5OaZzzF6nDm4cagaQ==} + /nan@2.16.0: + resolution: {integrity: sha512-UdAqHyFngu7TfQKsCBgAA6pWDkT8MAO7d0jyOecVhN5354xbLqdn8mV9Tat9gepAupm0bt2DbeaSC8vS52MuFA==} + requiresBuild: true dev: true optional: true /nano-time@1.0.0: - resolution: {integrity: sha512-flnngywOoQ0lLQOTRNexn2gGSNuM9bKj9RZAWSzhQ+UJYaAFG9bac4DW9VHjUAzrOaIcajHybCTHe/bkvozQqA==} + resolution: {integrity: sha1-sFVPaa2J4i0JB/ehKwmTpdlhN+8=} dependencies: big-integer: 1.6.51 dev: false @@ -18039,7 +19420,7 @@ packages: hasBin: true dependencies: commander: 2.20.3 - moo: 0.5.2 + moo: 0.5.1 railroad-diagrams: 1.0.0 randexp: 0.4.6 dev: true @@ -18057,7 +19438,7 @@ packages: resolution: {integrity: sha512-9iN1ka/9zmX1ZvLV9ewJYEk9h7RyRRtqdK0woXcqohu8EWIerfPUjYJPg0ULy0UqP7cslmdGc8xKDJcojlKiaw==} dev: true - /next@12.1.5(@babel/core@7.22.8)(react-dom@18.0.0)(react@18.0.0): + /next@12.1.5(@babel/core@7.22.5)(react-dom@18.0.0)(react@18.0.0): resolution: {integrity: sha512-YGHDpyfgCfnT5GZObsKepmRnne7Kzp7nGrac07dikhutWQug7hHg85/+sPJ4ZW5Q2pDkb+n0FnmLkmd44htIJQ==} engines: {node: '>=12.22.0'} hasBin: true @@ -18076,11 +19457,11 @@ packages: optional: true dependencies: '@next/env': 12.1.5 - caniuse-lite: 1.0.30001515 + caniuse-lite: 1.0.30001385 postcss: 8.4.5 react: 18.0.0 react-dom: 18.0.0(react@18.0.0) - styled-jsx: 5.0.1(@babel/core@7.22.8)(react@18.0.0) + styled-jsx: 5.0.1(@babel/core@7.22.5)(react@18.0.0) optionalDependencies: '@next/swc-android-arm-eabi': 12.1.5 '@next/swc-android-arm64': 12.1.5 @@ -18107,14 +19488,14 @@ packages: resolution: {integrity: sha512-fgAN3jGAh+RoxUGZHTSOLJIqUc2wmoBwGR4tbpNAKmmovFoWq0OdRkb0VkldReO2a2iBT/OEulG9XSUc10r3zg==} dependencies: lower-case: 2.0.2 - tslib: 2.6.0 + tslib: 2.5.3 dev: true /node-abi@3.45.0: resolution: {integrity: sha512-iwXuFrMAcFVi/ZoZiqq8BzAdsLw9kxDfTC0HMyjXfSL/6CSDAGD5UmR7azrAgWV1zKYq7dUUMj4owusBWKLsiQ==} engines: {node: '>=10'} dependencies: - semver: 7.5.4 + semver: 7.5.2 dev: true /node-addon-api@6.1.0: @@ -18136,8 +19517,8 @@ packages: resolution: {integrity: sha512-5IAMBTl9p6PaAjYCnMv5FmqIF6GcZnawAVnzaCG0rX2aYZJ4CxEkZNtVPuTRug7fL7wyM5BQYTlAzcyMPi6oTQ==} dev: true - /node-fetch@2.6.12: - resolution: {integrity: sha512-C/fGU2E8ToujUivIO0H+tpQ6HWo4eEmchoPIoXtxCrVghxdKq+QOHqEZW7tuP3KlV3bC8FRMO5nMCC7Zm1VP6g==} + /node-fetch@2.6.11: + resolution: {integrity: sha512-4I6pdBY1EthSqDmJkiNk3JIT8cswwR9nfeW/cPdUagJYEQG7R95WRH74wpz7ma8Gh/9dI9FP+OU+0E4FvtA55w==} engines: {node: 4.x || >=6.0.0} peerDependencies: encoding: ^0.1.0 @@ -18146,6 +19527,7 @@ packages: optional: true dependencies: whatwg-url: 5.0.0 + dev: true /node-fetch@2.6.7: resolution: {integrity: sha512-ZjMPFEfVx5j+y2yF35Kzx5sF7kDzxuDj6ziH4FFbOp87zKDZNx8yExJIb05OGF4Nlt9IHFIMBkRl41VdvcNdbQ==} @@ -18157,7 +19539,6 @@ packages: optional: true dependencies: whatwg-url: 5.0.0 - dev: true /node-int64@0.4.0: resolution: {integrity: sha512-O5lz91xSOeoXP6DulyHfllpq+Eg00MWitZIbtPfoSEvqIHdl5gfcY6hYzDWnj0qD5tz52PI08u9qUvSVeUBeHw==} @@ -18180,19 +19561,19 @@ packages: process: 0.11.10 punycode: 1.4.1 querystring-es3: 0.2.1 - readable-stream: 2.3.8 + readable-stream: 2.3.7 stream-browserify: 2.0.2 stream-http: 2.8.3 string_decoder: 1.3.0 timers-browserify: 2.0.12 tty-browserify: 0.0.0 - url: 0.11.1 + url: 0.11.0 util: 0.11.1 vm-browserify: 1.1.2 dev: true - /node-releases@2.0.13: - resolution: {integrity: sha512-uYr7J37ae/ORWdZeQ1xxMJe3NtdmqMC/JZK+geofDrkLUApKRHPd18/TxtBOJ4A0/+uUIliorNrfYV6s1b02eQ==} + /node-releases@2.0.6: + resolution: {integrity: sha512-PiVXnNuFm5+iYkLBNeq5211hvO38y63T0i2KKh2KnUs3RpzJ+JtODFjkD8yjLwnDkTYF1eKXheUwdssR+NRZdg==} /nopt@6.0.0: resolution: {integrity: sha512-ZwLpbTgdhuZUnZzjd7nb1ZV+4DoiC6/sfiVKok72ym/4Tlf+DFdlHYmT2JPmcNNWV6Pi3SDf1kT+A4r9RTuT9g==} @@ -18207,7 +19588,7 @@ packages: dependencies: hosted-git-info: 2.8.9 resolve: 1.22.2 - semver: 5.7.2 + semver: 5.7.1 validate-npm-package-license: 3.0.4 dev: true @@ -18217,7 +19598,7 @@ packages: dependencies: hosted-git-info: 4.1.0 is-core-module: 2.12.1 - semver: 7.5.4 + semver: 7.5.2 validate-npm-package-license: 3.0.4 dev: true @@ -18243,8 +19624,8 @@ packages: engines: {node: '>=14.16'} dev: true - /notistack@2.0.8(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(@mui/material@5.14.0)(react-dom@18.2.0)(react@18.2.0): - resolution: {integrity: sha512-/IY14wkFp5qjPgKNvAdfL5Jp6q90+MjgKTPh4c81r/lW70KeuX6b9pE/4f8L4FG31cNudbN9siiFS5ql1aSLRw==} + /notistack@2.0.5(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(@mui/material@5.10.3)(react-dom@18.2.0)(react@18.2.0): + resolution: {integrity: sha512-Ig2T1Muqkc1PaSQcEDrK7diKv6cBxw02Iq6uv074ySfgq524TV5lK41diAb6OSsaiWfp3aRt+T3+0MF8m2EcJQ==} peerDependencies: '@emotion/react': ^11.4.1 '@emotion/styled': ^11.3.0 @@ -18257,9 +19638,9 @@ packages: '@emotion/styled': optional: true dependencies: - '@emotion/react': 11.11.1(react@18.2.0) - '@emotion/styled': 11.11.0(@emotion/react@11.11.1)(react@18.2.0) - '@mui/material': 5.14.0(@emotion/react@11.11.1)(@emotion/styled@11.11.0)(react-dom@18.2.0)(react@18.2.0) + '@emotion/react': 11.10.4(@babel/core@7.22.5)(react@18.2.0) + '@emotion/styled': 11.10.4(@babel/core@7.22.5)(@emotion/react@11.10.4)(react@18.2.0) + '@mui/material': 5.10.3(@emotion/react@11.10.4)(@emotion/styled@11.10.4)(react-dom@18.2.0)(react@18.2.0) clsx: 1.2.1 hoist-non-react-statics: 3.3.2 react: 18.2.0 @@ -18278,8 +19659,8 @@ packages: minimatch: 3.1.2 pidtree: 0.3.1 read-pkg: 3.0.0 - shell-quote: 1.8.1 - string.prototype.padend: 3.1.4 + shell-quote: 1.7.4 + string.prototype.padend: 3.1.3 dev: true /npm-run-path@2.0.2: @@ -18322,8 +19703,16 @@ packages: resolution: {integrity: sha512-Y1wZESM7VUThYY+4W+X4ySH2maqcA+p7UR+w8VWNWVAd6lwuXXWz/w/Cz43J/dI2I+PS6wD5N+bJUF+gjWvIqg==} dev: true - /nwsapi@2.2.7: - resolution: {integrity: sha512-ub5E4+FBPKwAZx0UwIQOjYWGHTEq5sPqHQNRN8Z9e4A7u3Tj1weLJsL59yH9vmvqEtBHaOmT6cYQKIZOxp35FQ==} + /nwsapi@2.2.1: + resolution: {integrity: sha512-JYOWTeFoS0Z93587vRJgASD5Ut11fYl5NyihP3KrYBvMe1FRRs6RN7m20SA/16GM4P6hTnZjT+UmDOt38UeXNg==} + dev: true + + /nwsapi@2.2.2: + resolution: {integrity: sha512-90yv+6538zuvUMnN+zCr8LuV6bPFdq50304114vJYJ8RDyK8D5O9Phpbd6SZWgI7PwzmmfN1upeOJlvybDSgCw==} + dev: true + + /nwsapi@2.2.4: + resolution: {integrity: sha512-NHj4rzRo0tQdijE9ZqAx6kYDcoRwYwSYzCA8MY3JzfxlrvEU0jhnhJT9BhqhJs7I/dKcrDm6TyulaRqZPIhN5g==} dev: true /object-assign@4.1.1: @@ -18339,6 +19728,10 @@ packages: kind-of: 3.2.2 dev: true + /object-inspect@1.12.2: + resolution: {integrity: sha512-z+cPxW0QGUp0mcqcsgQyLVRDoXFQbXOwBaqyF7VIgI4TWNQsDHrBpUQslRmIfAoYWdYzs6UlKJtB2XJpTaNSpQ==} + dev: true + /object-inspect@1.12.3: resolution: {integrity: sha512-geUvdk7c+eizMNUDkRpW1wJwgfOiOeHbxBR/hLXK1aT6zmVSO0jsQcs7fj6MGw89jC/cjGfLcNOrtMYtGqm81g==} dev: true @@ -18373,33 +19766,32 @@ packages: object-keys: 1.1.1 dev: true - /object.entries@1.1.6: - resolution: {integrity: sha512-leTPzo4Zvg3pmbQ3rDK69Rl8GQvIqMWubrkxONG9/ojtFE2rD9fjMKfSI5BxW3osRH1m6VdzmqK8oAY9aT4x5w==} + /object.entries@1.1.5: + resolution: {integrity: sha512-TyxmjUoZggd4OrrU1W66FMDG6CuqJxsFvymeyXI51+vQLN67zYfZseptRge703kKQdo4uccgAKebXFcRCzk4+g==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.21.2 + es-abstract: 1.20.4 dev: true - /object.fromentries@2.0.6: - resolution: {integrity: sha512-VciD13dswC4j1Xt5394WR4MzmAQmlgN72phd/riNp9vtD7tp4QQWJ0R4wvclXcafgcYK8veHRed2W6XeGBvcfg==} + /object.fromentries@2.0.5: + resolution: {integrity: sha512-CAyG5mWQRRiBU57Re4FKoTBjXfDoNwdFVH2Y1tS9PqCsfUTymAohOkEMSG3aRNKmv4lV3O7p1et7c187q6bynw==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.21.2 + es-abstract: 1.20.4 dev: true - /object.getownpropertydescriptors@2.1.6: - resolution: {integrity: sha512-lq+61g26E/BgHv0ZTFgRvi7NMEPuAxLkFU7rukXjc/AlwH4Am5xXVnIXy3un1bg/JPbXHrixRkK1itUzzPiIjQ==} + /object.getownpropertydescriptors@2.1.4: + resolution: {integrity: sha512-sccv3L/pMModT6dJAYF3fzGMVcb38ysQ0tEE6ixv2yXJDtEIPph268OlAdJj5/qZMZDq2g/jqvwppt36uS/uQQ==} engines: {node: '>= 0.8'} dependencies: - array.prototype.reduce: 1.0.5 + array.prototype.reduce: 1.0.4 call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.21.2 - safe-array-concat: 1.0.0 + es-abstract: 1.20.4 dev: true /object.pick@1.3.0: @@ -18409,13 +19801,22 @@ packages: isobject: 3.0.1 dev: true + /object.values@1.1.5: + resolution: {integrity: sha512-QUZRW0ilQ3PnPpbNtgdNV1PDbEqLIiSFB3l+EnGtBQ/8SUTLj1PZwtQHABZtLgwpJZTSZhuGLOGk57Drx2IvYg==} + engines: {node: '>= 0.4'} + dependencies: + call-bind: 1.0.2 + define-properties: 1.2.0 + es-abstract: 1.20.4 + dev: true + /object.values@1.1.6: resolution: {integrity: sha512-FVVTkD1vENCsAcwNs9k6jea2uHC/X0+JcjG8YA60FN5CMaJmG95wT9jek/xX9nornqGRrBkKtzuAu2wuHpKqvw==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.21.2 + es-abstract: 1.20.4 dev: true /objectorarray@1.0.5: @@ -18445,10 +19846,10 @@ packages: /ohmyfetch@0.4.21: resolution: {integrity: sha512-VG7f/JRvqvBOYvL0tHyEIEG7XHWm7OqIfAs6/HqwWwDfjiJ1g0huIpe5sFEmyb+7hpFa1EGNH2aERWR72tlClw==} dependencies: - destr: 1.2.2 + destr: 1.2.0 node-fetch-native: 0.1.8 ufo: 0.8.6 - undici: 5.22.1 + undici: 5.12.0 dev: true /on-exit-leak-free@2.1.0: @@ -18494,8 +19895,8 @@ packages: is-wsl: 2.2.0 dev: true - /open@8.4.2: - resolution: {integrity: sha512-7x81NCL719oNbsq/3mh+hVrAWmFuEYUqrq/Iw3kUzH8ReypT9QQ0BLoJS7/G9k6N81XjW4qHWtjWwe/9eLy1EQ==} + /open@8.4.0: + resolution: {integrity: sha512-XgFPPM+B28FtCCgSb9I+s9szOC1vZRSwgWsRUA5ylIxRTgKozqjOCrVOqGsYABPYK5qnfqClxZTFBa8PKt2v6Q==} engines: {node: '>=12'} dependencies: define-lazy-prop: 2.0.0 @@ -18503,13 +19904,37 @@ packages: is-wsl: 2.2.0 dev: true - /optimism@0.16.2: - resolution: {integrity: sha512-zWNbgWj+3vLEjZNIh/okkY2EUfX+vB9TJopzIZwT1xxaMqC5hRLLraePod4c5n4He08xuXNH+zhKFFCu390wiQ==} + /optimism@0.16.1: + resolution: {integrity: sha512-64i+Uw3otrndfq5kaoGNoY7pvOhSsjFEN4bdEFh80MWVk/dbgJfMv7VFDeCT8LxNAlEVhQmdVEbfE7X2nWNIIg==} dependencies: - '@wry/context': 0.7.3 + '@wry/context': 0.6.1 '@wry/trie': 0.3.2 dev: false + /optionator@0.8.3: + resolution: {integrity: sha512-+IW9pACdk3XWmmTXG8m3upGUJst5XRGzxMRjXzAuJ1XnIFNvfhjjIuYkDvysnPQ7qzqVzLt78BCruntqRhWQbA==} + engines: {node: '>= 0.8.0'} + dependencies: + deep-is: 0.1.4 + fast-levenshtein: 2.0.6 + levn: 0.3.0 + prelude-ls: 1.1.2 + type-check: 0.3.2 + word-wrap: 1.2.3 + dev: true + + /optionator@0.9.1: + resolution: {integrity: sha512-74RlY5FCnhq4jRxVUPKDaRwrVNXMqsGsiW6AJw4XK8hmtm10wC0ypZBLw5IIp85NZMr91+qd1RvvENwg7jjRFw==} + engines: {node: '>= 0.8.0'} + dependencies: + deep-is: 0.1.4 + fast-levenshtein: 2.0.6 + levn: 0.4.1 + prelude-ls: 1.2.1 + type-check: 0.4.0 + word-wrap: 1.2.3 + dev: true + /optionator@0.9.3: resolution: {integrity: sha512-JjCoypp+jKn1ttEFExxhetCKeJt9zhAgAve5FXHixTvFDW/5aEktX9bufBKLRRMdU7bNtpLfcGu94B3cdEJgjg==} engines: {node: '>= 0.8.0'} @@ -18529,7 +19954,7 @@ packages: bl: 4.1.0 chalk: 4.1.2 cli-cursor: 3.1.0 - cli-spinners: 2.9.0 + cli-spinners: 2.7.0 is-interactive: 1.0.0 is-unicode-supported: 0.1.0 log-symbols: 4.1.0 @@ -18556,6 +19981,10 @@ packages: resolution: {integrity: sha512-o6E5qJV5zkAbIDNhGSIlyOhScKXgQrSRMilfph0clDfM0nEnBOlKlH4sWDmG95BW/CvwNz0vmm7dJVtU2KlMiA==} dev: true + /outvariant@1.3.0: + resolution: {integrity: sha512-yeWM9k6UPfG/nzxdaPlJkB2p08hCg4xP6Lx99F+vP8YF7xyZVfTmJjrrNalkmzudD4WFvNLVudQikqUmF8zhVQ==} + dev: true + /outvariant@1.4.0: resolution: {integrity: sha512-AlWY719RF02ujitly7Kk/0QlV+pXGFDHrHf9O2OKqyqgBieaPOIeuSkL8sRK6j2WK+/ZAURq2kZsY0d8JapUiw==} dev: true @@ -18687,16 +20116,16 @@ packages: /parallel-transform@1.2.0: resolution: {integrity: sha512-P2vSmIu38uIlvdcU7fDkyrxj33gTUy/ABO5ZUbGowxNCopBq/OoD42bP4UmMrJoPyk4Uqf0mu3mtWBhHCZD8yg==} dependencies: - cyclist: 1.0.2 + cyclist: 1.0.1 inherits: 2.0.4 - readable-stream: 2.3.8 + readable-stream: 2.3.7 dev: true /param-case@3.0.4: resolution: {integrity: sha512-RXlj7zCYokReqWpOPH9oYivUzLYZ5vAPIfEmCTNViosC78F8F0H9y7T7gG2M39ymgutxF5gcFEsyZQSph9Bp3A==} dependencies: dot-case: 3.0.4 - tslib: 2.6.0 + tslib: 2.5.3 dev: true /parent-module@1.0.1: @@ -18767,6 +20196,18 @@ packages: resolution: {integrity: sha512-Ofn/CTFzRGTTxwpNEs9PP93gXShHcTq255nzRYSKe8AkVpZY7e1fpmTfOyoIvjP5HG7Z2ZM7VS9PPhQGW2pOpw==} dev: true + /parse5@7.0.0: + resolution: {integrity: sha512-y/t8IXSPWTuRZqXc0ajH/UwDj4mnqLEbSttNbThcFhGrZuOyoyvNBO85PBp2jQa55wY9d07PBNjsK8ZP3K5U6g==} + dependencies: + entities: 4.5.0 + dev: true + + /parse5@7.1.1: + resolution: {integrity: sha512-kwpuwzB+px5WUg9pyK0IcK/shltJN5/OVhQagxhCQNtT9Y9QRZqNY2e1cmbu/paRh5LMnz/oVTVLBpjFmMZhSg==} + dependencies: + entities: 4.5.0 + dev: true + /parse5@7.1.2: resolution: {integrity: sha512-Czj1WaSVpaoj0wbhMzLmWD69anp2WH7FXMB9n1Sy8/ZFF9jolSQVMu1Ij5WIyGmcBmhk7EOndpO4mIpihVqAXw==} dependencies: @@ -18782,7 +20223,7 @@ packages: resolution: {integrity: sha512-uWlGT3YSnK9x3BQJaOdcZwrnV6hPpd8jFH1/ucpiLRPh/2zCVJKS19E4GvYHvaCcACn3foXZ0cLB9Wrx1KGe5g==} dependencies: no-case: 3.0.4 - tslib: 2.6.0 + tslib: 2.5.3 dev: true /pascalcase@0.1.1: @@ -18843,12 +20284,12 @@ packages: /path-parse@1.0.7: resolution: {integrity: sha512-LDJzPVEEEPR+y48z93A0Ed0yXb8pAByGWo/k5YYdYgpY2/2EsOsksJrq7lOHxryrVOn1ejG6oAp8ahvOIQD8sw==} - /path-scurry@1.10.1: - resolution: {integrity: sha512-MkhCqzzBEpPvxxQ71Md0b1Kk51W01lrYvlMzSUaIzNsODdd7mqhiimSZlr+VegAz5Z6Vzt9Xg2ttE//XBhH3EQ==} + /path-scurry@1.7.0: + resolution: {integrity: sha512-UkZUeDjczjYRE495+9thsgcVgsaCPkaw80slmfVFgllxY+IO8ubTsOpFVjDPROBqJdHfVPUFRHPBV/WciOVfWg==} engines: {node: '>=16 || 14 >=14.17'} dependencies: - lru-cache: 10.0.0 - minipass: 7.0.2 + lru-cache: 9.1.1 + minipass: 5.0.0 dev: true /path-to-regexp@0.1.7: @@ -18863,7 +20304,7 @@ packages: resolution: {integrity: sha512-S4eENJz1pkiQn9Znv33Q+deTOKmbl+jj1Fl+qiP/vYezj+S8x+J3Uo0ISrx/QoEvIlOaDWJhPaRd1flJ9HXZqg==} engines: {node: '>=0.10.0'} dependencies: - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 pify: 2.3.0 pinkie-promise: 2.0.1 dev: true @@ -18884,6 +20325,10 @@ packages: resolution: {integrity: sha512-6Y6s0vT112P3jD8dGfuS6r+lpa0qqNrLyHPOwvXMnyNTQaYiwgau2DP3aNDsR13xqtGj7rrPo+jFUATpU6/s+g==} dev: true + /pathe@1.1.0: + resolution: {integrity: sha512-ODbEPR0KKHqECXW1GoxdDb+AZvULmXjVPy4rt+pGo2+TnjJTIPJQSVS6N63n8T2Ip+syHhbn52OewKicV0373w==} + dev: true + /pathe@1.1.1: resolution: {integrity: sha512-d+RQGp0MAYTIaDBIMmOfMwz3E+LOZnxx1HZd5R18mmCZY0QBlK0LDZfPc8FW8Ed2DlvsuE6PRjroDY+wg4+j/Q==} @@ -18906,6 +20351,10 @@ packages: resolution: {integrity: sha512-F3asv42UuXchdzt+xXqfW1OGlVBe+mxa2mqI0pg5yAHZPvFmY3Y6drSf/GQ1A86WgWEN9Kzh/WrgKa6iGcHXLg==} dev: true + /perfect-debounce@0.1.3: + resolution: {integrity: sha512-NOT9AcKiDGpnV/HBhI22Str++XWcErO/bALvHCuhv33owZW/CjH8KAFLZDCmu3727sihe0wTxpDhyGc6M8qacQ==} + dev: true + /perfect-debounce@1.0.0: resolution: {integrity: sha512-xCy9V055GLEqoFaHoC1SoLIaLmWctgCUaBaWxDZ7/Zx4CTyX7cJQLJOok/orfjZAh9kEYpjJa4d0KcJmCbctZA==} dev: true @@ -18977,33 +20426,33 @@ packages: /pino-abstract-transport@1.0.0: resolution: {integrity: sha512-c7vo5OpW4wIS42hUVcT5REsL8ZljsUfBjqV/e2sFxmFEFZiq1XLUp5EYLtuDH6PEHq9W1egWqRbnLUP5FuZmOA==} dependencies: - readable-stream: 4.4.2 - split2: 4.2.0 + readable-stream: 4.1.0 + split2: 4.1.0 dev: true - /pino-std-serializers@6.2.2: - resolution: {integrity: sha512-cHjPPsE+vhj/tnhCy/wiMh3M3z3h/j15zHQX+S9GkTBgqJuTuJzYJ4gUyACLhDaJ7kk9ba9iRDmbH2tJU03OiA==} + /pino-std-serializers@6.0.0: + resolution: {integrity: sha512-mMMOwSKrmyl+Y12Ri2xhH1lbzQxwwpuru9VjyJpgFIH4asSj88F2csdMwN6+M5g1Ll4rmsYghHLQJw81tgZ7LQ==} dev: true - /pino@8.14.1: - resolution: {integrity: sha512-8LYNv7BKWXSfS+k6oEc6occy5La+q2sPwU3q2ljTX5AZk7v+5kND2o5W794FyRaqha6DJajmkNRsWtPpFyMUdw==} + /pino@8.5.0: + resolution: {integrity: sha512-PuD6sOti8Y+p9zRoNB5dibmfjfM/OU2tEtJFICxw5ulXi1d0qnq/Rt3CsR6aBEAOeyCXP+ZUfiNWW+tt55pNzg==} hasBin: true dependencies: atomic-sleep: 1.0.0 - fast-redact: 3.2.0 + fast-redact: 3.1.2 on-exit-leak-free: 2.1.0 pino-abstract-transport: 1.0.0 - pino-std-serializers: 6.2.2 - process-warning: 2.2.0 + pino-std-serializers: 6.0.0 + process-warning: 2.0.0 quick-format-unescaped: 4.0.4 real-require: 0.2.0 - safe-stable-stringify: 2.4.3 - sonic-boom: 3.3.0 - thread-stream: 2.3.0 + safe-stable-stringify: 2.3.1 + sonic-boom: 3.2.0 + thread-stream: 2.1.0 dev: true - /pirates@4.0.6: - resolution: {integrity: sha512-saLsH7WeYYPiD25LDuLRRY/i+6HaPYr6G1OUlN39otzkSTxKnubR9RTxS3/Kk50s1g2JTgFwWQDQyplC5/SHZg==} + /pirates@4.0.5: + resolution: {integrity: sha512-8V9+HQPupnaXMA23c5hvl69zXvTwTzyAYasnkb0Tts4XvO4CliqONMOnvlq26rkhLC3nWDFBJf73LU1e1VZLaQ==} engines: {node: '>= 6'} dev: true @@ -19042,28 +20491,49 @@ packages: mlly: 1.4.0 pathe: 1.1.1 - /playwright-chromium@1.36.0: - resolution: {integrity: sha512-AU4/euzKqiIeK7JMsxMlgVx3jRFOnXF0vkptF9mfqeNSETVYCbovZ9EpwJ3Kzm/vVAmIlpHp+VoXdX2bi+05Zg==} - engines: {node: '>=16'} + /playwright-chromium@1.30.0: + resolution: {integrity: sha512-ZfqjYdFuxnZxK02mDZtHFK/Mi0+cjCVn51RmwLwLLHA8PkCExk0odmZH2REx+LjqX8tDLGnmf6vDnPAirdSY0g==} + engines: {node: '>=14'} hasBin: true requiresBuild: true dependencies: - playwright-core: 1.36.0 + playwright-core: 1.30.0 dev: true - /playwright-core@1.36.0: - resolution: {integrity: sha512-7RTr8P6YJPAqB+8j5ATGHqD6LvLLM39sYVNsslh78g8QeLcBs5750c6+msjrHUwwGt+kEbczBj1XB22WMwn+WA==} + /playwright-core@1.28.0: + resolution: {integrity: sha512-nJLknd28kPBiCNTbqpu6Wmkrh63OEqJSFw9xOfL9qxfNwody7h6/L3O2dZoWQ6Oxcm0VOHjWmGiCUGkc0X3VZA==} + engines: {node: '>=14'} + hasBin: true + dev: true + + /playwright-core@1.30.0: + resolution: {integrity: sha512-7AnRmTCf+GVYhHbLJsGUtskWTE33SwMZkybJ0v6rqR1boxq2x36U7p1vDRV7HO2IwTZgmycracLxPEJI49wu4g==} + engines: {node: '>=14'} + hasBin: true + dev: true + + /playwright-core@1.35.1: + resolution: {integrity: sha512-pNXb6CQ7OqmGDRspEjlxE49w+4YtR6a3X6mT1hZXeJHWmsEz7SunmvZeiG/+y1yyMZdHnnn73WKYdtV1er0Xyg==} engines: {node: '>=16'} hasBin: true dev: true - /playwright@1.36.0: - resolution: {integrity: sha512-ODVOTp5WoRMxDJY3liMmC+wVNicc0cQB17gASvQ+zLBggVK9a2x3gdT5mbl7av+zomvtdirWOqqfD+O6qIrFgw==} + /playwright@1.28.0: + resolution: {integrity: sha512-kyOXGc5y1mgi+hgEcCIyE1P1+JumLrxS09nFHo5sdJNzrucxPRAGwM4A2X3u3SDOfdgJqx61yIoR6Av+5plJPg==} + engines: {node: '>=14'} + hasBin: true + requiresBuild: true + dependencies: + playwright-core: 1.28.0 + dev: true + + /playwright@1.35.1: + resolution: {integrity: sha512-NbwBeGJLu5m7VGM0+xtlmLAH9VUfWwYOhUi/lSEDyGg46r1CA9RWlvoc5yywxR9AzQb0mOCm7bWtOXV7/w43ZA==} engines: {node: '>=16'} hasBin: true requiresBuild: true dependencies: - playwright-core: 1.36.0 + playwright-core: 1.35.1 dev: true /pluralize@8.0.0: @@ -19081,11 +20551,11 @@ packages: engines: {node: '>=12.13.0'} dev: true - /pnp-webpack-plugin@1.6.4(typescript@4.9.5): + /pnp-webpack-plugin@1.6.4(typescript@4.8.4): resolution: {integrity: sha512-7Wjy+9E3WwLOEL30D+m8TSTF7qJJUJLONBnwQp0518siuMxUQUbgZwssaFX+QKlZkjHZcw/IpZCt/H0srrntSg==} engines: {node: '>=6'} dependencies: - ts-pnp: 1.2.0(typescript@4.9.5) + ts-pnp: 1.2.0(typescript@4.8.4) transitivePeerDependencies: - typescript dev: true @@ -19100,7 +20570,7 @@ packages: resolution: {integrity: sha512-Sz2Lkdxz6F2Pgnpi9U5Ng/WdWAUZxmHrNPoVlm3aAemxoy2Qy7LGjQg4uf8qKelDAUW94F4np3iH2YPf2qefcQ==} engines: {node: '>=10'} dependencies: - '@babel/runtime': 7.22.6 + '@babel/runtime': 7.18.9 dev: true /posix-character-classes@0.1.1: @@ -19138,12 +20608,12 @@ packages: postcss: ^7.0.0 || ^8.0.1 webpack: ^4.0.0 || ^5.0.0 dependencies: - cosmiconfig: 7.1.0 - klona: 2.0.6 - loader-utils: 2.0.4 + cosmiconfig: 7.0.1 + klona: 2.0.5 + loader-utils: 2.0.2 postcss: 7.0.39 - schema-utils: 3.3.0 - semver: 7.5.4 + schema-utils: 3.1.1 + semver: 7.5.2 webpack: 4.46.0 dev: true @@ -19160,7 +20630,7 @@ packages: dependencies: icss-utils: 4.1.1 postcss: 7.0.39 - postcss-selector-parser: 6.0.13 + postcss-selector-parser: 6.0.10 postcss-value-parser: 4.2.0 dev: true @@ -19169,7 +20639,7 @@ packages: engines: {node: '>= 6'} dependencies: postcss: 7.0.39 - postcss-selector-parser: 6.0.13 + postcss-selector-parser: 6.0.10 dev: true /postcss-modules-values@3.0.0: @@ -19179,8 +20649,8 @@ packages: postcss: 7.0.39 dev: true - /postcss-selector-parser@6.0.13: - resolution: {integrity: sha512-EaV1Gl4mUEV4ddhDnv/xtj7sxwrwxdetHdWUGnT4VJQf+4d05v6lHYZr8N573k5Z0BViss7BDhfWtKS3+sfAqQ==} + /postcss-selector-parser@6.0.10: + resolution: {integrity: sha512-IQ7TZdoaqbT+LCpShg46jnZVlhWD2w6iQYAcYXfHARZ7X1t/UGhhceQDs5X0cGqKvYlHNOuv7Oa1xmb0oQuA3w==} engines: {node: '>=4'} dependencies: cssesc: 3.0.0 @@ -19203,8 +20673,8 @@ packages: source-map: 0.6.1 dev: true - /postcss@8.4.25: - resolution: {integrity: sha512-7taJ/8t2av0Z+sQEvNzCkpDynl0tX3uJMCODi6nT3PfASC7dYCWV9aQ+uiCf+KBD4SEFcu+GvJdGdwzQ6OSjCw==} + /postcss@8.4.24: + resolution: {integrity: sha512-M0RzbcI0sO/XJNucsGjvWU9ERWxb/ytp1w6dKtxTKgixdtQDq4rmx/g8W1hnaheq9jgwL/oyEdH5Bc4WwJKMqg==} engines: {node: ^10 || ^12 || >=14} dependencies: nanoid: 3.3.6 @@ -19220,8 +20690,8 @@ packages: source-map-js: 1.0.2 dev: false - /preact@10.16.0: - resolution: {integrity: sha512-XTSj3dJ4roKIC93pald6rWuB2qQJO9gO2iLLyTe87MrjQN+HklueLsmskbywEWqCHlclgz3/M4YLL2iBr9UmMA==} + /preact@10.10.6: + resolution: {integrity: sha512-w0mCL5vICUAZrh1DuHEdOWBjxdO62lvcO++jbzr8UhhYcTbFkpegLH9XX+7MadjTl/y0feoqwQ/zAnzkc/EGog==} dev: true /prebuild-install@7.1.1: @@ -19243,19 +20713,24 @@ packages: tunnel-agent: 0.6.0 dev: true + /prelude-ls@1.1.2: + resolution: {integrity: sha512-ESF23V4SKG6lVSGZgYNpbsiaAkdab6ZgOxe52p7+Kid3W3u3bxR4Vfd/o21dmN7jSt0IwgZ4v5MUd26FEtXE9w==} + engines: {node: '>= 0.8.0'} + dev: true + /prelude-ls@1.2.1: resolution: {integrity: sha512-vkcDPrRZo1QZLbn5RLGPpg/WmIQ65qoWWhcGKf/b5eplkkarX0m9z8ppCat4mlOqUsWpyNuYgO3VRyrYHSzX5g==} engines: {node: '>= 0.8.0'} dev: true - /prettier-plugin-svelte@2.10.1(prettier@2.8.8)(svelte@3.59.2): + /prettier-plugin-svelte@2.10.1(prettier@2.8.8)(svelte@3.59.1): resolution: {integrity: sha512-Wlq7Z5v2ueCubWo0TZzKc9XHcm7TDxqcuzRuGd0gcENfzfT4JZ9yDlCbEgxWgiPmLHkBjfOtpAWkcT28MCDpUQ==} peerDependencies: prettier: ^1.16.4 || ^2.0.0 svelte: ^3.2.0 || ^4.0.0-next.0 dependencies: prettier: 2.8.8 - svelte: 3.59.2 + svelte: 3.59.1 dev: true /prettier@2.3.0: @@ -19264,6 +20739,12 @@ packages: hasBin: true dev: true + /prettier@2.7.1: + resolution: {integrity: sha512-ujppO+MkdPqoVINuDFDRLClm7D78qbDt0/NR+wp5FqEZOoTNAjPHWj17QRhu7geIHJfcNhRk1XVQmF8Bp3ye+g==} + engines: {node: '>=10.13.0'} + hasBin: true + dev: true + /prettier@2.8.8: resolution: {integrity: sha512-tdN8qQGvNjw4CHbY+XXk0JgCXn9QiF21a55rBe5LJAU+kDyC4WQn4+awm2Xfk2lQMk5fKup9XgzTZtGkjBdP9Q==} engines: {node: '>=10.13.0'} @@ -19275,8 +20756,8 @@ packages: engines: {node: '>=6'} dev: true - /pretty-bytes@6.1.0: - resolution: {integrity: sha512-Rk753HI8f4uivXi4ZCIYdhmG1V+WKzvRMg/X+M42a6t7D07RcmopXJMDNk6N++7Bl75URRGsb40ruvg7Hcp2wQ==} + /pretty-bytes@6.0.0: + resolution: {integrity: sha512-6UqkYefdogmzqAZWzJ7laYeJnaXDy2/J+ZqiiMtS7t7OfpXWTlaeGMwX8U6EFvPV/YWWEKRkS8hKS4k60WHTOg==} engines: {node: ^14.13.1 || >=16.0.0} dev: true @@ -19296,11 +20777,11 @@ packages: react-is: 17.0.2 dev: true - /pretty-format@29.6.1: - resolution: {integrity: sha512-7jRj+yXO0W7e4/tSJKoR7HRIHLPPjtNaUGG2xxKQnGvPNRkgWcQ0AZX6P4KBRJN4FcTBWb3sa7DVUJmocYuoog==} + /pretty-format@29.5.0: + resolution: {integrity: sha512-V2mGkI31qdttvTFX7Mt4efOqHXqJWMu4/r66Xh3Z3BwZaPfPJgp6/gbwoujRpPUtfEF6AUUWx3Jim3GCw5g/Qw==} engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: - '@jest/schemas': 29.6.0 + '@jest/schemas': 29.4.3 ansi-styles: 5.2.0 react-is: 18.2.0 @@ -19315,15 +20796,15 @@ packages: dependencies: condense-newlines: 0.2.1 extend-shallow: 2.0.1 - js-beautify: 1.14.8 + js-beautify: 1.14.6 dev: true /process-nextick-args@2.0.1: resolution: {integrity: sha512-3ouUOpQhtgrbOa17J7+uxOTpITYWaGP7/AhoR3+A+/1e9skrzelGi/dXzEYyvbxubEF6Wn2ypscTKiKJFFn1ag==} dev: true - /process-warning@2.2.0: - resolution: {integrity: sha512-/1WZ8+VQjR6avWOgHeEPd7SDQmFQ1B5mC1eRXsCm5TarlNmx/wCsa5GEaxGm05BORRtyG/Ex/3xq3TuRvq57qg==} + /process-warning@2.0.0: + resolution: {integrity: sha512-+MmoAXoUX+VTHAlwns0h+kFUWFs/3FZy+ZuchkgjyOu3oioLAo2LB5aCfKPh2+P9O18i3m43tUEv3YqttSy0Ww==} dev: true /process@0.11.10: @@ -19347,25 +20828,25 @@ packages: bluebird: 3.7.2 dev: true - /promise.allsettled@1.0.6: - resolution: {integrity: sha512-22wJUOD3zswWFqgwjNHa1965LvqTX87WPu/lreY2KSd7SVcERfuZ4GfUaOnJNnvtoIv2yXT/W00YIGMetXtFXg==} + /promise.allsettled@1.0.5: + resolution: {integrity: sha512-tVDqeZPoBC0SlzJHzWGZ2NKAguVq2oiYj7gbggbiTvH2itHohijTp7njOUA0aQ/nl+0lr/r6egmhoYu63UZ/pQ==} engines: {node: '>= 0.4'} dependencies: - array.prototype.map: 1.0.5 + array.prototype.map: 1.0.4 call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.21.2 - get-intrinsic: 1.2.1 + es-abstract: 1.20.4 + get-intrinsic: 1.2.0 iterate-value: 1.0.2 dev: true - /promise.prototype.finally@3.1.4: - resolution: {integrity: sha512-nNc3YbgMfLzqtqvO/q5DP6RR0SiHI9pUPGzyDf1q+usTwCN2kjvAnJkBb7bHe3o+fFSBPpsGMoYtaSi+LTNqng==} + /promise.prototype.finally@3.1.3: + resolution: {integrity: sha512-EXRF3fC9/0gz4qkt/f5EP5iW4kj9oFpBICNpCNOb/52+8nlHIX07FPLbi/q4qYBQ1xZqivMzTpNQSnArVASolQ==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.21.2 + es-abstract: 1.20.4 dev: true /prompts@2.4.2: @@ -19454,6 +20935,10 @@ packages: pump: 2.0.1 dev: true + /punycode@1.3.2: + resolution: {integrity: sha512-RofWgt/7fL5wP1Y7fxE7/EmTLzQVnB0ycyibJ0OOHIlJqTNzglYFxVwETOcIoJqJmpDXJ9xImDv+Fq34F/d4Dw==} + dev: true + /punycode@1.4.1: resolution: {integrity: sha512-jmYNElW7yvO7TV33CjSmvSiE2yco3bV2czu/OzDKdMNVZQWfxCblURLhf+47syQRBntjfLdd/H0egrzIG+oaFQ==} dev: true @@ -19489,7 +20974,6 @@ packages: /puppeteer@13.7.0: resolution: {integrity: sha512-U1uufzBjz3+PkpCxFrWzh4OrMIdIb2ztzCu0YEPfRHjHswcSwHZswnK+WdsOQJsRV8WeTg3jLhJR4D867+fjsA==} engines: {node: '>=10.18.1'} - deprecated: < 19.4.0 is no longer supported requiresBuild: true dependencies: cross-fetch: 3.1.5 @@ -19511,8 +20995,8 @@ packages: - utf-8-validate dev: true - /qs@6.10.4: - resolution: {integrity: sha512-OQiU+C+Ds5qiH91qh/mg0w+8nwQuLjM4F4M/PbmhDOoYehPh+Fb0bDjtR1sOvy7YKxvj28Y/M0PhP5uVX0kB+g==} + /qs@6.10.3: + resolution: {integrity: sha512-wr7M2E0OFRfIfJZjKGieI8lBKb7fRCH4Fv5KNPEs7gJ8jadvotdsS08PzOKR7opXhZ/Xkjtt3WF9g38drmyRqQ==} engines: {node: '>=0.6'} dependencies: side-channel: 1.0.4 @@ -19525,11 +21009,14 @@ packages: side-channel: 1.0.4 dev: true - /qs@6.11.2: - resolution: {integrity: sha512-tDNIz22aBzCDxLtVH++VnTfzxlfeK5CbqohpSqpJgj1Wg/cQbStNAz3NuqCs5vV+pjBsK4x4pN9HlVh7rcYRiA==} + /qs@6.5.3: + resolution: {integrity: sha512-qxXIEh4pCGfHICj1mAJQ2/2XVZkjCDTcEgfoSQxc/fYivUZxTkk7L3bDBJSoNrEzXI17oUO5Dp07ktqE5KzczA==} + engines: {node: '>=0.6'} + dev: true + + /qs@6.9.3: + resolution: {integrity: sha512-EbZYNarm6138UKKq46tdx08Yo/q9ZhFoAXAI1meAFd2GtbRDhbZY2WQSICskT0c5q99aFzLG1D4nvTk9tqfXIw==} engines: {node: '>=0.6'} - dependencies: - side-channel: 1.0.4 dev: true /query-selector-shadow-dom@1.0.1: @@ -19541,6 +21028,12 @@ packages: engines: {node: '>=0.4.x'} dev: true + /querystring@0.2.0: + resolution: {integrity: sha512-X/xY82scca2tau62i9mDyU9K+I+djTMUsvwf7xnUX5GLvVzgJybOJf4Y6o9Zx3oJK/LSXg5tTZBjwzqVPaPO2g==} + engines: {node: '>=0.4.x'} + deprecated: The querystring API is considered Legacy. new code should use the URLSearchParams API instead. + dev: true + /querystringify@2.2.0: resolution: {integrity: sha512-FIqgj2EUvTa7R50u0rGsyTftzjYmv/a3hO345bZNrqabNqjtgiDMgmo4mkUjd+nzU5oF3dClKqFIPUKybUyqoQ==} dev: true @@ -19548,10 +21041,6 @@ packages: /queue-microtask@1.2.3: resolution: {integrity: sha512-NuaNSa6flKT5JaSYQzJok04JzTL1CA6aGhv5rfLW3PgqA+M2ChpZQnAC8h8i4ZFkBS8X5RqkDBHA7r4hej3K9A==} - /queue-tick@1.0.1: - resolution: {integrity: sha512-kJt5qhMxoszgU/62PLP1CJytzd2NKetjSRnyuj31fDd3Rlcz3fzlFdFLD1SItunPwyqEOkca6GbV612BWfaBag==} - dev: true - /quick-format-unescaped@4.0.4: resolution: {integrity: sha512-tYC1Q1hgyRuHgloV/YXs2w15unPVh8qfu/qCTfhTYamaw7fyhumKa2yGpdSo87vY32rIclj+4fWYQXUMs9EHvg==} dev: true @@ -19575,10 +21064,6 @@ packages: resolution: {integrity: sha512-9QnLuG/kPVgWvMQ4aODhsBUFKOUmnbUnsSXACv+NCQZcHbeb+v8Lodp8OVxtRULN1/xOyYLLaL6npE6dMq5QTA==} dev: true - /ramda@0.29.0: - resolution: {integrity: sha512-BBea6L67bYLtdbOqfp8f58fPMqEwx0doL+pAi8TZyp2YWz8R9G8z9x75CZI8W+ftqhFHCpEX2cRnUUXK130iKA==} - dev: true - /randexp@0.4.6: resolution: {integrity: sha512-80WNmd9DA0tmZrw9qQa62GPPWfuXJknrmVmLcxvq4uZBdYqb1wYoKTmnlGUchvVWe0XiLupYkBoXVOxz3C8DYQ==} engines: {node: '>=0.12'} @@ -19621,16 +21106,16 @@ packages: peerDependencies: webpack: ^4.0.0 || ^5.0.0 dependencies: - loader-utils: 2.0.4 - schema-utils: 3.3.0 + loader-utils: 2.0.2 + schema-utils: 3.1.1 webpack: 4.46.0 dev: true - /rc9@2.1.1: - resolution: {integrity: sha512-lNeOl38Ws0eNxpO3+wD1I9rkHGQyj1NU1jlzv4go2CtEnEQEUfqnIvZG7W+bC/aXdJ27n5x/yUjb6RoT9tko+Q==} + /rc9@2.1.0: + resolution: {integrity: sha512-ROO9bv8PPqngWKoiUZU3JDQ4sugpdRs9DfwHnzDSxK25XtQn6BEHL6EOd/OtKuDT2qodrtNR+0WkPT6l0jxH5Q==} dependencies: defu: 6.1.2 - destr: 2.0.0 + destr: 1.2.2 flat: 5.0.2 dev: true @@ -19644,12 +21129,12 @@ packages: strip-json-comments: 2.0.1 dev: true - /react-docgen-typescript@2.2.2(typescript@4.9.5): + /react-docgen-typescript@2.2.2(typescript@4.8.4): resolution: {integrity: sha512-tvg2ZtOpOi6QDwsb3GZhOjDkkX0h8Z2gipvTg6OVMUyoYoURhEiRNePT8NZItTVCDh39JJHnLdfCOkzoLbFnTg==} peerDependencies: typescript: '>= 4.3.x' dependencies: - typescript: 4.9.5 + typescript: 4.8.4 dev: true /react-docgen@5.4.3: @@ -19657,9 +21142,9 @@ packages: engines: {node: '>=8.10.0'} hasBin: true dependencies: - '@babel/core': 7.22.8 - '@babel/generator': 7.22.7 - '@babel/runtime': 7.22.6 + '@babel/core': 7.22.5 + '@babel/generator': 7.22.5 + '@babel/runtime': 7.18.9 ast-types: 0.14.2 commander: 2.20.3 doctrine: 3.0.0 @@ -19671,20 +21156,21 @@ packages: - supports-color dev: true - /react-docgen@6.0.1: - resolution: {integrity: sha512-K+EHJrADKJYpmojACrebABRb5e6RvW8cSeJ/0950Km5YnrSglebHeMm/uGSv/DpBvsZOsMGVQoYb8XjCA3r0NQ==} - engines: {node: '>=14.18.0'} + /react-docgen@6.0.0-alpha.3: + resolution: {integrity: sha512-DDLvB5EV9As1/zoUsct6Iz2Cupw9FObEGD3DMcIs3EDFIoSKyz8FZtoWj3Wj+oodrU4/NfidN0BL5yrapIcTSA==} + engines: {node: '>=12.0.0'} + hasBin: true dependencies: - '@babel/core': 7.22.8 - '@babel/traverse': 7.22.8 - '@babel/types': 7.22.5 - '@types/babel__core': 7.20.1 - '@types/babel__traverse': 7.20.1 - '@types/doctrine': 0.0.5 - '@types/resolve': 1.20.2 + '@babel/core': 7.22.5 + '@babel/generator': 7.22.5 + ast-types: 0.14.2 + commander: 2.20.3 doctrine: 3.0.0 + estree-to-babel: 3.2.1 + neo-async: 2.6.2 + node-dir: 0.1.17 resolve: 1.22.2 - strip-indent: 4.0.0 + strip-indent: 3.0.0 transitivePeerDependencies: - supports-color dev: true @@ -19735,7 +21221,7 @@ packages: peerDependencies: react: ^16.8.4 || ^17.0.0 dependencies: - '@babel/runtime': 7.22.6 + '@babel/runtime': 7.18.9 is-dom: 1.1.0 prop-types: 15.8.1 react: 17.0.2 @@ -19755,8 +21241,8 @@ packages: resolution: {integrity: sha512-fBASbA6LnOU9dOU2eW7aQ8xmYBSXUIWr+UmF9b1efZBazGNO+rcXT/icdKnYm2pTwcRylVUYwW7H1PHfLekVzA==} dev: false - /react-query@3.39.3(react-dom@17.0.2)(react@17.0.2): - resolution: {integrity: sha512-nLfLz7GiohKTJDuT4us4X3h/8unOh+00MLb2yJoGTPjxKs2bc1iDhkNx2bd5MKklXnOD3NrVZ+J2UXujA5In4g==} + /react-query@3.39.2(react-dom@17.0.2)(react@17.0.2): + resolution: {integrity: sha512-F6hYDKyNgDQfQOuR1Rsp3VRzJnWHx6aRnnIZHMNGGgbL3SBgpZTDg8MQwmxOgpCAoqZJA+JSNCydF1xGJqKOCA==} peerDependencies: react: ^16.8.0 || ^17.0.0 || ^18.0.0 react-dom: '*' @@ -19767,7 +21253,7 @@ packages: react-native: optional: true dependencies: - '@babel/runtime': 7.22.6 + '@babel/runtime': 7.18.9 broadcast-channel: 3.7.0 match-sorter: 6.3.1 react: 17.0.2 @@ -19789,8 +21275,8 @@ packages: engines: {node: '>=0.10.0'} dev: true - /react-resize-detector@8.1.0(react-dom@18.2.0)(react@18.2.0): - resolution: {integrity: sha512-S7szxlaIuiy5UqLhLL1KY3aoyGHbZzsTpYal9eYMwCyKqoqoVLCmIgAgNyIM1FhnP2KyBygASJxdhejrzjMb+w==} + /react-resize-detector@7.1.2(react-dom@18.2.0)(react@18.2.0): + resolution: {integrity: sha512-zXnPJ2m8+6oq9Nn8zsep/orts9vQv3elrpA+R8XTcW7DVVUJ9vwDwMXaBtykAYjMnkCIaOoK9vObyR7ZgFNlOw==} peerDependencies: react: ^16.0.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.0.0 || ^17.0.0 || ^18.0.0 @@ -19800,26 +21286,24 @@ packages: react-dom: 18.2.0(react@18.2.0) dev: false - /react-router-dom@6.14.1(react-dom@18.2.0)(react@18.2.0): - resolution: {integrity: sha512-ssF6M5UkQjHK70fgukCJyjlda0Dgono2QGwqGvuk7D+EDGHdacEN3Yke2LTMjkrpHuFwBfDFsEjGVXBDmL+bWw==} - engines: {node: '>=14'} + /react-router-dom@6.3.0(react-dom@18.2.0)(react@18.2.0): + resolution: {integrity: sha512-uaJj7LKytRxZNQV8+RbzJWnJ8K2nPsOOEuX7aQstlMZKQT0164C+X2w6bnkqU3sjtLvpd5ojrezAyfZ1+0sStw==} peerDependencies: react: '>=16.8' react-dom: '>=16.8' dependencies: - '@remix-run/router': 1.7.1 + history: 5.3.0 react: 18.2.0 react-dom: 18.2.0(react@18.2.0) - react-router: 6.14.1(react@18.2.0) + react-router: 6.3.0(react@18.2.0) dev: false - /react-router@6.14.1(react@18.2.0): - resolution: {integrity: sha512-U4PfgvG55LdvbQjg5Y9QRWyVxIdO1LlpYT7x+tMAxd9/vmiPuJhIwdxZuIQLN/9e3O4KFDHYfR9gzGeYMasW8g==} - engines: {node: '>=14'} + /react-router@6.3.0(react@18.2.0): + resolution: {integrity: sha512-7Wh1DzVQ+tlFjkeo+ujvjSqSJmkt1+8JO+T5xklPlgrh70y7ogx75ODRW0ThWhY7S+6yEDks8TYrtQe/aoboBQ==} peerDependencies: react: '>=16.8' dependencies: - '@remix-run/router': 1.7.1 + history: 5.3.0 react: 18.2.0 dev: false @@ -19830,17 +21314,17 @@ packages: dependencies: object-assign: 4.1.1 react: 17.0.2 - react-is: 17.0.2 + react-is: 18.2.0 dev: true - /react-smooth@2.0.3(prop-types@15.8.1)(react-dom@18.2.0)(react@18.2.0): - resolution: {integrity: sha512-yl4y3XiMorss7ayF5QnBiSprig0+qFHui8uh7Hgg46QX5O+aRMRKlfGGNGLHno35JkQSvSYY8eCWkBfHfrSHfg==} + /react-smooth@2.0.1(prop-types@15.8.1)(react-dom@18.2.0)(react@18.2.0): + resolution: {integrity: sha512-Own9TA0GPPf3as4vSwFhDouVfXP15ie/wIHklhyKBH5AN6NFtdk0UpHBnonV11BtqDkAWlt40MOUc+5srmW7NA==} peerDependencies: prop-types: ^15.6.0 react: ^15.0.0 || ^16.0.0 || ^17.0.0 || ^18.0.0 react-dom: ^15.0.0 || ^16.0.0 || ^17.0.0 || ^18.0.0 dependencies: - fast-equals: 5.0.1 + fast-equals: 2.0.4 prop-types: 15.8.1 react: 18.2.0 react-dom: 18.2.0(react@18.2.0) @@ -19879,7 +21363,7 @@ packages: react: '>=16.6.0' react-dom: '>=16.6.0' dependencies: - '@babel/runtime': 7.22.6 + '@babel/runtime': 7.18.9 dom-helpers: 5.2.1 loose-envify: 1.4.0 prop-types: 15.8.1 @@ -19972,8 +21456,8 @@ packages: type-fest: 2.19.0 dev: true - /readable-stream@2.3.8: - resolution: {integrity: sha512-8p0AUk4XODgIewSi0l8Epjs+EVnWiK7NoDIEGU0HhE7+ZyY8D1IMY7odu5lRrFXGg71L15KG8QrPmum45RTtdA==} + /readable-stream@2.3.7: + resolution: {integrity: sha512-Ebho8K4jIbHAxnuxi7o42OrZgF/ZTNcsZj6nRKyUmkhLFq8CHItp/fy6hQZuZmP/n3yZ9VBUbp4zz/mX8hmYPw==} dependencies: core-util-is: 1.0.3 inherits: 2.0.4 @@ -19984,8 +21468,8 @@ packages: util-deprecate: 1.0.2 dev: true - /readable-stream@3.6.2: - resolution: {integrity: sha512-9u/sniCrY3D5WdsERHzHE4G2YCXqoG5FTHUiCC4SIbr6XcLZBY05ya9EKjYek9O5xOAwjGq+1JdGBAS7Q9ScoA==} + /readable-stream@3.6.0: + resolution: {integrity: sha512-BViHy7LKeTz4oNnkcLJ+lVSL6vpiFeX6/d3oSH8zCW7UxP2onchk+vTGB143xuFjHS3deTgkKoXXymXqymiIdA==} engines: {node: '>= 6'} dependencies: inherits: 2.0.4 @@ -19993,30 +21477,26 @@ packages: util-deprecate: 1.0.2 dev: true - /readable-stream@4.4.2: - resolution: {integrity: sha512-Lk/fICSyIhodxy1IDK2HazkeGjSmezAWX2egdtJnYhtzKEsBPJowlI6F6LPb5tqIQILrMbx22S5o3GuJavPusA==} + /readable-stream@4.1.0: + resolution: {integrity: sha512-sVisi3+P2lJ2t0BPbpK629j8wRW06yKGJUcaLAGXPAUhyUxVJm7VsCTit1PFgT4JHUDMrGNR+ZjSKpzGaRF3zw==} engines: {node: ^12.22.0 || ^14.17.0 || >=16.0.0} dependencies: abort-controller: 3.0.0 - buffer: 6.0.3 - events: 3.3.0 - process: 0.11.10 - string_decoder: 1.3.0 dev: true - /readdir-glob@1.1.3: - resolution: {integrity: sha512-v05I2k7xN8zXvPD9N+z/uhXPaj0sUFCe2rcWZIpBsqxfP7xXFQ0tipAd/wjj1YxWyWtUS5IDJpOG82JKt2EAVA==} + /readdir-glob@1.1.2: + resolution: {integrity: sha512-6RLVvwJtVwEDfPdn6X6Ille4/lxGl0ATOY4FN/B9nxQcgOazvvI0nodiD19ScKq0PvA/29VpaOQML36o5IzZWA==} dependencies: - minimatch: 5.1.6 + minimatch: 5.1.1 dev: true /readdirp@2.2.1: resolution: {integrity: sha512-1JU/8q+VgFZyxwrJ+SVIOsh+KywWGpds3NTqikiKpDMZWScmAYyKIgqkO+ARvNWJfXeXR1zxz7aHF4u4CyH6vQ==} engines: {node: '>=0.10'} dependencies: - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 micromatch: 3.1.10 - readable-stream: 2.3.8 + readable-stream: 2.3.7 transitivePeerDependencies: - supports-color dev: true @@ -20040,26 +21520,28 @@ packages: decimal.js-light: 2.5.1 dev: false - /recharts@2.7.2(prop-types@15.8.1)(react-dom@18.2.0)(react@18.2.0): - resolution: {integrity: sha512-HMKRBkGoOXHW+7JcRa6+MukPSifNtJlqbc+JreGVNA407VLE/vOP+8n3YYjprDVVIF9E2ZgwWnL3D7K/LUFzBg==} + /recharts@2.1.13(prop-types@15.8.1)(react-dom@18.2.0)(react@18.2.0): + resolution: {integrity: sha512-9VWu2nzExmfiMFDHKqRFhYlJVmjzQGVKH5rBetXR4EuyEXuu3Y6cVxQuNEdusHhbm4SoPPrVDCwlBdREL3sQPA==} engines: {node: '>=12'} peerDependencies: prop-types: ^15.6.0 react: ^16.0.0 || ^17.0.0 || ^18.0.0 react-dom: ^16.0.0 || ^17.0.0 || ^18.0.0 dependencies: - classnames: 2.3.2 + classnames: 2.3.1 + d3-interpolate: 3.0.1 + d3-scale: 4.0.2 + d3-shape: 3.1.0 eventemitter3: 4.0.7 lodash: 4.17.21 prop-types: 15.8.1 react: 18.2.0 react-dom: 18.2.0(react@18.2.0) react-is: 16.13.1 - react-resize-detector: 8.1.0(react-dom@18.2.0)(react@18.2.0) - react-smooth: 2.0.3(prop-types@15.8.1)(react-dom@18.2.0)(react@18.2.0) + react-resize-detector: 7.1.2(react-dom@18.2.0)(react@18.2.0) + react-smooth: 2.0.1(prop-types@15.8.1)(react-dom@18.2.0)(react@18.2.0) recharts-scale: 0.4.5 reduce-css-calc: 2.1.8 - victory-vendor: 36.6.11 dev: false /redent@1.0.0: @@ -20086,8 +21568,8 @@ packages: postcss-value-parser: 3.3.1 dev: false - /regenerate-unicode-properties@10.1.0: - resolution: {integrity: sha512-d1VudCLoIGitcU/hEg2QqvyGZQmdC0Lf8BqdOMXGFSvJP4bNV1+XqbPQeHHLD51Jh4QJJ225dlIFvY4Ly6MXmQ==} + /regenerate-unicode-properties@10.0.1: + resolution: {integrity: sha512-vn5DU6yg6h8hP/2OkQo3K7uVILvY4iu0oI4t3HFa81UPkhGJwkRwM10JEc3upjdhHjs/k8GJY1sRBhk5sr69Bw==} engines: {node: '>=4'} dependencies: regenerate: 1.4.2 @@ -20100,10 +21582,14 @@ packages: /regenerator-runtime@0.13.11: resolution: {integrity: sha512-kY1AZVr2Ra+t+piVaJ4gxaFaReZVH40AKNo7UCX6W+dEwBo/2oZJzqfuN1qLq1oL45o56cPaTXELwrTh8Fpggg==} - /regenerator-transform@0.15.1: - resolution: {integrity: sha512-knzmNAcuyxV+gQCufkYcvOqX/qIIfHLv0u5x79kRxuGojfYVky1f15TzZEu2Avte8QGepvUNTnLskf8E6X6Vyg==} + /regenerator-runtime@0.13.9: + resolution: {integrity: sha512-p3VT+cOEgxFsRRA9X4lkI1E+k2/CtnKtU4gcxyaCUreilL/vqI6CdZ3wxVUx3UOUg+gnUOQQcRI7BmSI656MYA==} + dev: true + + /regenerator-transform@0.15.0: + resolution: {integrity: sha512-LsrGtPmbYg19bcPHwdtmXwbW+TqNvtY4riE3P83foeHRroMbH6/2ddFBfab3t7kbzc7v7p4wbkIecHImqt0QNg==} dependencies: - '@babel/runtime': 7.22.6 + '@babel/runtime': 7.18.9 dev: true /regex-not@1.0.2: @@ -20114,8 +21600,8 @@ packages: safe-regex: 1.1.0 dev: true - /regexp-tree@0.1.27: - resolution: {integrity: sha512-iETxpjK6YoRWJG5o6hXLwvjYAoW+FEZn9os0PD/b6AP6xQwsa/Y7lCVgIixBbUPMfhu+i2LtdeAqVTgGlQarfA==} + /regexp-tree@0.1.24: + resolution: {integrity: sha512-s2aEVuLhvnVJW6s/iPgEGK6R+/xngd2jNQ+xy4bXNDKxZKJH6jpPHY6kVeVv1IeLCHgswRj+Kl3ELaDjG6V1iw==} hasBin: true dev: true @@ -20133,16 +21619,20 @@ packages: engines: {node: '>=8'} dev: true - /regexpu-core@5.3.2: - resolution: {integrity: sha512-RAM5FlZz+Lhmo7db9L298p2vHP5ZywrVXmVXpmAD9GuL5MPH6t9ROw1iA/wfHkQ76Qe7AaPF0nGuim96/IrQMQ==} + /regexpu-core@5.1.0: + resolution: {integrity: sha512-bb6hk+xWd2PEOkj5It46A16zFMs2mv86Iwpdu94la4S3sJ7C973h2dHpYKwIBGaWSO7cIRJ+UX0IeMaWcO4qwA==} engines: {node: '>=4'} dependencies: - '@babel/regjsgen': 0.8.0 regenerate: 1.4.2 - regenerate-unicode-properties: 10.1.0 - regjsparser: 0.9.1 + regenerate-unicode-properties: 10.0.1 + regjsgen: 0.6.0 + regjsparser: 0.8.4 unicode-match-property-ecmascript: 2.0.0 - unicode-match-property-value-ecmascript: 2.1.0 + unicode-match-property-value-ecmascript: 2.0.0 + dev: true + + /regjsgen@0.6.0: + resolution: {integrity: sha512-ozE883Uigtqj3bx7OhL1KNbCzGyW2NQZPl6Hs09WTvCuZD5sTI4JY58bkbQWa/Y9hxIsvJ3M8Nbf7j54IqeZbA==} dev: true /regjsparser@0.10.0: @@ -20152,8 +21642,8 @@ packages: jsesc: 0.5.0 dev: true - /regjsparser@0.9.1: - resolution: {integrity: sha512-dQUtn90WanSNl+7mQKcXAgZxvUe7Z0SqXlgzv0za4LwiUhyzBC58yQO3liFoUgu8GiJVInAhJjkj1N0EtQ5nkQ==} + /regjsparser@0.8.4: + resolution: {integrity: sha512-J3LABycON/VNEu3abOviqGHuB/LOtOQj8SKmfP9anY5GfAVw/SPjwzSjxGjbZXIxbGfqTHtJw58C2Li/WkStmA==} hasBin: true dependencies: jsesc: 0.5.0 @@ -20217,7 +21707,7 @@ packages: /remark-slug@6.1.0: resolution: {integrity: sha512-oGCxDF9deA8phWvxFuyr3oSJsdyUAxMFbA0mZ7Y1Sas+emILtO+e5WutF9564gDsEN4IXaQXm5pFo6MLH+YmwQ==} dependencies: - github-slugger: 1.5.0 + github-slugger: 1.4.0 mdast-util-to-string: 1.1.0 unist-util-visit: 2.0.3 dev: true @@ -20229,7 +21719,7 @@ packages: dev: true /remove-accents@0.4.2: - resolution: {integrity: sha512-7pXIJqJOq5tFgG1A2Zxti3Ht8jJF337m4sowbuHsW30ZnkQFnDzy9qBNhgzX8ZLW4+UBcXiiR7SwR6pokHsxiA==} + resolution: {integrity: sha1-CkPTqq4egNuRngeuJUsoXZ4ce7U=} dev: false /remove-trailing-separator@1.1.0: @@ -20335,11 +21825,6 @@ packages: supports-preserve-symlinks-flag: 1.0.0 dev: true - /response-iterator@0.2.6: - resolution: {integrity: sha512-pVzEEzrsg23Sh053rmDUvLSkGXluZio0qu8VT6ukrYuvtjVfCbDZH9d6PGXb8HZfzdNZt8feXv/jvUzlhRgLnw==} - engines: {node: '>=0.8'} - dev: false - /responselike@3.0.0: resolution: {integrity: sha512-40yHxbNcl2+rzXvZuVkrYohathsSJlMTXKryG5y8uciHv1+xDLHQpgjG64JUO9nrEq2jGLH6IZ8BcZyw3wrweg==} engines: {node: '>=14.16'} @@ -20417,7 +21902,7 @@ packages: engines: {node: '>=14'} hasBin: true dependencies: - glob: 10.3.3 + glob: 10.2.7 dev: true /ripemd160@2.0.2: @@ -20427,7 +21912,7 @@ packages: inherits: 2.0.4 dev: true - /rollup-plugin-dts@5.3.0(rollup@3.26.2)(typescript@5.1.6): + /rollup-plugin-dts@5.3.0(rollup@3.26.0)(typescript@5.1.6): resolution: {integrity: sha512-8FXp0ZkyZj1iU5klkIJYLjIq/YZSwBoERu33QBDxm/1yw5UU4txrEtcmMkrq+ZiKu3Q4qvPCNqc3ovX6rjqzbQ==} engines: {node: '>=v14'} peerDependencies: @@ -20435,31 +21920,31 @@ packages: typescript: ^4.1 || ^5.0 dependencies: magic-string: 0.30.1 - rollup: 3.26.2 + rollup: 3.26.0 typescript: 5.1.6 optionalDependencies: '@babel/code-frame': 7.22.5 dev: true - /rollup-plugin-esbuild@5.0.0(esbuild@0.18.11)(rollup@3.26.2): + /rollup-plugin-esbuild@5.0.0(esbuild@0.18.11)(rollup@3.26.0): resolution: {integrity: sha512-1cRIOHAPh8WQgdQQyyvFdeOdxuiyk+zB5zJ5+YOwrZP4cJ0MT3Fs48pQxrZeyZHcn+klFherytILVfE4aYrneg==} engines: {node: '>=14.18.0', npm: '>=8.0.0'} peerDependencies: esbuild: '>=0.10.1' rollup: ^1.20.0 || ^2.0.0 || ^3.0.0 dependencies: - '@rollup/pluginutils': 5.0.2(rollup@3.26.2) + '@rollup/pluginutils': 5.0.2(rollup@3.26.0) debug: 4.3.4(supports-color@8.1.1) - es-module-lexer: 1.3.0 + es-module-lexer: 1.1.0 esbuild: 0.18.11 joycon: 3.1.1 jsonc-parser: 3.2.0 - rollup: 3.26.2 + rollup: 3.26.0 transitivePeerDependencies: - supports-color dev: true - /rollup-plugin-license@3.0.1(rollup@3.26.2): + /rollup-plugin-license@3.0.1(rollup@3.26.0): resolution: {integrity: sha512-/lec6Y94Y3wMfTDeYTO/jSXII0GQ/XkDZCiqkMKxyU5D5nGPaxr/2JNYvAgYsoCYuOLGOanKDPjCCQiTT96p7A==} engines: {node: '>=14.0.0'} peerDependencies: @@ -20472,7 +21957,7 @@ packages: mkdirp: 1.0.4 moment: 2.29.4 package-name-regex: 2.0.6 - rollup: 3.26.2 + rollup: 3.26.0 spdx-expression-validate: 2.0.0 spdx-satisfies: 5.0.1 dev: true @@ -20487,7 +21972,7 @@ packages: jest-worker: 26.6.2 rollup: 2.79.1 serialize-javascript: 4.0.0 - terser: 5.19.0 + terser: 5.15.0 dev: true /rollup@2.79.1: @@ -20497,8 +21982,15 @@ packages: optionalDependencies: fsevents: 2.3.2 - /rollup@3.26.2: - resolution: {integrity: sha512-6umBIGVz93er97pMgQO08LuH3m6PUb3jlDUUGFsNJB6VgTCUaDFpupf5JfU30529m/UKOgmiX+uY6Sx8cOYpLA==} + /rollup@3.23.0: + resolution: {integrity: sha512-h31UlwEi7FHihLe1zbk+3Q7z1k/84rb9BSwmBSr/XjOCEaBJ2YyedQDuM0t/kfOS0IxM+vk1/zI9XxYj9V+NJQ==} + engines: {node: '>=14.18.0', npm: '>=8.0.0'} + hasBin: true + optionalDependencies: + fsevents: 2.3.2 + + /rollup@3.26.0: + resolution: {integrity: sha512-YzJH0eunH2hr3knvF3i6IkLO/jTjAEwU4HoMUbQl4//Tnl3ou0e7P5SjxdDr8HQJdeUJShlbEHXrrnEHy1l7Yg==} engines: {node: '>=14.18.0', npm: '>=8.0.0'} hasBin: true optionalDependencies: @@ -20544,7 +22036,7 @@ packages: /rxjs@7.8.1: resolution: {integrity: sha512-AA3TVj+0A2iuIoQkWEK/tqFjBq2j+6PO6Y0zJcvzLAFhEFIO3HL0vls9hWLncZbAAbK0mar7oZ4V079I/qPMxg==} dependencies: - tslib: 2.6.0 + tslib: 2.5.3 dev: true /sade@1.8.1: @@ -20562,23 +22054,12 @@ packages: resolution: {integrity: sha512-997HUPVHdOk0019Yz2qbX/B47bC0LcUxMrHU2PDY8IOO7hiT1uhBQEeEAF1BeCrZKFgx5cmsbWYmFgFN0TfqNA==} dev: true - /safe-array-concat@1.0.0: - resolution: {integrity: sha512-9dVEFruWIsnie89yym+xWTAYASdpw3CJV7Li/6zBewGf9z2i1j31rP6jnY0pHEO4QZh6N0K11bFjWmdR8UGdPQ==} - engines: {node: '>=0.4'} - dependencies: - call-bind: 1.0.2 - get-intrinsic: 1.2.1 - has-symbols: 1.0.3 - isarray: 2.0.5 - dev: true - /safe-buffer@5.1.1: resolution: {integrity: sha512-kKvNJn6Mm93gAczWVJg7wH+wGYWNrDHdWvpUmHyEsgCtIwwo3bqPtV4tR5tuPaUhTOo/kvhVwd8XwwOllGYkbg==} dev: true /safe-buffer@5.1.2: resolution: {integrity: sha512-Gd2UZBJDkXlY7GbJxfsE8/nvKkUEU1G38c1siN6QP6a9PT9MmHB8GnpscSmMJSoF8LOIrt8ud/wPtojys4G6+g==} - dev: true /safe-buffer@5.2.1: resolution: {integrity: sha512-rp3So07KcdmmKbGvgaNxQSJr7bGVSVk5S9Eq1F+ppbRo70+YeaDxkw5Dd8NPN+GD6bjnYm2VuPuCXmpuYvmCXQ==} @@ -20588,7 +22069,7 @@ packages: resolution: {integrity: sha512-JBUUzyOgEwXQY1NuPtvcj/qcBDbDmEvWufhlnXZIm75DEHp+afM1r1ujJpJsV/gSM4t59tpDyPi1sd6ZaPFfsA==} dependencies: call-bind: 1.0.2 - get-intrinsic: 1.2.1 + get-intrinsic: 1.2.0 is-regex: 1.1.4 dev: true @@ -20607,11 +22088,11 @@ packages: /safe-regex@2.1.1: resolution: {integrity: sha512-rx+x8AMzKb5Q5lQ95Zoi6ZbJqwCLkqi3XuJXp5P3rT8OEc6sZCJG5AE5dU3lsgRr/F4Bs31jSlVN+j5KrsGu9A==} dependencies: - regexp-tree: 0.1.27 + regexp-tree: 0.1.24 dev: true - /safe-stable-stringify@2.4.3: - resolution: {integrity: sha512-e2bDA2WJT0wxseVd4lsDP4+3ONX6HpMXQa1ZhFQ7SU+GjvORCmShbCMltrtIDfkYhVHrOcPtj+KhmDBdPdZD1g==} + /safe-stable-stringify@2.3.1: + resolution: {integrity: sha512-kYBSfT+troD9cDA85VDnHZ1rpHC50O0g1e6WlGHVCz/g+JS+9WKLj+XwFYyR8UbrZN8ll9HUpDAAddY58MGisg==} engines: {node: '>=10'} dev: true @@ -20623,7 +22104,7 @@ packages: resolution: {integrity: sha512-3lVqBir7WuKDHGrKRDn/1Ye3kwpXaDOMsiRP1wd6wpZW56gJhsbp5RqQpA6JG/P+pkXizygnr1dKR8vzWaVsfA==} dependencies: es6-promise: 3.3.1 - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 mkdirp: 0.5.6 rimraf: 2.7.1 dev: true @@ -20639,7 +22120,7 @@ packages: capture-exit: 2.0.0 exec-sh: 0.3.6 execa: 1.0.0 - fb-watchman: 2.0.2 + fb-watchman: 2.0.1 micromatch: 3.1.10 minimist: 1.2.8 walker: 1.0.8 @@ -20690,7 +22171,7 @@ packages: resolution: {integrity: sha512-0ilKFI6QQF5nxDZLFn2dMjvc4hjg/Wkg7rHd3jK6/A4a1Hl9VFdQWvgB1UMGoU94pad1P/8N7fMcEnLnSiju8A==} engines: {node: '>= 8.9.0'} dependencies: - '@types/json-schema': 7.0.12 + '@types/json-schema': 7.0.11 ajv: 6.12.6 ajv-keywords: 3.5.2(ajv@6.12.6) dev: true @@ -20699,16 +22180,16 @@ packages: resolution: {integrity: sha512-SHiNtMOUGWBQJwzISiVYKu82GiV4QYGePp3odlY1tuKO7gPtphAT5R/py0fA6xtbgLL/RvtJZnU9b8s0F1q0Xg==} engines: {node: '>= 8.9.0'} dependencies: - '@types/json-schema': 7.0.12 + '@types/json-schema': 7.0.11 ajv: 6.12.6 ajv-keywords: 3.5.2(ajv@6.12.6) dev: true - /schema-utils@3.3.0: - resolution: {integrity: sha512-pN/yOAvcC+5rQ5nERGuwrjLlYvLTbCibnZ1I7B1LaiAz9BRBlE9GMgE/eqV30P7aJQUf7Ddimy/RsbYO/GrVGg==} + /schema-utils@3.1.1: + resolution: {integrity: sha512-Y5PQxS4ITlC+EahLuXaY86TXfR7Dc5lw294alXOq86JAHCihAIZfqv8nNCWvaEJvaC51uN9hbLGeV0cFBdH+Fw==} engines: {node: '>= 10.13.0'} dependencies: - '@types/json-schema': 7.0.12 + '@types/json-schema': 7.0.11 ajv: 6.12.6 ajv-keywords: 3.5.2(ajv@6.12.6) dev: true @@ -20717,30 +22198,43 @@ packages: resolution: {integrity: sha512-4AsO/FrViE/iDNEPaAQlb77tf0csuq27EsVpy6ett584EcRTp6pTDLoGWVxCD77y5iU5FauOvhsI4o1APwPoSQ==} dev: true - /search-insights@2.7.0: - resolution: {integrity: sha512-GLbVaGgzYEKMvuJbHRhLi1qoBFnjXZGZ6l4LxOYPCp4lI2jDRB3jPU9/XNhMwv6kvnA9slTreq6pvK+b3o3aqg==} + /search-insights@2.6.0: + resolution: {integrity: sha512-vU2/fJ+h/Mkm/DJOe+EaM5cafJv/1rRTZpGJTuFPf/Q5LjzgMDsqPdSaZsAe+GAWHHsfsu+rQSAn6c8IGtBEVw==} engines: {node: '>=8.16.0'} dev: true - /secure-json-parse@2.7.0: - resolution: {integrity: sha512-6aU+Rwsezw7VR8/nyvKTx8QpWH9FrcYiXXlqC4z5d5XQBDRqtbfsRjnwGyqbi3gddNtWHuEk9OANUotL26qKUw==} + /secure-json-parse@2.5.0: + resolution: {integrity: sha512-ZQruFgZnIWH+WyO9t5rWt4ZEGqCKPwhiw+YbzTwpmT9elgLrLcfuyUiSnwwjUiVy9r4VM3urtbNF1xmEh9IL2w==} dev: true /select-hose@2.0.0: resolution: {integrity: sha512-mEugaLK+YfkijB4fx0e6kImuJdCIt2LxCRcbEYPqRGCs4F2ogyfZU5IAZRdjCP8JPq2AtdNoC/Dux63d9Kiryg==} dev: true - /semver@5.7.2: - resolution: {integrity: sha512-cBznnQ9KjJqU67B52RMC65CMarK2600WFnbkcaiwWq3xy/5haFJlshgnpjovMVJ+Hff49d8GEn0b87C5pDQ10g==} + /semver@5.7.1: + resolution: {integrity: sha512-sauaDf/PZdVgrLTNYHRtpXa1iRiKcaebiKQ1BJdpQlWH2lCvexQdX55snPFyK7QzpudqbCI0qXFfOasHdyNDGQ==} + hasBin: true + dev: true + + /semver@6.3.0: + resolution: {integrity: sha512-b39TBaTSfV6yBrapU89p5fKekE2m/NwnDocOVruQFS1/veMgdzuPcnOM34M6CwxW8jH/lxEa5rBoDeUwu5HHTw==} + hasBin: true + + /semver@7.0.0: + resolution: {integrity: sha512-+GB6zVA9LWh6zovYQLALHwv5rb2PHGlJi3lfiqIHxR0uuwCgefcOJc59v9fv1w8GbStwxuuqqAjI9NMAOOgq1A==} hasBin: true dev: true - /semver@6.3.1: - resolution: {integrity: sha512-BR7VvDCVHO+q2xBEWskxS6DJE1qRnb7DxzUrogb71CWoSficBxYsiAGd+Kl0mmq/MprG9yArRkyrQxTO6XjMzA==} + /semver@7.3.7: + resolution: {integrity: sha512-QlYTucUYOews+WeEujDoEGziz4K6c47V/Bd+LjSSYcA94p+DmINdf7ncaUinThfvZyu13lN9OY1XDxt8C0Tw0g==} + engines: {node: '>=10'} hasBin: true + dependencies: + lru-cache: 6.0.0 + dev: true - /semver@7.5.4: - resolution: {integrity: sha512-1bCSESV6Pv+i21Hvpxp3Dx+pSD8lIPt8uVjRrxAUt/nbswYc+tK6Y2btiULjd4+fnq15PX+nqQDC7Oft7WkwcA==} + /semver@7.5.2: + resolution: {integrity: sha512-SoftuTROv/cRjCze/scjGyiDtcUyxw1rgYQSZY7XTmtR5hX+dm76iDbTH8TkLPHCQmlbQVSSbNZCPM2hb0knnQ==} engines: {node: '>=10'} hasBin: true dependencies: @@ -20787,16 +22281,12 @@ packages: randombytes: 2.1.0 dev: true - /serialize-javascript@6.0.1: - resolution: {integrity: sha512-owoXEFjWRllis8/M1Q+Cw5k8ZH40e3zhp/ovX+Xr/vi1qj6QesbyXXViFbpNvWvPNAD62SutwEXavefrLJWj7w==} + /serialize-javascript@6.0.0: + resolution: {integrity: sha512-Qr3TosvguFt8ePWqsvRfrKyQXIiW+nGbYpy8XK24NQHE83caxWt+mIymTT19DGFbNWNLfEwsrkSmN64lVWB9ag==} dependencies: randombytes: 2.1.0 dev: true - /seroval@0.5.1: - resolution: {integrity: sha512-ZfhQVB59hmIauJG5Ydynupy8KHyr5imGNtdDhbZG68Ufh1Ynkv9KOYOAABf71oVbQxJ8VkWnMHAjEHE7fWkH5g==} - engines: {node: '>=10'} - /serve-favicon@2.5.0: resolution: {integrity: sha512-FMW2RvqNr03x+C0WxTyu6sOv21oOjkq5j8tjquWccwa6ScNyGFOGJVpuS1NmTVGBAHS07xnSKotgf2ehQmf9iA==} engines: {node: '>= 0.8.0'} @@ -20824,6 +22314,10 @@ packages: resolution: {integrity: sha512-KiKBS8AnWGEyLzofFfmvKwpdPzqiy16LvQfK3yv/fVH7Bj13/wl3JSR1J+rfgRE9q7xUJK4qvgS8raSOeLUehw==} dev: true + /set-cookie-parser@2.5.1: + resolution: {integrity: sha512-1jeBGaKNGdEq4FgIrORu/N570dwoPYio8lSoYLWmX7sQ//0JY08Xh9o5pBcgmHQ/MbsYp/aZnOe1s1lIsbLprQ==} + dev: true + /set-cookie-parser@2.6.0: resolution: {integrity: sha512-RVnVQxTXuerk653XfuliOxBP81Sf0+qfQE73LIYKcyMYHG94AuH0kgrQpRDuTZnSmjpysHmzxJXKNfa6PjFhyQ==} dev: true @@ -20866,11 +22360,11 @@ packages: dependencies: decode-ico: 0.4.1 ico-endec: 0.1.6 - sharp: 0.32.2 + sharp: 0.32.1 dev: true - /sharp@0.32.2: - resolution: {integrity: sha512-e4hyWKtU7ks/rLmoPys476zhpQnLqPJopz4+5b6OPeyJfvCTInAp0pe5tGhstjsNdUvDLrUVGEwevewYdZM8Eg==} + /sharp@0.32.1: + resolution: {integrity: sha512-kQTFtj7ldpUqSe8kDxoGLZc1rnMFU0AO2pqbX6pLy3b7Oj8ivJIdoKNwxHVQG2HN6XpHPJqCSM2nsma2gOXvOg==} engines: {node: '>=14.15.0'} requiresBuild: true dependencies: @@ -20878,9 +22372,9 @@ packages: detect-libc: 2.0.1 node-addon-api: 6.1.0 prebuild-install: 7.1.1 - semver: 7.5.4 + semver: 7.5.2 simple-get: 4.0.1 - tar-fs: 3.0.4 + tar-fs: 2.1.1 tunnel-agent: 0.6.0 dev: true @@ -20908,8 +22402,8 @@ packages: engines: {node: '>=8'} dev: true - /shell-quote@1.8.1: - resolution: {integrity: sha512-6j1W9l1iAs/4xYBI1SYOVZyFcCis9b4KCLQ8fgAGG07QvzaRLVVRQvAy85yNmmZSjYjg4MWh4gNvlPujU/5LpA==} + /shell-quote@1.7.4: + resolution: {integrity: sha512-8o/QEhSSRb1a5i7TFR0iM4G16Z0vYB2OQVs4G3aAFXjn3T6yEx8AZxy1PgDF7I00LZHYA3WxaSYIf5e5sAX8Rw==} dev: true /shiki@0.14.3: @@ -20925,7 +22419,7 @@ packages: resolution: {integrity: sha512-q5XPytqFEIKHkGdiMIrY10mvLRvnQh42/+GoBlFW3b2LXLE2xxJpZFdm94we0BaoV3RwJyGqg5wS7epxTv0Zvw==} dependencies: call-bind: 1.0.2 - get-intrinsic: 1.2.1 + get-intrinsic: 1.2.0 object-inspect: 1.12.3 dev: true @@ -20941,8 +22435,8 @@ packages: resolution: {integrity: sha512-wnD2ZE+l+SPC/uoS0vXeE9L1+0wuaMqKlfz9AMUo38JsyLSBWSFcHR1Rri62LZc12vLr1gb3jl7iwQhgwpAbGQ==} dev: true - /signal-exit@4.0.2: - resolution: {integrity: sha512-MY2/qGx4enyjprQnFaZsHib3Yadh3IXyV2C321GY0pjGfVBu4un0uDJkwgdxqO+Rdx8JMT8IfJIRwbYVz3Ob3Q==} + /signal-exit@4.0.1: + resolution: {integrity: sha512-uUWsN4aOxJAS8KOuf3QMyFtgm1pkb6I+KRZbRF/ghdf5T7sM+B1lLLzPDxswUjkmHyxQAVzEgG35E3NzDM9GVw==} engines: {node: '>=14'} dev: true @@ -20976,7 +22470,7 @@ packages: dependencies: '@polka/url': 1.0.0-next.21 mrmime: 1.0.1 - totalist: 3.0.1 + totalist: 3.0.0 /sisteransi@1.0.5: resolution: {integrity: sha512-bLGGlR1QxBcynn2d5YmDX4MGjlZvy2MRBDRNHLJ8VI6l6+9FUiyTFNJ0IveOSP0bcXgVDPRcfGqA0pjaqUpfVg==} @@ -21055,36 +22549,34 @@ packages: - supports-color dev: true - /solid-js@1.7.8: - resolution: {integrity: sha512-XHBWk1FvFd0JMKljko7FfhefJMTSgYEuVKcQ2a8hzRXfiuSJAGsrPPafqEo+f6l+e8Oe3cROSpIL6kbzjC1fjQ==} + /solid-js@1.5.2: + resolution: {integrity: sha512-4dUeAVVJsMNLuEZ4VjGYf3rUgOc2CXEvzp/Q01UcF1EJBnMoqhYmXTEDiLD829kAyDpgnE1O0bXG1PzYYiXOZQ==} dependencies: - csstype: 3.1.2 - seroval: 0.5.1 + csstype: 3.1.0 - /solid-refresh@0.5.3(solid-js@1.7.8): - resolution: {integrity: sha512-Otg5it5sjOdZbQZJnvo99TEBAr6J7PQ5AubZLNU6szZzg3RQQ5MX04oteBIIGDs0y2Qv8aXKm9e44V8z+UnFdw==} + /solid-refresh@0.4.1(solid-js@1.5.2): + resolution: {integrity: sha512-v3tD/OXQcUyXLrWjPW1dXZyeWwP7/+GQNs8YTL09GBq+5FguA6IejJWUvJDrLIA4M0ho9/5zK2e9n+uy+4488g==} peerDependencies: solid-js: ^1.3 dependencies: - '@babel/generator': 7.22.7 + '@babel/generator': 7.22.5 '@babel/helper-module-imports': 7.22.5 '@babel/types': 7.22.5 - solid-js: 1.7.8 + solid-js: 1.5.2 dev: true - /solid-testing-library@0.5.1(solid-js@1.7.8): - resolution: {integrity: sha512-CfcCWsI5zIJz2zcyZQz2weq+6cCS5QrcmWeEmUEy03fElJ/BV5Ly4MMTsmwdOK803zY3wJP5pPf026C40VrE1Q==} + /solid-testing-library@0.5.0(solid-js@1.5.2): + resolution: {integrity: sha512-vr4Ke9Dq3bUFLaXOcN8/IVn2e9Q37w4vdmoIOmFBIPs7iCJX9IxuC0IdQqK8nzBZMQqceijkfyCE3Qc407KmaA==} engines: {node: '>= 14'} - deprecated: This package is now available at @solidjs/testing-library peerDependencies: solid-js: '>=1.0.0' dependencies: - '@testing-library/dom': 8.20.1 - solid-js: 1.7.8 + '@testing-library/dom': 8.19.0 + solid-js: 1.5.2 dev: true - /sonic-boom@3.3.0: - resolution: {integrity: sha512-LYxp34KlZ1a2Jb8ZQgFCK3niIHzibdwtwNUWKg0qQRzsDoJ3Gfgkf8KdBTFU3SkejDEIlWwnSnpVdOZIhFMl/g==} + /sonic-boom@3.2.0: + resolution: {integrity: sha512-SbbZ+Kqj/XIunvIAgUZRlqd6CGQYq71tRRbXR92Za8J/R3Yh4Av+TWENiSiEgnlwckYLyP0YZQWVfyNC0dzLaA==} dependencies: atomic-sleep: 1.0.0 dev: true @@ -21112,7 +22604,7 @@ packages: deprecated: See https://github.com/lydell/source-map-resolve#deprecated dependencies: atob: 2.1.2 - decode-uri-component: 0.2.2 + decode-uri-component: 0.2.0 resolve-url: 0.2.1 source-map-url: 0.4.1 urix: 0.1.0 @@ -21137,6 +22629,7 @@ packages: /source-map@0.6.1: resolution: {integrity: sha512-UjgapumWlbMhkBgzT7Ykc5YXUT46F0iKu8SGXq0bcwP5dz/h0Plj6enJqjz1Zbq2l5WaqYnrVbwWOWMyF3F47g==} engines: {node: '>=0.10.0'} + requiresBuild: true /source-map@0.7.4: resolution: {integrity: sha512-l3BikUxvPOcn5E74dZiq5BGsTb5yEwhaTSzccU6t4sDOH8NWJCstKO5QT2CvtFoK6F0saL7p9xHAqHOlCPJygA==} @@ -21153,7 +22646,6 @@ packages: /sourcemap-codec@1.4.8: resolution: {integrity: sha512-9NykojV5Uih4lgo5So5dtw+f0JgJX30KCNI8gwhz2J9A15wD0Ml6tjHKwf6fTSa6fAdVBdZeNOs9eJ71qCk8vA==} deprecated: Please use @jridgewell/sourcemap-codec instead - dev: true /space-separated-tokens@1.1.5: resolution: {integrity: sha512-q/JSVd1Lptzhf5bkYm4ob4iWPjx0KiRe3sRFBNrVqbJkFaBm5vbbowy1mymoPNLRa52+oadOhJ+K49wsSeSjTA==} @@ -21167,11 +22659,11 @@ packages: spdx-ranges: 2.1.1 dev: true - /spdx-correct@3.2.0: - resolution: {integrity: sha512-kN9dJbvnySHULIluDHy32WHRUu3Og7B9sbY7tsFLctQkIqnMh3hErYgdMjTYuqmcXX+lK5T1lnUt3G7zNswmZA==} + /spdx-correct@3.1.1: + resolution: {integrity: sha512-cOYcUWwhCuHCXi49RhFRCyJEK3iPj1Ziz9DpViV3tbZOwXD49QzIN3MpOLJNxh2qwq2lJJZaKMVw9qNi4jTC0w==} dependencies: spdx-expression-parse: 3.0.1 - spdx-license-ids: 3.0.13 + spdx-license-ids: 3.0.12 dev: true /spdx-exceptions@2.3.0: @@ -21182,7 +22674,7 @@ packages: resolution: {integrity: sha512-cbqHunsQWnJNE6KhVSMsMeH5H/L9EpymbzqTQ3uLwNCLZ1Q481oWaofqH7nO6V07xlXwY6PhQdQ2IedWx/ZK4Q==} dependencies: spdx-exceptions: 2.3.0 - spdx-license-ids: 3.0.13 + spdx-license-ids: 3.0.12 dev: true /spdx-expression-validate@2.0.0: @@ -21191,8 +22683,8 @@ packages: spdx-expression-parse: 3.0.1 dev: true - /spdx-license-ids@3.0.13: - resolution: {integrity: sha512-XkD+zwiqXHikFZm4AX/7JSCXA98U5Db4AFd5XUg/+9UNtnH75+Z9KxtpYiJZx36mUDVOwH83pl7yvCer6ewM3w==} + /spdx-license-ids@3.0.12: + resolution: {integrity: sha512-rr+VVSXtRhO4OHbXUiAF7xW3Bo9DuuF6C5jH+q/x15j2jniycgKbxU09Hr0WqlSLUs4i4ltHGXqTe7VHclYWyA==} dev: true /spdx-ranges@2.1.1: @@ -21214,7 +22706,7 @@ packages: detect-node: 2.1.0 hpack.js: 2.1.6 obuf: 1.1.2 - readable-stream: 3.6.2 + readable-stream: 3.6.0 wbuf: 1.7.3 transitivePeerDependencies: - supports-color @@ -21240,8 +22732,8 @@ packages: extend-shallow: 3.0.2 dev: true - /split2@4.2.0: - resolution: {integrity: sha512-UcjcJOWknrNkF6PLX83qcHM6KHgVKNkV62Y8a5uYDVv9ydGQVwAHMKqHdJje1VTWpljG0WYpCDhrCdAOYH4TWg==} + /split2@4.1.0: + resolution: {integrity: sha512-VBiJxFkxiXRlUIeyMQi8s4hgvKCSjtknJv/LVYbrgALPwf5zSKmEwV9Lst25AkvMDnvxODugjdl6KZgwKM1WYQ==} engines: {node: '>= 10.x'} dev: true @@ -21283,7 +22775,7 @@ packages: resolution: {integrity: sha512-97qShzy1AiyxvPNIkLWoGua7xoQzzPjQ0HAH4B0rWKo7SZ6USuPcrUiAFrws0UH8RrbWmgq3LMTObhPIHbbBeQ==} engines: {node: '>= 8'} dependencies: - minipass: 3.3.6 + minipass: 3.3.4 dev: true /stable@0.1.8: @@ -21291,8 +22783,8 @@ packages: deprecated: 'Modern JS already guarantees Array#sort() is a stable sort, so this library is deprecated. See the compatibility table on MDN: https://developer.mozilla.org/en-US/docs/Web/JavaScript/Reference/Global_Objects/Array/sort#browser_compatibility' dev: true - /stack-utils@2.0.6: - resolution: {integrity: sha512-XlkWvfIm6RmsWtNJx+uqtKLS8eqFbxUg0ZzLXqY0caEy9l7hruX8IpiDnjsLavoBgqCCR71TqWO8MaXYheJ3RQ==} + /stack-utils@2.0.5: + resolution: {integrity: sha512-xrQcmYhOsn/1kX+Vraq+7j4oE2j/6BFscZ0etmYg81xuM8Gq0022Pxb8+IqgOFUIaxHs0KaSb7T1+OegiNrNFA==} engines: {node: '>=10'} dependencies: escape-string-regexp: 2.0.0 @@ -21342,7 +22834,7 @@ packages: resolution: {integrity: sha512-nX6hmklHs/gr2FuxYDltq8fJA1GDlxKQCz8O/IM4atRqBH8OORmBNgfvW5gG10GT/qQ9u0CzIvr2X5Pkt6ntqg==} dependencies: inherits: 2.0.4 - readable-stream: 2.3.8 + readable-stream: 2.3.7 dev: true /stream-each@1.2.3: @@ -21357,7 +22849,7 @@ packages: dependencies: builtin-status-codes: 3.0.0 inherits: 2.0.4 - readable-stream: 2.3.8 + readable-stream: 2.3.7 to-arraybuffer: 1.0.1 xtend: 4.0.2 dev: true @@ -21371,13 +22863,6 @@ packages: engines: {node: '>=10.0.0'} dev: true - /streamx@2.15.0: - resolution: {integrity: sha512-HcxY6ncGjjklGs1xsP1aR71INYcsXFJet5CU1CHqihQ2J5nOsbd4OjgjHO42w/4QNv9gZb3BueV+Vxok5pLEXg==} - dependencies: - fast-fifo: 1.3.0 - queue-tick: 1.0.1 - dev: true - /strict-event-emitter@0.2.8: resolution: {integrity: sha512-KDf/ujU8Zud3YaLtMCcTI4xkZlZVIYxTLr+XIULexP+77EEVWixeXroLUXQXiVtH4XH2W7jr/3PT1v3zBuvc3A==} dependencies: @@ -21388,8 +22873,8 @@ packages: resolution: {integrity: sha512-12KWeb+wixJohmnwNFerbyiBrAlq5qJLwIt38etRtKtmmHyDSoGlIqFE9wx+4IwG0aDjI7GV8tc8ZccjWZZtTg==} dev: true - /string-argv@0.3.2: - resolution: {integrity: sha512-aqD2Q0144Z+/RqG52NeHEkZauTAUWJO8c6yTftGJKO3Tja5tUgIfmIl6kExvhtxSDP7fXB6DvzkfMpCd/F3G+Q==} + /string-argv@0.3.1: + resolution: {integrity: sha512-a1uQGz7IyVy9YwhqjZIZu1c8JO8dNIe20xBmSS6qu9kv++k3JGzCVmprbNN5Kn+BgzD5E7YYwg1CcjuJMRNsvg==} engines: {node: '>=0.6.19'} dev: true @@ -21419,60 +22904,60 @@ packages: strip-ansi: 7.1.0 dev: true - /string.prototype.matchall@4.0.8: - resolution: {integrity: sha512-6zOCOcJ+RJAQshcTvXPHoxoQGONa3e/Lqx90wUA+wEzX78sg5Bo+1tQo4N0pohS0erG9qtCqJDjNCQBjeWVxyg==} + /string.prototype.matchall@4.0.7: + resolution: {integrity: sha512-f48okCX7JiwVi1NXCVWcFnZgADDC/n2vePlQ/KUCNqCikLLilQvwjMO8+BHVKvgzH0JB0J9LEPgxOGT02RoETg==} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.21.2 - get-intrinsic: 1.2.1 + es-abstract: 1.20.4 + get-intrinsic: 1.2.0 has-symbols: 1.0.3 internal-slot: 1.0.5 regexp.prototype.flags: 1.5.0 side-channel: 1.0.4 dev: true - /string.prototype.padend@3.1.4: - resolution: {integrity: sha512-67otBXoksdjsnXXRUq+KMVTdlVRZ2af422Y0aTyTjVaoQkGr3mxl2Bc5emi7dOQ3OGVVQQskmLEWwFXwommpNw==} + /string.prototype.padend@3.1.3: + resolution: {integrity: sha512-jNIIeokznm8SD/TZISQsZKYu7RJyheFNt84DUPrh482GC8RVp2MKqm2O5oBRdGxbDQoXrhhWtPIWQOiy20svUg==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.21.2 + es-abstract: 1.20.4 dev: true - /string.prototype.padstart@3.1.4: - resolution: {integrity: sha512-XqOHj8horGsF+zwxraBvMTkBFM28sS/jHBJajh17JtJKA92qazidiQbLosV4UA18azvLOVKYo/E3g3T9Y5826w==} + /string.prototype.padstart@3.1.3: + resolution: {integrity: sha512-NZydyOMtYxpTjGqp0VN5PYUF/tsU15yDMZnUdj16qRUIUiMJkHHSDElYyQFrMu+/WloTpA7MQSiADhBicDfaoA==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.21.2 + es-abstract: 1.20.4 dev: true - /string.prototype.trim@1.2.7: - resolution: {integrity: sha512-p6TmeT1T3411M8Cgg9wBTMRtY2q9+PNy9EV1i2lIXUN/btt763oIfxwN3RR8VU6wHX8j/1CFy0L+YuThm6bgOg==} + /string.prototype.trim@1.2.6: + resolution: {integrity: sha512-8lMR2m+U0VJTPp6JjvJTtGyc4FIGq9CdRt7O9p6T0e6K4vjU+OP+SQJpbe/SBmRcCUIvNUnjsbmY6lnMp8MhsQ==} engines: {node: '>= 0.4'} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.21.2 + es-abstract: 1.20.4 dev: true - /string.prototype.trimend@1.0.6: - resolution: {integrity: sha512-JySq+4mrPf9EsDBEDYMOb/lM7XQLulwg5R/m1r0PXEFqrV0qHvl58sdTilSXtKOflCsK2E8jxf+GKC0T07RWwQ==} + /string.prototype.trimend@1.0.5: + resolution: {integrity: sha512-I7RGvmjV4pJ7O3kdf+LXFpVfdNOxtCW/2C8f6jNiW4+PQchwxkCDzlk1/7p+Wl4bqFIZeF47qAHXLuHHWKAxog==} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.21.2 + es-abstract: 1.20.4 dev: true - /string.prototype.trimstart@1.0.6: - resolution: {integrity: sha512-omqjMDaY92pbn5HOX7f9IccLA+U1tA9GvtU4JrodiXFfYB7jPzzHpRzpglLAjtUV6bB557zwClJezTqnAiYnQA==} + /string.prototype.trimstart@1.0.5: + resolution: {integrity: sha512-THx16TJCGlsN0o6dl2o6ncWUsdgnLRSA23rRE5pyGBw/mLr3Ej/R2LaqCtgP8VNMGZsvMWnf9ooZPyY2bHvUFg==} dependencies: call-bind: 1.0.2 define-properties: 1.2.0 - es-abstract: 1.21.2 + es-abstract: 1.20.4 dev: true /string_decoder@1.1.1: @@ -21510,6 +22995,13 @@ packages: ansi-regex: 5.0.1 dev: true + /strip-ansi@7.0.1: + resolution: {integrity: sha512-cXNxvT8dFNRVfhVME3JAe98mkXDYN2O1l7jmcwMnOslDeESg1rF/OZMtK0nRAhiari1unG5cD4jG3rapUAkLbw==} + engines: {node: '>=12'} + dependencies: + ansi-regex: 6.0.1 + dev: true + /strip-ansi@7.1.0: resolution: {integrity: sha512-iq6eVVI64nQQTRYq2KtEg2d2uU7LElhTJwsH4YzIHZshxlgZms/wIc4VoDQTlG/IvVIrBKG06CrZnp0qv7hkcQ==} engines: {node: '>=12'} @@ -21571,13 +23063,6 @@ packages: min-indent: 1.0.1 dev: true - /strip-indent@4.0.0: - resolution: {integrity: sha512-mnVSV2l+Zv6BLpSD/8V87CW/y9EmmbYzGCIavsnsI6/nwn26DwffM/yztm30Z/I2DY9wdS3vXVCMnHDgZaVNoA==} - engines: {node: '>=12'} - dependencies: - min-indent: 1.0.1 - dev: true - /strip-json-comments@2.0.1: resolution: {integrity: sha512-4gB8na07fecVVkOI6Rs4e7T6NOTki5EmL7TUduTs6bu3EdnSycntVJ4re8kgZA+wx9IueI2Y11bfbgwtzuE0KQ==} engines: {node: '>=0.10.0'} @@ -21591,7 +23076,7 @@ packages: /strip-literal@1.0.1: resolution: {integrity: sha512-QZTsipNpa2Ppr6v1AmJHESqJ3Uz247MUS0OjrnnZjFAvEoWqxuyFuXn2xLgMtRnijJShAa1HL0gtJyUs7u7n3Q==} dependencies: - acorn: 8.10.0 + acorn: 8.9.0 /style-loader@1.3.0(webpack@4.46.0): resolution: {integrity: sha512-V7TCORko8rs9rIqkSrlMfkqA63DfoGBBJmK1kKGCcSi+BWb4cqz0SRsnp4l6rU5iwOEd0/2ePv68SV22VXon4Q==} @@ -21599,7 +23084,7 @@ packages: peerDependencies: webpack: ^4.0.0 || ^5.0.0 dependencies: - loader-utils: 2.0.4 + loader-utils: 2.0.2 schema-utils: 2.7.1 webpack: 4.46.0 dev: true @@ -21610,7 +23095,7 @@ packages: inline-style-parser: 0.1.1 dev: true - /styled-jsx@5.0.1(@babel/core@7.22.8)(react@18.0.0): + /styled-jsx@5.0.1(@babel/core@7.22.5)(react@18.0.0): resolution: {integrity: sha512-+PIZ/6Uk40mphiQJJI1202b+/dYeTVd9ZnMPR80pgiWbjIwvN2zIp4r9et0BgqBuShh48I0gttPlAXA7WVvBxw==} engines: {node: '>= 12.0.0'} peerDependencies: @@ -21623,42 +23108,42 @@ packages: babel-plugin-macros: optional: true dependencies: - '@babel/core': 7.22.8 + '@babel/core': 7.22.5 react: 18.0.0 dev: false - /stylis@4.2.0: - resolution: {integrity: sha512-Orov6g6BB1sDfYgzWfTHDOxamtX1bE/zo104Dh9e6fqJ3PooipYyfJ0pUmrZO2wAvO8YbEyeFrkV91XTsGMSrw==} + /stylis@4.0.13: + resolution: {integrity: sha512-xGPXiFVl4YED9Jh7Euv2V220mriG9u4B2TA6Ybjc1catrstKD2PpIdU3U0RKpkVBC2EhmL/F0sPCr9vrFTNRag==} dev: false - /sucrase@3.32.0: - resolution: {integrity: sha512-ydQOU34rpSyj2TGyz4D2p8rbktIOZ8QY9s+DGLvFU1i5pWJE8vkpruCjGCMHsdXwnD7JDcS+noSwM/a7zyNFDQ==} + /sucrase@3.28.0: + resolution: {integrity: sha512-TK9600YInjuiIhVM3729rH4ZKPOsGeyXUwY+Ugu9eilNbdTFyHr6XcAGYbRVZPDgWj6tgI7bx95aaJjHnbffag==} engines: {node: '>=8'} hasBin: true dependencies: - '@jridgewell/gen-mapping': 0.3.3 commander: 4.1.1 glob: 7.1.6 lines-and-columns: 1.2.4 mz: 2.7.0 - pirates: 4.0.6 + pirates: 4.0.5 ts-interface-checker: 0.1.13 dev: true - /superagent@8.0.9: - resolution: {integrity: sha512-4C7Bh5pyHTvU33KpZgwrNKh/VQnvgtCSqPRfJAUdmrtSYePVzVg4E4OzsrbkhJj9O7SO6Bnv75K/F8XVZT8YHA==} + /superagent@8.0.0: + resolution: {integrity: sha512-iudipXEel+SzlP9y29UBWGDjB+Zzag+eeA1iLosaR2YHBRr1Q1kC29iBrF2zIVD9fqVbpZnXkN/VJmwFMVyNWg==} engines: {node: '>=6.4.0 <13 || >=14'} dependencies: component-emitter: 1.3.0 - cookiejar: 2.1.4 + cookiejar: 2.1.3 debug: 4.3.4(supports-color@8.1.1) fast-safe-stringify: 2.1.1 form-data: 4.0.0 - formidable: 2.1.2 + formidable: 2.0.1 methods: 1.1.2 mime: 2.6.0 - qs: 6.11.2 - semver: 7.5.4 + qs: 6.11.0 + readable-stream: 3.6.0 + semver: 7.5.2 transitivePeerDependencies: - supports-color dev: true @@ -21668,7 +23153,7 @@ packages: engines: {node: '>=6.4.0'} dependencies: methods: 1.1.2 - superagent: 8.0.9 + superagent: 8.0.0 transitivePeerDependencies: - supports-color dev: true @@ -21708,8 +23193,8 @@ packages: resolution: {integrity: sha512-ot0WnXS9fgdkgIcePe6RHNk1WA8+muPa6cSjeR3V8K27q9BB1rTE3R1p7Hv0z1ZyAc8s6Vvv8DIyWf681MAt0w==} engines: {node: '>= 0.4'} - /svelte-check@3.4.6(svelte@3.59.2): - resolution: {integrity: sha512-OBlY8866Zh1zHQTkBMPS6psPi7o2umTUyj6JWm4SacnIHXpWFm658pG32m3dKvKFL49V4ntAkfFHKo4ztH07og==} + /svelte-check@3.4.3(svelte@3.59.1): + resolution: {integrity: sha512-O07soQFY3X0VDt+bcGc6D5naz0cLtjwnmNP9JsEBPVyMemFEqUhL2OdLqvkl5H/u8Jwm50EiAU4BPRn5iin/kg==} hasBin: true peerDependencies: svelte: ^3.55.0 || ^4.0.0-next.0 || ^4.0.0 @@ -21720,9 +23205,9 @@ packages: import-fresh: 3.3.0 picocolors: 1.0.0 sade: 1.8.1 - svelte: 3.59.2 - svelte-preprocess: 5.0.4(svelte@3.59.2)(typescript@5.1.6) - typescript: 5.1.6 + svelte: 3.59.1 + svelte-preprocess: 5.0.4(svelte@3.59.1)(typescript@5.1.3) + typescript: 5.1.3 transitivePeerDependencies: - '@babel/core' - coffeescript @@ -21735,13 +23220,13 @@ packages: - sugarss dev: true - /svelte-hmr@0.15.2(svelte@3.59.2): + /svelte-hmr@0.15.2(svelte@3.59.1): resolution: {integrity: sha512-q/bAruCvFLwvNbeE1x3n37TYFb3mTBJ6TrCq6p2CoFbSTNhDE9oAtEfpy+wmc9So8AG0Tja+X0/mJzX9tSfvIg==} engines: {node: ^12.20 || ^14.13.1 || >= 16} peerDependencies: svelte: ^3.19.0 || ^4.0.0-next.0 dependencies: - svelte: 3.59.2 + svelte: 3.59.1 dev: true /svelte-hmr@0.15.2(svelte@4.0.5): @@ -21753,7 +23238,7 @@ packages: svelte: 4.0.5 dev: true - /svelte-preprocess@5.0.4(svelte@3.59.2)(typescript@5.1.6): + /svelte-preprocess@5.0.4(svelte@3.59.1)(typescript@5.1.3): resolution: {integrity: sha512-ABia2QegosxOGsVlsSBJvoWeXy1wUKSfF7SWJdTjLAbx/Y3SrVevvvbFNQqrSJw89+lNSsM58SipmZJ5SRi5iw==} engines: {node: '>= 14.10.0'} requiresBuild: true @@ -21796,12 +23281,12 @@ packages: magic-string: 0.27.0 sorcery: 0.11.0 strip-indent: 3.0.0 - svelte: 3.59.2 - typescript: 5.1.6 + svelte: 3.59.1 + typescript: 5.1.3 dev: true - /svelte@3.59.2: - resolution: {integrity: sha512-vzSyuGr3eEoAtT/A6bmajosJZIUWySzY2CzB3w2pgPvnkUjGqlDnsNnA0PMO+mMAhuyMul6C2uuZzY6ELSkzyA==} + /svelte@3.59.1: + resolution: {integrity: sha512-pKj8fEBmqf6mq3/NfrB9SLtcJcUvjYSWyePlfCqN9gujLB25RitWK8PvFzlwim6hD/We35KbPlRteuA6rnPGcQ==} engines: {node: '>= 8'} dev: true @@ -21812,7 +23297,7 @@ packages: '@ampproject/remapping': 2.2.1 '@jridgewell/sourcemap-codec': 1.4.15 '@jridgewell/trace-mapping': 0.3.18 - acorn: 8.10.0 + acorn: 8.9.0 aria-query: 5.3.0 axobject-query: 3.2.1 code-red: 1.0.3 @@ -21839,8 +23324,8 @@ packages: resolution: {integrity: sha512-ovssysQTa+luh7A5Weu3Rta6FJlFBBbInjOh722LIt6klpU2/HtdUbszju/G4devcvk8PGt7FCLv5wftu3THUA==} dev: true - /sweetalert2@11.7.16: - resolution: {integrity: sha512-vxqVcA358RWdK/XOG1gFtOzT7qBH186Ry4gnW0Xtrx7vIo1mpnR8hG8MxQms4gz3JPbYQ6UIgZn0+hTK7in3Jw==} + /sweetalert2@11.6.16: + resolution: {integrity: sha512-T2FO8LptErsjE4r0WMfiSk4YbeUvPadNaUZ/cADMEOnws000znrf8zFX9S5e/spvzJDyRI5En73WQyDZhGypxQ==} dev: true /swr@1.3.0(react@18.2.0): @@ -21867,15 +23352,15 @@ packages: call-bind: 1.0.2 get-symbol-description: 1.0.0 has-symbols: 1.0.3 - object.getownpropertydescriptors: 2.1.6 + object.getownpropertydescriptors: 2.1.4 dev: true - /synchronous-promise@2.0.17: - resolution: {integrity: sha512-AsS729u2RHUfEra9xJrE39peJcc2stq2+poBXX8bcM08Y6g9j/i/PUzwNQqkaJde7Ntg1TO7bSREbR5sdosQ+g==} + /synchronous-promise@2.0.16: + resolution: {integrity: sha512-qImOD23aDfnIDNqlG1NOehdB9IYsn1V9oByPjKY1nakv2MQYCEMyX033/q+aEtYCpmYK1cv2+NTmlH+ra6GA5A==} dev: true - /tabbable@6.2.0: - resolution: {integrity: sha512-Cat63mxsVJlzYvN51JmVXIgNoUokrIaT2zLclCXjRd8boZ0004U4KCs/sToJ75C6sdlByWxpYnb5Boif1VSFew==} + /tabbable@6.1.2: + resolution: {integrity: sha512-qCN98uP7i9z0fIS4amQ5zbGBOq+OSigYeGvPy7NDk8Y9yncqDZ9pRPgfsc2PJIVM9RrJj7GIfuRgmjoUU9zTHQ==} dev: true /tapable@1.1.3: @@ -21897,14 +23382,6 @@ packages: tar-stream: 2.2.0 dev: true - /tar-fs@3.0.4: - resolution: {integrity: sha512-5AFQU8b9qLfZCX9zp2duONhPmZv0hGYiBPJsyUdqMjzq/mqVpy/rEUSeHk1+YitmxugaptgBh5oDGU3VsAJq4w==} - dependencies: - mkdirp-classic: 0.5.3 - pump: 3.0.0 - tar-stream: 3.1.6 - dev: true - /tar-stream@2.2.0: resolution: {integrity: sha512-ujeqbceABgwMZxEJnk2HDY2DlnUZ+9oEcb1KzTVfYHio0UE6dG71n60d8D2I4qNvleWrrXpmjpt7vZeF1LnMZQ==} engines: {node: '>=6'} @@ -21913,24 +23390,16 @@ packages: end-of-stream: 1.4.4 fs-constants: 1.0.0 inherits: 2.0.4 - readable-stream: 3.6.2 + readable-stream: 3.6.0 dev: true - /tar-stream@3.1.6: - resolution: {integrity: sha512-B/UyjYwPpMBv+PaFSWAmtYjwdrlEaZQEhMIBFNC5oEG8lpiW8XjcSdmEaClj28ArfKScKHs2nshz3k2le6crsg==} - dependencies: - b4a: 1.6.4 - fast-fifo: 1.3.0 - streamx: 2.15.0 - dev: true - - /tar@6.1.15: - resolution: {integrity: sha512-/zKt9UyngnxIT/EAGYuxaMYgOIJiP81ab9ZfkILq4oNLPFX50qyYmu7jRj9qeXoxmJHjGlbH0+cm2uy1WCs10A==} + /tar@6.1.13: + resolution: {integrity: sha512-jdIBIN6LTIe2jqzay/2vtYLlBHa3JF42ot3h1dW8Q0PaAG4v8rm0cvpVePtau5C6OKXGGcgO9q2AMNSWxiLqKw==} engines: {node: '>=10'} dependencies: chownr: 2.0.0 fs-minipass: 2.1.0 - minipass: 5.0.0 + minipass: 4.2.5 minizlib: 2.1.2 mkdirp: 1.0.4 yallist: 4.0.0 @@ -21949,12 +23418,6 @@ packages: memoizerific: 1.11.3 dev: true - /telejson@7.1.0: - resolution: {integrity: sha512-jFJO4P5gPebZAERPkJsqMAQ0IMA1Hi0AoSfxpnUaV6j6R2SZqlpkbS20U6dEUtA3RUYt2Ak/mTlkQzHH9Rv/hA==} - dependencies: - memoizerific: 1.11.3 - dev: true - /temp-dir@2.0.0: resolution: {integrity: sha512-aoBAniQmmwtcKp/7BzsH8Cxzv8OL736p7v1ihGb5e9DJ9kTwGWHrQrVB5+lfVDzfGrdRzXch+ig7LHaY1JTOrg==} engines: {node: '>=8'} @@ -22006,18 +23469,18 @@ packages: find-cache-dir: 3.3.2 jest-worker: 26.6.2 p-limit: 3.1.0 - schema-utils: 3.3.0 + schema-utils: 3.1.1 serialize-javascript: 5.0.1 source-map: 0.6.1 - terser: 5.19.0 + terser: 5.15.0 webpack: 4.46.0 webpack-sources: 1.4.3 transitivePeerDependencies: - bluebird dev: true - /terser-webpack-plugin@5.3.9(esbuild@0.18.11)(webpack@5.88.1): - resolution: {integrity: sha512-ZuXsqE07EcggTWQjXUj+Aot/OMcD0bMKGgF63f7UxYcu5/AJF53aIpK1YoP5xR9l6s/Hy2b+t1AM0bLNPRuhwA==} + /terser-webpack-plugin@5.3.6(esbuild@0.18.11)(webpack@5.74.0): + resolution: {integrity: sha512-kfLFk+PoLUQIbLmB1+PZDMRSZS99Mp+/MHqDNmMA6tOItzRt+Npe3E+fsMs5mfcM0wCtrrdU387UnV+vnSffXQ==} engines: {node: '>= 10.13.0'} peerDependencies: '@swc/core': '*' @@ -22035,10 +23498,10 @@ packages: '@jridgewell/trace-mapping': 0.3.18 esbuild: 0.18.11 jest-worker: 27.5.1 - schema-utils: 3.3.0 - serialize-javascript: 6.0.1 - terser: 5.19.0 - webpack: 5.88.1(esbuild@0.18.11) + schema-utils: 3.1.1 + serialize-javascript: 6.0.0 + terser: 5.15.0 + webpack: 5.74.0(esbuild@0.18.11) dev: true /terser@4.8.1: @@ -22046,19 +23509,19 @@ packages: engines: {node: '>=6.0.0'} hasBin: true dependencies: - acorn: 8.10.0 + acorn: 8.9.0 commander: 2.20.3 source-map: 0.6.1 source-map-support: 0.5.21 dev: true - /terser@5.19.0: - resolution: {integrity: sha512-JpcpGOQLOXm2jsomozdMDpd5f8ZHh1rR48OFgWUH3QsyZcfPgv2qDCYbcDEAYNd4OZRj2bWYKpwdll/udZCk/Q==} + /terser@5.15.0: + resolution: {integrity: sha512-L1BJiXVmheAQQy+as0oF3Pwtlo4s3Wi1X2zNZ2NxOB4wx9bdS9Vk67XQENLFdLYGCK/Z2di53mTj/hBafR+dTA==} engines: {node: '>=10'} hasBin: true dependencies: - '@jridgewell/source-map': 0.3.5 - acorn: 8.10.0 + '@jridgewell/source-map': 0.3.2 + acorn: 8.9.0 commander: 2.20.3 source-map-support: 0.5.21 dev: true @@ -22088,8 +23551,8 @@ packages: any-promise: 1.3.0 dev: true - /thread-stream@2.3.0: - resolution: {integrity: sha512-kaDqm1DET9pp3NXwR8382WHbnpXnRkN9xGN9dQt3B2+dmXiW8X1SOwmFOxAErEQ47ObhZ96J6yhZNXuyCOL7KA==} + /thread-stream@2.1.0: + resolution: {integrity: sha512-5+Pf2Ya31CsZyIPYYkhINzdTZ3guL+jHq7D8lkBybgGcSQIKDbid3NJku3SpCKeE/gACWAccDA/rH2B6doC5aA==} dependencies: real-require: 0.2.0 dev: true @@ -22105,7 +23568,7 @@ packages: /through2@2.0.5: resolution: {integrity: sha512-/mrRod8xqpA+IHSLyGCQ2s8SPHiCDEeQJSep1jqLYeEUClOFG2Qsh+4FU6G9VeqpZnGW/Su8LQGc4YKni5rYSQ==} dependencies: - readable-stream: 2.3.8 + readable-stream: 2.3.7 xtend: 4.0.2 dev: true @@ -22120,6 +23583,13 @@ packages: setimmediate: 1.0.5 dev: true + /tiny-glob@0.2.9: + resolution: {integrity: sha512-g/55ssRPUjShh+xkfx9UPDXqhckHEsHr4Vd9zX55oSdGZc/MD0m3sferOkwWtp98bv+kcVfEHtRJgBVJzelrzg==} + dependencies: + globalyzer: 0.1.0 + globrex: 0.1.2 + dev: true + /tiny-lru@8.0.2: resolution: {integrity: sha512-ApGvZ6vVvTNdsmt676grvCkUCGwzG9IqXma5Z07xJgiC5L7akUMof5U8G2JTI9Rz/ovtVhJBlY6mNhEvtjzOIg==} engines: {node: '>=6'} @@ -22139,8 +23609,8 @@ packages: engines: {node: '>=14.0.0'} dev: false - /tinyspy@1.1.1: - resolution: {integrity: sha512-UVq5AXt/gQlti7oxoIg5oi/9r0WpF7DGEVwXgqWSMmyN16+e3tl5lIvTaOpJ3TAtu5xFzWccFRM4R5NaWHF+4g==} + /tinyspy@1.0.2: + resolution: {integrity: sha512-bSGlgwLBYf7PnUsQ6WOc6SJ3pGOcd+d8AA6EUnLDDM0kWEstC1JIlSZA3UNliDXhd9ABoS7hiRBDCu+XP/sf1Q==} engines: {node: '>=14.0.0'} dev: true @@ -22215,8 +23685,8 @@ packages: engines: {node: '>=0.6'} dev: true - /totalist@3.0.1: - resolution: {integrity: sha512-sf4i37nQ2LBx4m3wB74y+ubopq6W/dIzXg0FDGjsYnZHVa1Da8FH853wlL2gtUhg+xJXjfk3kUZS3BRoQeoQBQ==} + /totalist@3.0.0: + resolution: {integrity: sha512-eM+pCBxXO/njtF7vdFsHuqb+ElbxqtI4r5EAvk6grfAFyJ6IvWlSkfZ5T9ozC6xWw3Fj1fGoSmrl0gUs46JVIw==} engines: {node: '>=6'} /tough-cookie@2.5.0: @@ -22227,8 +23697,8 @@ packages: punycode: 2.3.0 dev: true - /tough-cookie@4.1.3: - resolution: {integrity: sha512-aX/y5pVRkfRnfmuX+OdbSdXvPe6ieKX/G2s7e98f4poJHnqH3281gDPm/metm6E/WRamfx7WC4HUqkWHfQHprw==} + /tough-cookie@4.1.2: + resolution: {integrity: sha512-G9fqXWoYFZgTc2z8Q5zaHy/vJMjm+WV0AkAeHxVCQiEB1b+dGvWzFW6QV07cY5jQ5gRkeid2qIkzkxUnmoQZUQ==} engines: {node: '>=6'} dependencies: psl: 1.9.0 @@ -22283,8 +23753,7 @@ packages: dev: true /trim@0.0.1: - resolution: {integrity: sha512-YzQV+TZg4AxpKxaTHK3c3D+kRDCGVEE7LemdlQZoQXn0iennk10RsIoY6ikzAqJTc9Xjl9C1/waHom/J86ziAQ==} - deprecated: Use String.prototype.trim() instead + resolution: {integrity: sha1-WFhUf2spB1fulczMZm+1AITEYN0=} dev: true /trough@1.0.5: @@ -22304,7 +23773,7 @@ packages: resolution: {integrity: sha512-uivwYcQaxAucv1CzRp2n/QdYPo4ILf9VXgH19zEIjFx2EJufV16P0JtJVpYHy89DItG6Kwj2oIUjrcK5au+4tQ==} engines: {node: '>=8'} dependencies: - tslib: 2.6.0 + tslib: 2.5.3 dev: false /ts-node@10.9.1(@types/node@18.16.19)(typescript@5.1.6): @@ -22325,9 +23794,9 @@ packages: '@tsconfig/node10': 1.0.9 '@tsconfig/node12': 1.0.11 '@tsconfig/node14': 1.0.3 - '@tsconfig/node16': 1.0.4 + '@tsconfig/node16': 1.0.3 '@types/node': 18.16.19 - acorn: 8.10.0 + acorn: 8.9.0 acorn-walk: 8.2.0 arg: 4.1.3 create-require: 1.1.1 @@ -22338,7 +23807,7 @@ packages: yn: 3.1.1 dev: true - /ts-pnp@1.2.0(typescript@4.9.5): + /ts-pnp@1.2.0(typescript@4.8.4): resolution: {integrity: sha512-csd+vJOb/gkzvcCHgTGSChYpy5f1/XKNsmvBGO4JXS+z1v2HobugDz4s1IeFXM3wZB44uczs+eazB5Q/ccdhQw==} engines: {node: '>=6'} peerDependencies: @@ -22347,7 +23816,7 @@ packages: typescript: optional: true dependencies: - typescript: 4.9.5 + typescript: 4.8.4 dev: true /tslib@1.14.1: @@ -22358,8 +23827,8 @@ packages: resolution: {integrity: sha512-d6xOpEDfsi2CZVlPQzGeux8XMwLT9hssAsaPYExaQMuYskwb+x1x7J371tWlbBdWHroy99KnVB6qIkUbs5X3UQ==} dev: false - /tslib@2.6.0: - resolution: {integrity: sha512-7At1WUettjcSRHXCyYtTselblcHl9PJFFVKiCAy/bY97+BPZXSQ2wbq0P9s8tK2G7dFQfNnlJnPAiArVBVBsfA==} + /tslib@2.5.3: + resolution: {integrity: sha512-mSxlJJwl3BMEQCUNnxXBU9jP4JBktcEGhURcPR6VQVlnP0FdDEsIaz0C35dXNGLyRfrATNofF0F5p2KPxQgB+w==} /tsup@6.7.0(ts-node@10.9.1)(typescript@5.1.6): resolution: {integrity: sha512-L3o8hGkaHnu5TdJns+mCqFsDBo83bJ44rlK7e6VdanIvpea4ArPcU3swWGsLVbXak1PqQx/V+SSmFPujBK+zEQ==} @@ -22377,19 +23846,19 @@ packages: typescript: optional: true dependencies: - bundle-require: 4.0.1(esbuild@0.17.19) + bundle-require: 4.0.1(esbuild@0.17.18) cac: 6.7.14 chokidar: 3.5.3 debug: 4.3.4(supports-color@8.1.1) - esbuild: 0.17.19 + esbuild: 0.17.18 execa: 5.1.1 globby: 11.1.0 joycon: 3.1.1 postcss-load-config: 3.1.4(ts-node@10.9.1) resolve-from: 5.0.0 - rollup: 3.26.2 + rollup: 3.26.0 source-map: 0.8.0-beta.0 - sucrase: 3.32.0 + sucrase: 3.28.0 tree-kill: 1.2.2 typescript: 5.1.6 transitivePeerDependencies: @@ -22407,19 +23876,30 @@ packages: typescript: 5.1.6 dev: true - /tsx@3.12.7: - resolution: {integrity: sha512-C2Ip+jPmqKd1GWVQDvz/Eyc6QJbGfE7NrR3fx5BpEHMZsEHoIxHL1j+lKdGobr8ovEyqeNkPLSKp6SCSOt7gmw==} + /tsx@3.11.0: + resolution: {integrity: sha512-q+q4xxu41+AafVwvAGqtNJ1ekPFd33ZhTMXvgIpHMqv/W89efwDRE9IyjhEAZm5iTHsshKaf1BYWSk789BrNCA==} + hasBin: true + dependencies: + '@esbuild-kit/cjs-loader': 2.4.0 + '@esbuild-kit/core-utils': 3.0.0 + '@esbuild-kit/esm-loader': 2.5.0 + optionalDependencies: + fsevents: 2.3.2 + dev: true + + /tsx@3.9.0: + resolution: {integrity: sha512-ofxsE+qjqCYYq4UBt5khglvb+ESgxef1YpuNcdQI92kvcAT2tZVrnSK3g4bRXTUhLmKHcC5q8vIZA47os/stng==} hasBin: true dependencies: - '@esbuild-kit/cjs-loader': 2.4.2 - '@esbuild-kit/core-utils': 3.1.0 - '@esbuild-kit/esm-loader': 2.5.5 + '@esbuild-kit/cjs-loader': 2.3.3 + '@esbuild-kit/core-utils': 2.3.0 + '@esbuild-kit/esm-loader': 2.4.2 optionalDependencies: fsevents: 2.3.2 dev: true /tty-browserify@0.0.0: - resolution: {integrity: sha512-JVa5ijo+j/sOoHGjw0sxw734b1LhBkQ3bvUGNdxnVXDCX81Yx7TFgnZygxrIIWn23hbfTaMYLwRmAxFyDuFmIw==} + resolution: {integrity: sha1-oVe6QC2iTpv5V/mqadUk7tQpAaY=} dev: true /tunnel-agent@0.6.0: @@ -22432,6 +23912,13 @@ packages: resolution: {integrity: sha512-KXXFFdAbFXY4geFIwoyNK+f5Z1b7swfXABfL7HXCmoIWMKU3dmS26672A4EeQtDzLKy7SXmfBu51JolvEKwtGA==} dev: true + /type-check@0.3.2: + resolution: {integrity: sha512-ZCmOJdvOWDBYJlzAoFkC+Q0+bUyEOS1ltgp1MGU03fqHG+dbi9tBFU2Rd9QKiDZFAYrhPh2JUf7rZRIuHRKtOg==} + engines: {node: '>= 0.8.0'} + dependencies: + prelude-ls: 1.1.2 + dev: true + /type-check@0.4.0: resolution: {integrity: sha512-XleUoc9uwGXqjWwXaUTZAmzMcFZ5858QA2vvx1Ur5xIcixXIP+8LnFDgRplU30us6teqdlskFfu+ae4K79Ooew==} engines: {node: '>= 0.8.0'} @@ -22486,14 +23973,6 @@ packages: mime-types: 2.1.35 dev: true - /typed-array-length@1.0.4: - resolution: {integrity: sha512-KjZypGq+I/H7HI5HlOoGHkWUUGq+Q0TPhQurLbyrVrvnKTBgzLhIJ7j6J/XTQOi0d1RjyZ0wdas8bKs2p0x3Ng==} - dependencies: - call-bind: 1.0.2 - for-each: 0.3.3 - is-typed-array: 1.1.10 - dev: true - /typedarray-to-buffer@3.1.5: resolution: {integrity: sha512-zdu8XMNEDepKKR+XYOXAVPtWui0ly0NtohUscw+UmaHiAWT8hrV1rr//H6V+0DvJ3OQ19S979M0laLfX8rm82Q==} dependencies: @@ -22504,20 +23983,26 @@ packages: resolution: {integrity: sha512-/aCDEGatGvZ2BIk+HmLf4ifCJFwvKFNb9/JeZPMulfgFracn9QFcAf5GO8B/mweUjSoblS5In0cWhqpfs/5PQA==} dev: true - /typescript@4.9.5: - resolution: {integrity: sha512-1FXk9E2Hm+QzZQ7z+McJiHL4NW1F2EzMu9Nq9i3zAaGqibafqYwCVU6WyWAuyQRRzOlxou8xZSyXLEN8oKj24g==} + /typescript@4.8.4: + resolution: {integrity: sha512-QCh+85mCy+h0IGff8r5XWzOVSbBO+KfeYrMQh7NJ58QujwcE22u+NUSmUxqF+un70P9GXKxa2HCNiTTMJknyjQ==} engines: {node: '>=4.2.0'} hasBin: true dev: true + /typescript@5.1.3: + resolution: {integrity: sha512-XH627E9vkeqhlZFQuL+UsyAXEnibT0kWR2FWONlr4sTjvxyJYnyefgrkyECLzM5NenmKzRAy2rR/OlYLA1HkZw==} + engines: {node: '>=14.17'} + hasBin: true + dev: true + /typescript@5.1.6: resolution: {integrity: sha512-zaWCozRZ6DLEWAWFrVDz1H6FVXzUSfTy5FUMWsQlU8Ym5JP9eO4xkTIROFCQvhQf61z6O/G6ugw3SgAnvvm+HA==} engines: {node: '>=14.17'} hasBin: true dev: true - /ua-parser-js@1.0.35: - resolution: {integrity: sha512-fKnGuqmTBnIE+/KXSzCn4db8RTigUzw1AN0DmdU6hJovUTbYJKyqj+8Mt1c4VfRDnOVJnENmfYkIPZ946UrSAA==} + /ua-parser-js@1.0.34: + resolution: {integrity: sha512-K9mwJm/DaB6mRLZfw6q8IMXipcrmuT6yfhYmwhAkuh+81sChuYstYA+znlgaflUPaYUa3odxKPKGw6Vw/lANew==} dev: true /ufo@0.8.6: @@ -22527,8 +24012,8 @@ packages: /ufo@1.1.2: resolution: {integrity: sha512-TrY6DsjTQQgyS3E3dBaOXf0TpPD8u9FVrVYmKVegJuFw51n/YB9XPt+U6ydzFG5ZIN7+DIjPbNmXoBj9esYhgQ==} - /uglify-js@3.17.4: - resolution: {integrity: sha512-T9q82TJI9e/C1TAxYvfb16xO120tMVFZrGA3f9/P4424DNu6ypK103y0GPFVa17yotwSyZW5iYXgjYHkGrJW/g==} + /uglify-js@3.17.0: + resolution: {integrity: sha512-aTeNPVmgIMPpm1cxXr2Q/nEbvkmV8yq66F3om7X3P/cvOXQ0TMQ64Wk63iyT1gPlmdmGzjGpyLh1f3y8MZWXGg==} engines: {node: '>=0.8.0'} hasBin: true dev: true @@ -22554,7 +24039,14 @@ packages: dependencies: '@antfu/utils': 0.7.5 defu: 6.1.2 - jiti: 1.19.1 + jiti: 1.18.2 + dev: true + + /undici@5.12.0: + resolution: {integrity: sha512-zMLamCG62PGjd9HHMpo05bSLvvwWOZgGeiWlN/vlqu3+lRo3elxktVGEyLMX+IO7c2eflLjcW74AlkhEZm15mg==} + engines: {node: '>=12.18'} + dependencies: + busboy: 1.6.0 dev: true /undici@5.22.1: @@ -22585,23 +24077,23 @@ packages: engines: {node: '>=4'} dependencies: unicode-canonical-property-names-ecmascript: 2.0.0 - unicode-property-aliases-ecmascript: 2.1.0 + unicode-property-aliases-ecmascript: 2.0.0 dev: true - /unicode-match-property-value-ecmascript@2.1.0: - resolution: {integrity: sha512-qxkjQt6qjg/mYscYMC0XKRn3Rh0wFPlfxB0xkt9CfyTvpX1Ra0+rAmdX2QyAobptSEvuy4RtpPRui6XkV+8wjA==} + /unicode-match-property-value-ecmascript@2.0.0: + resolution: {integrity: sha512-7Yhkc0Ye+t4PNYzOGKedDhXbYIBe1XEQYQxOPyhcXNMJ0WCABqqj6ckydd6pWRZTHV4GuCPKdBAUiMc60tsKVw==} engines: {node: '>=4'} dev: true - /unicode-property-aliases-ecmascript@2.1.0: - resolution: {integrity: sha512-6t3foTQI9qne+OZoVQB/8x8rk2k1eVy1gRXhV3oFQ5T6R1dqQ1xtin3XqSlx3+ATBkliTaR/hHyJBm+LVPNM8w==} + /unicode-property-aliases-ecmascript@2.0.0: + resolution: {integrity: sha512-5Zfuy9q/DFr4tfO7ZPeVXb1aPoeQSdeFMLpYuFebehDAhbuevLs5yxSZmIFN1tP5F9Wl4IpJrYojg85/zgyZHQ==} engines: {node: '>=4'} dev: true /unified@9.2.0: resolution: {integrity: sha512-vx2Z0vY+a3YoTj8+pttM3tiJHCwY5UFbYdiWrwBEbHmK8pvsPj2rtAX2BFfgXen8T39CJWblWRDT4L5WGXtDdg==} dependencies: - '@types/unist': 2.0.7 + '@types/unist': 2.0.6 bail: 1.0.5 extend: 3.0.2 is-buffer: 2.0.5 @@ -22610,10 +24102,28 @@ packages: vfile: 4.2.1 dev: true - /unimport@3.0.14(rollup@3.26.2): + /unimport@3.0.14(rollup@3.26.0): resolution: {integrity: sha512-67Rh/sGpEuVqdHWkXaZ6NOq+I7sKt86o+DUtKeGB6dh4Hk1A8AQrzyVGg2+LaVEYotStH7HwvV9YSaRjyT7Uqg==} dependencies: - '@rollup/pluginutils': 5.0.2(rollup@3.26.2) + '@rollup/pluginutils': 5.0.2(rollup@3.26.0) + escape-string-regexp: 5.0.0 + fast-glob: 3.3.0 + local-pkg: 0.4.3 + magic-string: 0.30.1 + mlly: 1.4.0 + pathe: 1.1.1 + pkg-types: 1.0.3 + scule: 1.0.0 + strip-literal: 1.0.1 + unplugin: 1.3.2 + transitivePeerDependencies: + - rollup + dev: true + + /unimport@3.0.7(rollup@3.26.0): + resolution: {integrity: sha512-2dVQUxJEGcrSZ0U4qtwJVODrlfyGcwmIOoHVqbAFFUx7kPoEN5JWr1cZFhLwoAwTmZOvqAm3YIkzv1engIQocg==} + dependencies: + '@rollup/pluginutils': 5.0.2(rollup@3.26.0) escape-string-regexp: 5.0.0 fast-glob: 3.3.0 local-pkg: 0.4.3 @@ -22688,20 +24198,20 @@ packages: /unist-util-stringify-position@2.0.3: resolution: {integrity: sha512-3faScn5I+hy9VleOq/qNbAd6pAx7iH5jYBMS9I1HgQVijz/4mv5Bvw5iw1sC/90CODiKo81G/ps8AJrISn687g==} dependencies: - '@types/unist': 2.0.7 + '@types/unist': 2.0.6 dev: true /unist-util-visit-parents@3.1.1: resolution: {integrity: sha512-1KROIZWo6bcMrZEwiH2UrXDyalAa0uqzWCxCJj6lPOvTve2WkfgCytoDTPaMnodXh1WrXOq0haVYHj99ynJlsg==} dependencies: - '@types/unist': 2.0.7 + '@types/unist': 2.0.6 unist-util-is: 4.1.0 dev: true /unist-util-visit@2.0.3: resolution: {integrity: sha512-iJ4/RczbJMkD0712mGktuGpm/U4By4FfDonL7N/9tATGIF4imikjOuagyMY53tnZq3NP6BcmlrHhEKAfGWjh7Q==} dependencies: - '@types/unist': 2.0.7 + '@types/unist': 2.0.6 unist-util-is: 4.1.0 unist-util-visit-parents: 3.1.1 dev: true @@ -22719,39 +24229,39 @@ packages: /unload@2.2.0: resolution: {integrity: sha512-B60uB5TNBLtN6/LsgAf3udH9saB5p7gqJwcFfbOEZ8BcBHnGwCf6G/TGiEqkRAxX7zAFIUtzdrXQSdL3Q/wqNA==} dependencies: - '@babel/runtime': 7.22.6 + '@babel/runtime': 7.18.9 detect-node: 2.1.0 dev: false - /unocss@0.53.5(postcss@8.4.25)(rollup@2.79.1)(vite@4.4.3): - resolution: {integrity: sha512-LXAdtzAaH8iEDWxW4t9i6TvJNw0OSrgdN+jw8rAZAWb73Nx51ZLoKPUB1rFvQMr2Li7LcsUj5hYpOrQbhhafYg==} + /unocss@0.53.4(postcss@8.4.24)(rollup@2.79.1)(vite@4.3.9): + resolution: {integrity: sha512-UUEi+oh1rngHHP0DVESRS+ScoKMRF8q6GIQrElHb67gqG7GDEGpy3oocIA/6+1t71I4FFvnnxLMGIo9qAD0TEw==} engines: {node: '>=14'} peerDependencies: - '@unocss/webpack': 0.53.5 + '@unocss/webpack': 0.53.4 peerDependenciesMeta: '@unocss/webpack': optional: true dependencies: - '@unocss/astro': 0.53.5(rollup@2.79.1)(vite@4.4.3) - '@unocss/cli': 0.53.5(rollup@2.79.1) - '@unocss/core': 0.53.5 - '@unocss/extractor-arbitrary-variants': 0.53.5 - '@unocss/postcss': 0.53.5(postcss@8.4.25) - '@unocss/preset-attributify': 0.53.5 - '@unocss/preset-icons': 0.53.5 - '@unocss/preset-mini': 0.53.5 - '@unocss/preset-tagify': 0.53.5 - '@unocss/preset-typography': 0.53.5 - '@unocss/preset-uno': 0.53.5 - '@unocss/preset-web-fonts': 0.53.5 - '@unocss/preset-wind': 0.53.5 - '@unocss/reset': 0.53.5 - '@unocss/transformer-attributify-jsx': 0.53.5 - '@unocss/transformer-attributify-jsx-babel': 0.53.5 - '@unocss/transformer-compile-class': 0.53.5 - '@unocss/transformer-directives': 0.53.5 - '@unocss/transformer-variant-group': 0.53.5 - '@unocss/vite': 0.53.5(rollup@2.79.1)(vite@4.4.3) + '@unocss/astro': 0.53.4(rollup@2.79.1)(vite@4.3.9) + '@unocss/cli': 0.53.4(rollup@2.79.1) + '@unocss/core': 0.53.4 + '@unocss/extractor-arbitrary-variants': 0.53.4 + '@unocss/postcss': 0.53.4(postcss@8.4.24) + '@unocss/preset-attributify': 0.53.4 + '@unocss/preset-icons': 0.53.4 + '@unocss/preset-mini': 0.53.4 + '@unocss/preset-tagify': 0.53.4 + '@unocss/preset-typography': 0.53.4 + '@unocss/preset-uno': 0.53.4 + '@unocss/preset-web-fonts': 0.53.4 + '@unocss/preset-wind': 0.53.4 + '@unocss/reset': 0.53.4 + '@unocss/transformer-attributify-jsx': 0.53.4 + '@unocss/transformer-attributify-jsx-babel': 0.53.4 + '@unocss/transformer-compile-class': 0.53.4 + '@unocss/transformer-directives': 0.53.4 + '@unocss/transformer-variant-group': 0.53.4 + '@unocss/vite': 0.53.4(rollup@2.79.1)(vite@4.3.9) transitivePeerDependencies: - postcss - rollup @@ -22759,35 +24269,35 @@ packages: - vite dev: true - /unocss@0.53.5(postcss@8.4.25)(rollup@3.26.2)(vite@4.4.3): - resolution: {integrity: sha512-LXAdtzAaH8iEDWxW4t9i6TvJNw0OSrgdN+jw8rAZAWb73Nx51ZLoKPUB1rFvQMr2Li7LcsUj5hYpOrQbhhafYg==} + /unocss@0.53.4(postcss@8.4.24)(rollup@3.26.0)(vite@4.3.9): + resolution: {integrity: sha512-UUEi+oh1rngHHP0DVESRS+ScoKMRF8q6GIQrElHb67gqG7GDEGpy3oocIA/6+1t71I4FFvnnxLMGIo9qAD0TEw==} engines: {node: '>=14'} peerDependencies: - '@unocss/webpack': 0.53.5 + '@unocss/webpack': 0.53.4 peerDependenciesMeta: '@unocss/webpack': optional: true dependencies: - '@unocss/astro': 0.53.5(rollup@3.26.2)(vite@4.4.3) - '@unocss/cli': 0.53.5(rollup@3.26.2) - '@unocss/core': 0.53.5 - '@unocss/extractor-arbitrary-variants': 0.53.5 - '@unocss/postcss': 0.53.5(postcss@8.4.25) - '@unocss/preset-attributify': 0.53.5 - '@unocss/preset-icons': 0.53.5 - '@unocss/preset-mini': 0.53.5 - '@unocss/preset-tagify': 0.53.5 - '@unocss/preset-typography': 0.53.5 - '@unocss/preset-uno': 0.53.5 - '@unocss/preset-web-fonts': 0.53.5 - '@unocss/preset-wind': 0.53.5 - '@unocss/reset': 0.53.5 - '@unocss/transformer-attributify-jsx': 0.53.5 - '@unocss/transformer-attributify-jsx-babel': 0.53.5 - '@unocss/transformer-compile-class': 0.53.5 - '@unocss/transformer-directives': 0.53.5 - '@unocss/transformer-variant-group': 0.53.5 - '@unocss/vite': 0.53.5(rollup@3.26.2)(vite@4.4.3) + '@unocss/astro': 0.53.4(rollup@3.26.0)(vite@4.3.9) + '@unocss/cli': 0.53.4(rollup@3.26.0) + '@unocss/core': 0.53.4 + '@unocss/extractor-arbitrary-variants': 0.53.4 + '@unocss/postcss': 0.53.4(postcss@8.4.24) + '@unocss/preset-attributify': 0.53.4 + '@unocss/preset-icons': 0.53.4 + '@unocss/preset-mini': 0.53.4 + '@unocss/preset-tagify': 0.53.4 + '@unocss/preset-typography': 0.53.4 + '@unocss/preset-uno': 0.53.4 + '@unocss/preset-web-fonts': 0.53.4 + '@unocss/preset-wind': 0.53.4 + '@unocss/reset': 0.53.4 + '@unocss/transformer-attributify-jsx': 0.53.4 + '@unocss/transformer-attributify-jsx-babel': 0.53.4 + '@unocss/transformer-compile-class': 0.53.4 + '@unocss/transformer-directives': 0.53.4 + '@unocss/transformer-variant-group': 0.53.4 + '@unocss/vite': 0.53.4(rollup@3.26.0)(vite@4.3.9) transitivePeerDependencies: - postcss - rollup @@ -22800,7 +24310,31 @@ packages: engines: {node: '>= 0.8'} dev: true - /unplugin-auto-import@0.16.6(@vueuse/core@10.2.1)(rollup@3.26.2): + /unplugin-auto-import@0.16.4(@vueuse/core@10.2.1)(rollup@3.26.0): + resolution: {integrity: sha512-xdgBa9NAS3JG8HjkAZHSbGSMlrjKpaWKXGUzaF6RzEtr980RCl1t0Zsu0skUInNYrEQfqaHc7aGWPv41DLTK/w==} + engines: {node: '>=14'} + peerDependencies: + '@nuxt/kit': ^3.2.2 + '@vueuse/core': '*' + peerDependenciesMeta: + '@nuxt/kit': + optional: true + '@vueuse/core': + optional: true + dependencies: + '@antfu/utils': 0.7.4 + '@rollup/pluginutils': 5.0.2(rollup@3.26.0) + '@vueuse/core': 10.2.1(vue@3.3.4) + local-pkg: 0.4.3 + magic-string: 0.30.1 + minimatch: 9.0.1 + unimport: 3.0.7(rollup@3.26.0) + unplugin: 1.3.1 + transitivePeerDependencies: + - rollup + dev: true + + /unplugin-auto-import@0.16.6(rollup@3.26.0): resolution: {integrity: sha512-M+YIITkx3C/Hg38hp8HmswP5mShUUyJOzpifv7RTlAbeFlO2Tyw0pwrogSSxnipHDPTtI8VHFBpkYkNKzYSuyA==} engines: {node: '>=14'} peerDependencies: @@ -22813,13 +24347,12 @@ packages: optional: true dependencies: '@antfu/utils': 0.7.5 - '@rollup/pluginutils': 5.0.2(rollup@3.26.2) - '@vueuse/core': 10.2.1(vue@3.3.4) + '@rollup/pluginutils': 5.0.2(rollup@3.26.0) fast-glob: 3.3.0 local-pkg: 0.4.3 magic-string: 0.30.1 minimatch: 9.0.3 - unimport: 3.0.14(rollup@3.26.2) + unimport: 3.0.14(rollup@3.26.0) unplugin: 1.3.2 transitivePeerDependencies: - rollup @@ -22838,23 +24371,23 @@ packages: '@nuxt/kit': optional: true dependencies: - '@antfu/utils': 0.7.5 + '@antfu/utils': 0.7.4 '@rollup/pluginutils': 5.0.2(rollup@2.79.1) chokidar: 3.5.3 debug: 4.3.4(supports-color@8.1.1) fast-glob: 3.3.0 local-pkg: 0.4.3 - magic-string: 0.30.1 - minimatch: 9.0.3 + magic-string: 0.30.0 + minimatch: 9.0.1 resolve: 1.22.2 - unplugin: 1.3.2 + unplugin: 1.3.1 vue: 3.3.4 transitivePeerDependencies: - rollup - supports-color dev: true - /unplugin-vue-components@0.25.1(rollup@3.26.2)(vue@3.3.4): + /unplugin-vue-components@0.25.1(rollup@3.26.0)(vue@3.3.4): resolution: {integrity: sha512-kzS2ZHVMaGU2XEO2keYQcMjNZkanDSGDdY96uQT9EPe+wqSZwwgbFfKVJ5ti0+8rGAcKHColwKUvctBhq2LJ3A==} engines: {node: '>=14'} peerDependencies: @@ -22867,26 +24400,35 @@ packages: '@nuxt/kit': optional: true dependencies: - '@antfu/utils': 0.7.5 - '@rollup/pluginutils': 5.0.2(rollup@3.26.2) + '@antfu/utils': 0.7.4 + '@rollup/pluginutils': 5.0.2(rollup@3.26.0) chokidar: 3.5.3 debug: 4.3.4(supports-color@8.1.1) fast-glob: 3.3.0 local-pkg: 0.4.3 - magic-string: 0.30.1 - minimatch: 9.0.3 + magic-string: 0.30.0 + minimatch: 9.0.1 resolve: 1.22.2 - unplugin: 1.3.2 + unplugin: 1.3.1 vue: 3.3.4 transitivePeerDependencies: - rollup - supports-color dev: true + /unplugin@1.3.1: + resolution: {integrity: sha512-h4uUTIvFBQRxUKS2Wjys6ivoeofGhxzTe2sRWlooyjHXVttcVfV/JiavNd3d4+jty0SVV0dxGw9AkY9MwiaCEw==} + dependencies: + acorn: 8.9.0 + chokidar: 3.5.3 + webpack-sources: 3.2.3 + webpack-virtual-modules: 0.5.0 + dev: true + /unplugin@1.3.2: resolution: {integrity: sha512-Lh7/2SryjXe/IyWqx9K7IKwuKhuOFZEhotiBquOODsv2IVyDkI9lv/XhgfjdXf/xdbv32txmnBNnC/JVTDJlsA==} dependencies: - acorn: 8.10.0 + acorn: 8.9.0 chokidar: 3.5.3 webpack-sources: 3.2.3 webpack-virtual-modules: 0.5.0 @@ -22918,13 +24460,13 @@ packages: engines: {node: '>=4'} dev: true - /update-browserslist-db@1.0.11(browserslist@4.21.9): - resolution: {integrity: sha512-dCwEFf0/oT85M1fHBg4F0jtLwJrutGoHSQXCh7u4o2t1drG+c0a9Flnqww6XUKSfQMPpJBRjU8d4RXB09qtvaA==} + /update-browserslist-db@1.0.5(browserslist@4.21.3): + resolution: {integrity: sha512-dteFFpCyvuDdr9S/ff1ISkKt/9YZxKjI9WlRR99c180GaztJtRa/fn18FdxGVKVsnPY7/a/FDN68mcvUmP4U7Q==} hasBin: true peerDependencies: browserslist: '>= 4.21.0' dependencies: - browserslist: 4.21.9 + browserslist: 4.21.3 escalade: 3.1.1 picocolors: 1.0.0 @@ -22950,9 +24492,9 @@ packages: optional: true dependencies: file-loader: 6.2.0(webpack@4.46.0) - loader-utils: 2.0.4 + loader-utils: 2.0.2 mime-types: 2.1.35 - schema-utils: 3.3.0 + schema-utils: 3.1.1 webpack: 4.46.0 dev: true @@ -22963,11 +24505,11 @@ packages: requires-port: 1.0.0 dev: true - /url@0.11.1: - resolution: {integrity: sha512-rWS3H04/+mzzJkv0eZ7vEDGiQbgquI1fGfOad6zKvgYQi1SzMmhl7c/DdRGxhaWrVH6z0qWITo8rpnxK/RfEhA==} + /url@0.11.0: + resolution: {integrity: sha512-kbailJa29QrtXnxgq+DdCEGlbTeYM2eJUxsz6vjZavrCYPMIFHMKQmSKYAIuUK2i7hgPm28a8piX5NTUtM/LKQ==} dependencies: - punycode: 1.4.1 - qs: 6.11.2 + punycode: 1.3.2 + querystring: 0.2.0 dev: true /use-sync-external-store@1.2.0(react@18.2.0): @@ -22991,7 +24533,7 @@ packages: resolution: {integrity: sha512-i+6qA2MPhvoKLuxnJNpXAGhg7HphQOSUq2LKMZD0m15EiskXUkMvKdF4Uui0WYeCUGea+o2cw/ZuwehtfsrNkA==} dependencies: define-properties: 1.2.0 - object.getownpropertydescriptors: 2.1.6 + object.getownpropertydescriptors: 2.1.4 dev: true /util@0.10.3: @@ -23013,7 +24555,7 @@ packages: is-arguments: 1.1.1 is-generator-function: 1.0.10 is-typed-array: 1.1.10 - which-typed-array: 1.1.10 + which-typed-array: 1.1.9 dev: true /utila@0.4.0: @@ -23021,13 +24563,12 @@ packages: dev: true /utils-merge@1.0.1: - resolution: {integrity: sha512-pMZTvIkT1d+TFGvDOqodOclx0QWkkgi6Tdoa8gC8ffGAAqz9pzPTZWAybbsHHoED/ztMtkv/VoYTYyShUn81hA==} + resolution: {integrity: sha1-n5VxD1CiZ5R7LMwSR0HBAoQn5xM=} engines: {node: '>= 0.4.0'} dev: true /uuid-browser@3.1.0: resolution: {integrity: sha512-dsNgbLaTrd6l3MMxTtouOCFw4CBFc/3a+GgYA2YyrJvyQ1u6q4pcu3ktLoUZ/VN/Aw9WsauazbgsgdfVWgAKQg==} - deprecated: Package no longer supported and required. Use the uuid package or crypto.randomUUID instead dev: true /uuid@3.4.0: @@ -23071,14 +24612,10 @@ packages: '@types/istanbul-lib-coverage': 2.0.4 convert-source-map: 1.9.0 - /validate-html-nesting@1.2.2: - resolution: {integrity: sha512-hGdgQozCsQJMyfK5urgFcWEqsSSrK63Awe0t/IMR0bZ0QMtnuaiHzThW81guu3qx9abLi99NEuiaN6P9gVYsNg==} - dev: true - /validate-npm-package-license@3.0.4: resolution: {integrity: sha512-DpKm2Ui/xN7/HQKCtpZxoRWBhZ9Z0kqtygG8XCgNQ8ZlDnxuQmWhj566j8fN4Cu3/JmbhsDo7fcAJq4s9h27Ew==} dependencies: - spdx-correct: 3.2.0 + spdx-correct: 3.1.1 spdx-expression-parse: 3.0.1 dev: true @@ -23107,39 +24644,20 @@ packages: /vfile-message@2.0.4: resolution: {integrity: sha512-DjssxRGkMvifUOJre00juHoP9DPWuzjxKuMDrhNbk2TdaYYBNMStsNhEOt3idrtI12VQYM/1+iM0KOzXi4pxwQ==} dependencies: - '@types/unist': 2.0.7 + '@types/unist': 2.0.6 unist-util-stringify-position: 2.0.3 dev: true /vfile@4.2.1: resolution: {integrity: sha512-O6AE4OskCG5S1emQ/4gl8zK586RqA3srz3nfK/Viy0UPToBc5Trp9BVFb1u0CjsKrAWwnpr4ifM/KBXPWwJbCA==} dependencies: - '@types/unist': 2.0.7 + '@types/unist': 2.0.6 is-buffer: 2.0.5 unist-util-stringify-position: 2.0.3 vfile-message: 2.0.4 dev: true - /victory-vendor@36.6.11: - resolution: {integrity: sha512-nT8kCiJp8dQh8g991J/R5w5eE2KnO8EAIP0xocWlh9l2okngMWglOPoMZzJvek8Q1KUc4XE/mJxTZnvOB1sTYg==} - dependencies: - '@types/d3-array': 3.0.5 - '@types/d3-ease': 3.0.0 - '@types/d3-interpolate': 3.0.1 - '@types/d3-scale': 4.0.3 - '@types/d3-shape': 3.1.1 - '@types/d3-time': 3.0.0 - '@types/d3-timer': 3.0.0 - d3-array: 3.2.4 - d3-ease: 3.0.1 - d3-interpolate: 3.0.1 - d3-scale: 4.0.2 - d3-shape: 3.2.0 - d3-time: 3.1.0 - d3-timer: 3.0.1 - dev: false - - /vite-plugin-pages@0.31.0(vite@4.4.3): + /vite-plugin-pages@0.31.0(vite@4.3.9): resolution: {integrity: sha512-fw3onBfVTXQI7rOzAbSZhmfwvk50+3qNnGZpERjmD93c8nEjrGLyd53eFXYMxcJV4KA1vzi4qIHt2+6tS4dEMw==} peerDependencies: '@vue/compiler-sfc': ^2.7.0 || ^3.0.0 @@ -23150,19 +24668,19 @@ packages: dependencies: '@types/debug': 4.1.8 debug: 4.3.4(supports-color@8.1.1) - deep-equal: 2.2.2 + deep-equal: 2.2.1 extract-comments: 1.1.0 fast-glob: 3.3.0 json5: 2.2.3 local-pkg: 0.4.3 picocolors: 1.0.0 - vite: 4.4.3(@types/node@18.16.19) + vite: 4.3.9(@types/node@18.16.19) yaml: 2.3.1 transitivePeerDependencies: - supports-color dev: true - /vite-plugin-pwa@0.16.4(vite@4.4.3)(workbox-build@7.0.0)(workbox-window@7.0.0): + /vite-plugin-pwa@0.16.4(vite@4.3.9)(workbox-build@7.0.0)(workbox-window@7.0.0): resolution: {integrity: sha512-lmwHFIs9zI2H9bXJld/zVTbCqCQHZ9WrpyDMqosICDV0FVnCJwniX1NMDB79HGTIZzOQkY4gSZaVTJTw6maz/Q==} engines: {node: '>=16.0.0'} peerDependencies: @@ -23172,53 +24690,51 @@ packages: dependencies: debug: 4.3.4(supports-color@8.1.1) fast-glob: 3.3.0 - pretty-bytes: 6.1.0 - vite: 4.4.3(@types/node@18.16.19) + pretty-bytes: 6.0.0 + vite: 4.3.9(@types/node@18.16.19) workbox-build: 7.0.0 workbox-window: 7.0.0 transitivePeerDependencies: - supports-color dev: true - /vite-plugin-ruby@3.2.2(vite@4.4.3): - resolution: {integrity: sha512-cuHG1MajRWPR8YdfF6lvgsQRnKFEBRwZF//asFbRiI1psacxB5aPlHSvYZYxAu5IflrAa0MdR0HxEq+g98M3iQ==} + /vite-plugin-ruby@3.1.2(vite@4.3.9): + resolution: {integrity: sha512-Pp/NR79lV96wEOjp5MhVHuFxqUhEMNqc7L/02i+XXl1Mq1ab7s2j9kAgtiqp5QKxMd1jy8gV32PgWWVOmcd7/Q==} peerDependencies: - vite: '>=4.0.0' + vite: '>=2.5.0' dependencies: debug: 4.3.4(supports-color@8.1.1) fast-glob: 3.3.0 - vite: 4.4.3(@types/node@18.16.19) + vite: 4.3.9(@types/node@18.16.19) transitivePeerDependencies: - supports-color dev: true - /vite-plugin-solid@2.7.0(solid-js@1.7.8)(vite@4.4.3): - resolution: {integrity: sha512-avp/Jl5zOp/Itfo67xtDB2O61U7idviaIp4mLsjhCa13PjKNasz+IID0jYTyqUp9SFx6/PmBr6v4KgDppqompg==} + /vite-plugin-solid@2.5.0(solid-js@1.5.2)(vite@4.3.9): + resolution: {integrity: sha512-VneGd3RyFJvwaiffsqgymeMaofn0IzQLPwDzafTV2f1agoWeeJlk5VrI5WqT9BTtLe69vNNbCJWqLhHr9fOdDw==} peerDependencies: - solid-js: ^1.7.2 + solid-js: ^1.3.17 || ^1.4.0 || ^1.5.0 || ^1.6.0 vite: ^3.0.0 || ^4.0.0 dependencies: - '@babel/core': 7.22.8 - '@babel/preset-typescript': 7.22.5(@babel/core@7.22.8) - '@types/babel__core': 7.20.1 - babel-preset-solid: 1.7.7(@babel/core@7.22.8) - merge-anything: 5.1.7 - solid-js: 1.7.8 - solid-refresh: 0.5.3(solid-js@1.7.8) - vite: 4.4.3(@types/node@18.16.19) - vitefu: 0.2.4(vite@4.4.3) + '@babel/core': 7.20.5 + '@babel/preset-typescript': 7.18.6(@babel/core@7.20.5) + babel-preset-solid: 1.6.3(@babel/core@7.20.5) + merge-anything: 5.1.4 + solid-js: 1.5.2 + solid-refresh: 0.4.1(solid-js@1.5.2) + vite: 4.3.9(@types/node@18.16.19) + vitefu: 0.2.3(vite@4.3.9) transitivePeerDependencies: - supports-color dev: true - /vite@4.4.3(@types/node@18.16.19): - resolution: {integrity: sha512-IMnXQXXWgLi5brBQx/4WzDxdzW0X3pjO4nqFJAuNvwKtxzAmPzFE1wszW3VDpAGQJm3RZkm/brzRdyGsnwgJIA==} + /vite@4.3.9(@types/node@18.16.19): + resolution: {integrity: sha512-qsTNZjO9NoJNW7KnOrgYwczm0WctJ8m/yqYAMAK9Lxt4SoySUfS5S8ia9K7JHpa3KEeMfyF8LoJ3c5NeBJy6pg==} engines: {node: ^14.18.0 || >=16.0.0} hasBin: true peerDependencies: '@types/node': '>= 14' less: '*' - lightningcss: ^1.21.0 sass: '*' stylus: '*' sugarss: '*' @@ -23228,8 +24744,6 @@ packages: optional: true less: optional: true - lightningcss: - optional: true sass: optional: true stylus: @@ -23240,20 +24754,19 @@ packages: optional: true dependencies: '@types/node': 18.16.19 - esbuild: 0.18.11 - postcss: 8.4.25 - rollup: 3.26.2 + esbuild: 0.17.18 + postcss: 8.4.24 + rollup: 3.23.0 optionalDependencies: fsevents: 2.3.2 - /vite@4.4.3(@types/node@20.4.1): - resolution: {integrity: sha512-IMnXQXXWgLi5brBQx/4WzDxdzW0X3pjO4nqFJAuNvwKtxzAmPzFE1wszW3VDpAGQJm3RZkm/brzRdyGsnwgJIA==} + /vite@4.3.9(@types/node@18.7.13): + resolution: {integrity: sha512-qsTNZjO9NoJNW7KnOrgYwczm0WctJ8m/yqYAMAK9Lxt4SoySUfS5S8ia9K7JHpa3KEeMfyF8LoJ3c5NeBJy6pg==} engines: {node: ^14.18.0 || >=16.0.0} hasBin: true peerDependencies: '@types/node': '>= 14' less: '*' - lightningcss: ^1.21.0 sass: '*' stylus: '*' sugarss: '*' @@ -23263,7 +24776,38 @@ packages: optional: true less: optional: true - lightningcss: + sass: + optional: true + stylus: + optional: true + sugarss: + optional: true + terser: + optional: true + dependencies: + '@types/node': 18.7.13 + esbuild: 0.17.18 + postcss: 8.4.24 + rollup: 3.23.0 + optionalDependencies: + fsevents: 2.3.2 + dev: false + + /vite@4.3.9(@types/node@20.4.1): + resolution: {integrity: sha512-qsTNZjO9NoJNW7KnOrgYwczm0WctJ8m/yqYAMAK9Lxt4SoySUfS5S8ia9K7JHpa3KEeMfyF8LoJ3c5NeBJy6pg==} + engines: {node: ^14.18.0 || >=16.0.0} + hasBin: true + peerDependencies: + '@types/node': '>= 14' + less: '*' + sass: '*' + stylus: '*' + sugarss: '*' + terser: ^5.4.0 + peerDependenciesMeta: + '@types/node': + optional: true + less: optional: true sass: optional: true @@ -23275,13 +24819,25 @@ packages: optional: true dependencies: '@types/node': 20.4.1 - esbuild: 0.18.11 - postcss: 8.4.25 - rollup: 3.26.2 + esbuild: 0.17.18 + postcss: 8.4.24 + rollup: 3.23.0 optionalDependencies: fsevents: 2.3.2 + dev: true + + /vitefu@0.2.3(vite@4.3.9): + resolution: {integrity: sha512-75l7TTuU8isAhz1QFtNKjDkqjxvndfMC1AfIMjJ0ZQ59ZD0Ow9QOIsJJX16Wv9PS8f+zMzp6fHy5cCbKG/yVUQ==} + peerDependencies: + vite: ^3.0.0 || ^4.0.0 + peerDependenciesMeta: + vite: + optional: true + dependencies: + vite: 4.3.9(@types/node@18.16.19) + dev: true - /vitefu@0.2.4(vite@4.4.3): + /vitefu@0.2.4(vite@4.3.9): resolution: {integrity: sha512-fanAXjSaf9xXtOOeno8wZXIhgia+CZury481LsDaV++lSvcU2R9Ch2bPh3PYFyoHW+w9LqAeYRISVQjUIew14g==} peerDependencies: vite: ^3.0.0 || ^4.0.0 @@ -23289,25 +24845,25 @@ packages: vite: optional: true dependencies: - vite: 4.4.3(@types/node@18.16.19) + vite: 4.3.9(@types/node@18.16.19) dev: true - /vitepress@1.0.0-beta.5(@types/node@18.16.19)(search-insights@2.7.0): + /vitepress@1.0.0-beta.5(@types/node@18.16.19)(search-insights@2.6.0): resolution: {integrity: sha512-/RjqqRsSEKkzF6HhK5e5Ij+bZ7ETb9jNCRRgIMm10gJ+ZLC3D1OqkE465lEqCeJUgt2HZ6jmWjDqIBfrJSpv7w==} hasBin: true dependencies: '@docsearch/css': 3.5.1 - '@docsearch/js': 3.5.1(search-insights@2.7.0) - '@vitejs/plugin-vue': 4.2.3(vite@4.4.3)(vue@3.3.4) + '@docsearch/js': 3.5.1(search-insights@2.6.0) + '@vitejs/plugin-vue': 4.2.3(vite@4.3.9)(vue@3.3.4) '@vue/devtools-api': 6.5.0 '@vueuse/core': 10.2.1(vue@3.3.4) - '@vueuse/integrations': 10.2.1(focus-trap@7.5.2)(vue@3.3.4) + '@vueuse/integrations': 10.2.1(focus-trap@7.4.3)(vue@3.3.4) body-scroll-lock: 4.0.0-beta.0 - focus-trap: 7.5.2 + focus-trap: 7.4.3 mark.js: 8.11.1 minisearch: 6.1.0 shiki: 0.14.3 - vite: 4.4.3(@types/node@18.16.19) + vite: 4.3.9(@types/node@18.16.19) vue: 3.3.4 transitivePeerDependencies: - '@algolia/client-search' @@ -23322,7 +24878,6 @@ packages: - idb-keyval - jwt-decode - less - - lightningcss - nprogress - qrcode - react @@ -23362,6 +24917,36 @@ packages: resolution: {integrity: sha512-iGdlqtajmiqed8ptURKPJ/Olz0/mwripVZszg6tygfZSIL9kYFPJTNY6+Q6OjWGznl2L06vxG5HvNvAnWrnzbg==} dev: true + /vue-demi@0.13.11(vue@3.2.39): + resolution: {integrity: sha512-IR8HoEEGM65YY3ZJYAjMlKygDQn25D5ajNFNoKh9RSDMQtlzCxtfQjdQgv9jjK+m3377SsJXY8ysq8kLCZL25A==} + engines: {node: '>=12'} + hasBin: true + requiresBuild: true + peerDependencies: + '@vue/composition-api': ^1.0.0-rc.1 + vue: ^3.0.0-0 || ^2.6.0 + peerDependenciesMeta: + '@vue/composition-api': + optional: true + dependencies: + vue: 3.2.39 + dev: false + + /vue-demi@0.14.0(vue@3.2.39): + resolution: {integrity: sha512-gt58r2ogsNQeVoQ3EhoUAvUsH9xviydl0dWJj7dabBC/2L4uBId7ujtCwDRD0JhkGsV1i0CtfLAeyYKBht9oWg==} + engines: {node: '>=12'} + hasBin: true + requiresBuild: true + peerDependencies: + '@vue/composition-api': ^1.0.0-rc.1 + vue: ^3.0.0-0 || ^2.6.0 + peerDependenciesMeta: + '@vue/composition-api': + optional: true + dependencies: + vue: 3.2.39 + dev: false + /vue-demi@0.14.5(vue@3.3.4): resolution: {integrity: sha512-o9NUVpl/YlsGJ7t+xuqJKx8EBGf1quRhCiT6D/J0pfwmk9zUwYkC7yrF4SZCe6fETvSM3UNL2edcbYrSyc4QHA==} engines: {node: '>=12'} @@ -23386,10 +24971,10 @@ packages: eslint: 8.44.0 eslint-scope: 7.2.0 eslint-visitor-keys: 3.4.1 - espree: 9.6.0 + espree: 9.5.2 esquery: 1.5.0 lodash: 4.17.21 - semver: 7.5.4 + semver: 7.5.2 transitivePeerDependencies: - supports-color dev: true @@ -23402,8 +24987,8 @@ packages: vue: 3.3.4 dev: true - /vue-router@4.2.4(vue@3.3.4): - resolution: {integrity: sha512-9PISkmaCO02OzPVOMq2w82ilty6+xJmQrarYZDkjZBfl4RvYAlt4PKnEX21oW4KTtWfa9OuO/b3qk1Od3AEdCQ==} + /vue-router@4.2.2(vue@3.3.4): + resolution: {integrity: sha512-cChBPPmAflgBGmy3tBsjeoe3f3VOSG6naKyY5pjtrqLGbNEXdzCigFUHgBvp9e3ysAtFtEx7OLqcSDh/1Cq2TQ==} peerDependencies: vue: ^3.2.0 dependencies: @@ -23411,15 +24996,15 @@ packages: vue: 3.3.4 dev: true - /vue-template-compiler@2.7.14: - resolution: {integrity: sha512-zyA5Y3ArvVG0NacJDkkzJuPQDF8RFeRlzV2vLeSnhSpieO6LK2OVbdLPi5MPPs09Ii+gMO8nY4S3iKQxBxDmWQ==} + /vue-template-compiler@2.7.10: + resolution: {integrity: sha512-QO+8R9YRq1Gudm8ZMdo/lImZLJVUIAM8c07Vp84ojdDAf8HmPJc7XB556PcXV218k2AkKznsRz6xB5uOjAC4EQ==} dependencies: de-indent: 1.0.2 he: 1.2.0 - vue: 2.7.14 + vue: 2.7.10 dev: true - /vue-tsc@0.40.13(typescript@4.9.5): + /vue-tsc@0.40.13(typescript@4.8.4): resolution: {integrity: sha512-xzuN3g5PnKfJcNrLv4+mAjteMd5wLm5fRhW0034OfNJZY4WhB07vhngea/XeGn7wNYt16r7syonzvW/54dcNiA==} hasBin: true peerDependencies: @@ -23427,14 +25012,23 @@ packages: dependencies: '@volar/vue-language-core': 0.40.13 '@volar/vue-typescript': 0.40.13 - typescript: 4.9.5 + typescript: 4.8.4 dev: true - /vue@2.7.14: - resolution: {integrity: sha512-b2qkFyOM0kwqWFuQmgd4o+uHGU7T+2z3T+WQp8UBjADfEv2n4FEMffzBmCKNP0IGzOEEfYjvtcC62xaSKeQDrQ==} + /vue@2.7.10: + resolution: {integrity: sha512-HmFC70qarSHPXcKtW8U8fgIkF6JGvjEmDiVInTkKZP0gIlEPhlVlcJJLkdGIDiNkIeA2zJPQTWJUI4iWe+AVfg==} dependencies: - '@vue/compiler-sfc': 2.7.14 - csstype: 3.1.2 + '@vue/compiler-sfc': 2.7.10 + csstype: 3.1.0 + + /vue@3.2.39: + resolution: {integrity: sha512-tRkguhRTw9NmIPXhzk21YFBqXHT2t+6C6wPOgQ50fcFVWnPdetmRqbmySRHznrYjX2E47u0cGlKGcxKZJ38R/g==} + dependencies: + '@vue/compiler-dom': 3.2.39 + '@vue/compiler-sfc': 3.2.39 + '@vue/runtime-dom': 3.2.39 + '@vue/server-renderer': 3.2.39(vue@3.2.39) + '@vue/shared': 3.2.39 /vue@3.3.4: resolution: {integrity: sha512-VTyEYn3yvIeY1Py0WaYGZsXnz3y5UnGi62GjVEqvEGPl6nxbOrCXbVOTQWBEJUqAyTUk2uJ5JLVnYJ6ZzGbrSw==} @@ -23447,7 +25041,6 @@ packages: /w3c-hr-time@1.0.2: resolution: {integrity: sha512-z8P5DvDNjKDoFIHK7q8r8lackT6l+jo/Ye3HOle7l9nICP9lf1Ci25fy9vHd0JOWewkIFzXIEig3TdKT7JQ5fQ==} - deprecated: Use your platform's native performance.now() and performance.timeOrigin. dependencies: browser-process-hrtime: 1.0.0 dev: true @@ -23459,6 +25052,13 @@ packages: xml-name-validator: 3.0.0 dev: true + /w3c-xmlserializer@3.0.0: + resolution: {integrity: sha512-3WFqGEgSXIyGhOmAFtlicJNMjEps8b1MG31NCA0/vOF9+nKMUW1ckhi9cnNHmf88Rzw5V+dwIwsm2C7X8k9aQg==} + engines: {node: '>=12'} + dependencies: + xml-name-validator: 4.0.0 + dev: true + /w3c-xmlserializer@4.0.0: resolution: {integrity: sha512-d+BFHzbiCx6zGfz0HyQ6Rg69w9k19nviJspaj4yNscGjrHu94sVP+aRm75yEbCh+r2/yR+7q6hux9LVtbuTGBw==} engines: {node: '>=14'} @@ -23485,7 +25085,7 @@ packages: /watchpack@1.7.5: resolution: {integrity: sha512-9P3MWk6SrKjHsGkLT2KHXdQ/9SNkyoJbabxnKOoJepsvJjJG8uYTR3yTPxPQvNDI3w4Nz1xnE0TLHK4RIVe/MQ==} dependencies: - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 neo-async: 2.6.2 optionalDependencies: chokidar: 3.5.3 @@ -23499,7 +25099,7 @@ packages: engines: {node: '>=10.13.0'} dependencies: glob-to-regexp: 0.4.1 - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 dev: true /wbuf@1.7.3: @@ -23511,7 +25111,7 @@ packages: /wcwidth@1.0.1: resolution: {integrity: sha512-XHPEwS0q6TaxcvG85+8EYkbiCux2XtWG2mkc47Ng2A77BQu9+DqIOJldST4HgPkuea7dvKSj5VgX3P1d4rW8Tg==} dependencies: - defaults: 1.0.4 + defaults: 1.0.3 dev: true /web-encoding@1.1.5: @@ -23537,7 +25137,7 @@ packages: '@wdio/protocols': 8.11.0 '@wdio/types': 8.10.4 '@wdio/utils': 8.12.1 - deepmerge-ts: 5.1.0 + deepmerge-ts: 5.0.0 got: 12.6.1 ky: 0.33.3 ws: 8.13.0 @@ -23568,7 +25168,7 @@ packages: is-plain-obj: 4.1.0 lodash.clonedeep: 4.5.0 lodash.zip: 4.2.0 - minimatch: 9.0.3 + minimatch: 9.0.1 puppeteer-core: 20.3.0(typescript@5.1.6) query-selector-shadow-dom: 1.0.1 resq: 1.11.0 @@ -23628,11 +25228,11 @@ packages: webpack: 4.46.0 dev: true - /webpack-hot-middleware@2.25.4: - resolution: {integrity: sha512-IRmTspuHM06aZh98OhBJtqLpeWFM8FXJS5UYpKYxCJzyFoyWj1w6VGFfomZU7OPA55dMLrQK0pRT1eQ3PACr4w==} + /webpack-hot-middleware@2.25.2: + resolution: {integrity: sha512-CVgm3NAQyfdIonRvXisRwPTUYuSbyZ6BY7782tMeUzWOO7RmVI2NaBYuCp41qyD4gYCkJyTneAJdK69A13B0+A==} dependencies: ansi-html-community: 0.0.8 - html-entities: 2.4.0 + html-entities: 2.3.3 strip-ansi: 6.0.1 dev: true @@ -23693,7 +25293,7 @@ packages: eslint-scope: 4.0.3 json-parse-better-errors: 1.0.2 loader-runner: 2.4.0 - loader-utils: 1.4.2 + loader-utils: 1.4.0 memory-fs: 0.4.1 micromatch: 3.1.10 mkdirp: 0.5.6 @@ -23708,8 +25308,8 @@ packages: - supports-color dev: true - /webpack@5.88.1(esbuild@0.18.11): - resolution: {integrity: sha512-FROX3TxQnC/ox4N+3xQoWZzvGXSuscxR32rbzjpXgEzWudJFEJBpdlkkob2ylrv5yzzufD1zph1OoFsLtm6stQ==} + /webpack@5.74.0(esbuild@0.18.11): + resolution: {integrity: sha512-A2InDwnhhGN4LYctJj6M1JEaGL7Luj6LOmyBHjcI8529cm5p6VXiTIW2sn6ffvEAKmveLzvu4jrihwXtPojlAA==} engines: {node: '>=10.13.0'} hasBin: true peerDependencies: @@ -23719,27 +25319,27 @@ packages: optional: true dependencies: '@types/eslint-scope': 3.7.4 - '@types/estree': 1.0.1 - '@webassemblyjs/ast': 1.11.6 - '@webassemblyjs/wasm-edit': 1.11.6 - '@webassemblyjs/wasm-parser': 1.11.6 - acorn: 8.10.0 - acorn-import-assertions: 1.9.0(acorn@8.10.0) - browserslist: 4.21.9 + '@types/estree': 0.0.51 + '@webassemblyjs/ast': 1.11.1 + '@webassemblyjs/wasm-edit': 1.11.1 + '@webassemblyjs/wasm-parser': 1.11.1 + acorn: 8.9.0 + acorn-import-assertions: 1.8.0(acorn@8.9.0) + browserslist: 4.21.3 chrome-trace-event: 1.0.3 - enhanced-resolve: 5.15.0 - es-module-lexer: 1.3.0 + enhanced-resolve: 5.10.0 + es-module-lexer: 0.9.3 eslint-scope: 5.1.1 events: 3.3.0 glob-to-regexp: 0.4.1 - graceful-fs: 4.2.11 + graceful-fs: 4.2.10 json-parse-even-better-errors: 2.3.1 loader-runner: 4.3.0 mime-types: 2.1.35 neo-async: 2.6.2 - schema-utils: 3.3.0 + schema-utils: 3.1.1 tapable: 2.2.1 - terser-webpack-plugin: 5.3.9(esbuild@0.18.11)(webpack@5.88.1) + terser-webpack-plugin: 5.3.6(esbuild@0.18.11)(webpack@5.74.0) watchpack: 2.4.0 webpack-sources: 3.2.3 transitivePeerDependencies: @@ -23828,8 +25428,8 @@ packages: is-weakset: 2.0.2 dev: true - /which-typed-array@1.1.10: - resolution: {integrity: sha512-uxoA5vLUfRPdjCuJ1h5LlYdmTLbYfums398v3WLkM+i/Wltl2/XyZpQWKbN++ck5L64SR/grOHqtXCUKmlZPNA==} + /which-typed-array@1.1.9: + resolution: {integrity: sha512-w9c4xkx6mPidwp7180ckYWfMmvxpjlZuIudNtDf4N/tTAUB8VJbX25qZoAsrtGuYNnGw3pa0AXgbGKRB8/EceA==} engines: {node: '>= 0.4'} dependencies: available-typed-arrays: 1.0.5 @@ -23855,8 +25455,8 @@ packages: isexe: 2.0.0 dev: true - /which@3.0.1: - resolution: {integrity: sha512-XA1b62dzQzLfaEOSQFTCOd5KFf/1VSzZo7/7TUjnya6u0vGGKzU96UQBZTAThCb2j4/xjBAyii1OhRLJEivHvg==} + /which@3.0.0: + resolution: {integrity: sha512-nla//68K9NU6yRiwDY/Q8aU6siKlSs64aEC7+IV56QoAuyQT2ovsJcgGYGyqMOmI/CGN1BOR6mM5EN0FBO+zyQ==} engines: {node: ^14.17.0 || ^16.13.0 || >=18.0.0} hasBin: true dependencies: @@ -23885,6 +25485,11 @@ packages: string-width: 4.2.3 dev: true + /word-wrap@1.2.3: + resolution: {integrity: sha512-Hz/mrNwitNRh/HUAtM/VT/5VH+ygD6DV7mYKZAtHOrbs8U7lvPS6xf7EJKMF0uW1KJCl0H701g3ZGus+muE5vQ==} + engines: {node: '>=0.10.0'} + dev: true + /wordwrap@1.0.0: resolution: {integrity: sha512-gvVzJFlPycKc5dZN4yPkP8w7Dc37BtP1yczEneOb4uq34pXZcvrtRTmWV8W+Ume+XCxKgbjM+nevkyFPMybd4Q==} dev: true @@ -23906,15 +25511,15 @@ packages: resolution: {integrity: sha512-CttE7WCYW9sZC+nUYhQg3WzzGPr4IHmrPnjKiu3AMXsiNQKx+l4hHl63WTrnicLmKEKHScWDH8xsGBdrYgtBzg==} engines: {node: '>=16.0.0'} dependencies: - '@apideck/better-ajv-errors': 0.3.6(ajv@8.12.0) - '@babel/core': 7.22.8 - '@babel/preset-env': 7.22.7(@babel/core@7.22.8) - '@babel/runtime': 7.22.6 - '@rollup/plugin-babel': 5.3.1(@babel/core@7.22.8)(rollup@2.79.1) + '@apideck/better-ajv-errors': 0.3.6(ajv@8.11.0) + '@babel/core': 7.22.5 + '@babel/preset-env': 7.18.10(@babel/core@7.22.5) + '@babel/runtime': 7.18.9 + '@rollup/plugin-babel': 5.3.1(@babel/core@7.22.5)(rollup@2.79.1) '@rollup/plugin-node-resolve': 11.2.1(rollup@2.79.1) '@rollup/plugin-replace': 2.4.2(rollup@2.79.1) '@surma/rollup-plugin-off-main-thread': 2.2.3 - ajv: 8.12.0 + ajv: 8.11.0 common-tags: 1.8.2 fast-json-stable-stringify: 2.1.0 fs-extra: 9.1.0 @@ -24031,7 +25636,7 @@ packages: /workbox-window@7.0.0: resolution: {integrity: sha512-j7P/bsAWE/a7sxqTzXo3P2ALb1reTfZdvVp6OJ/uLr/C2kZAMvjeWGm8V4htQhor7DOvYg0sSbFN2+flT5U0qA==} dependencies: - '@types/trusted-types': 2.0.3 + '@types/trusted-types': 2.0.2 workbox-core: 7.0.0 dev: true @@ -24065,8 +25670,8 @@ packages: strip-ansi: 6.0.1 dev: true - /wrap-ansi@8.1.0: - resolution: {integrity: sha512-si7QWI6zUMq56bESFvagtmzMdGOtoxfR+Sez11Mobfc7tm+VkUckk9bW2UeffTGVUbOksxmSw0AA2gs8g71NCQ==} + /wrap-ansi@8.0.1: + resolution: {integrity: sha512-QFF+ufAqhoYHvoHdajT/Po7KoXVBPXS2bgjIam5isfWJPfIOnQZ50JtUiVvCv/sjgacf3yRrt2ZKUZ/V4itN4g==} engines: {node: '>=12'} dependencies: ansi-styles: 6.2.1 @@ -24099,6 +25704,19 @@ packages: optional: true dev: true + /ws@8.11.0: + resolution: {integrity: sha512-HPG3wQd9sNQoT9xHyNCXoDUa+Xw/VevmY9FoHyQ+g+rrMn4j6FB4np7Z0OhdTgjx6MgQLK7jwSy1YecU1+4Asg==} + engines: {node: '>=10.0.0'} + peerDependencies: + bufferutil: ^4.0.1 + utf-8-validate: ^5.0.2 + peerDependenciesMeta: + bufferutil: + optional: true + utf-8-validate: + optional: true + dev: true + /ws@8.13.0: resolution: {integrity: sha512-x9vcZYTrFPC7aSIbj7sRCYo7L/Xb8Iy+pW0ng0wt2vCJv7M9HOMy0UoN3rr+IFC7hb7vXoqS+P9ktyLLLhO+LA==} engines: {node: '>=10.0.0'} @@ -24210,11 +25828,11 @@ packages: yargs-parser: 20.2.9 dev: true - /yargs@17.7.1: - resolution: {integrity: sha512-cwiTb08Xuv5fqF4AovYacTFNxk62th7LKJ6BL9IGUpTJrWoU7/7WdQGTP2SjKf1dUNBGzDd28p/Yfs/GI6JrLw==} + /yargs@17.5.1: + resolution: {integrity: sha512-t6YAJcxDkNX7NFYiVtKvWUz8l+PaKTLiL63mJYWR2GnHq2gjEWISzsLp9wg3aY36dY1j+gfIEL3pIF+XlJJfbA==} engines: {node: '>=12'} dependencies: - cliui: 8.0.1 + cliui: 7.0.4 escalade: 3.1.1 get-caller-file: 2.0.5 require-directory: 2.1.1 @@ -24223,8 +25841,8 @@ packages: yargs-parser: 21.1.1 dev: true - /yargs@17.7.2: - resolution: {integrity: sha512-7dSzzRQ++CKnNI/krKnYRV7JKKPUXMEh61soaHKg9mrWEhzFWhFnxPxGl+69cD1Ou63C13NUPCnmIcrvqCuM6w==} + /yargs@17.7.1: + resolution: {integrity: sha512-cwiTb08Xuv5fqF4AovYacTFNxk62th7LKJ6BL9IGUpTJrWoU7/7WdQGTP2SjKf1dUNBGzDd28p/Yfs/GI6JrLw==} engines: {node: '>=12'} dependencies: cliui: 8.0.1 @@ -24273,11 +25891,11 @@ packages: dependencies: archiver-utils: 2.1.0 compress-commons: 4.1.1 - readable-stream: 3.6.2 + readable-stream: 3.6.0 dev: true - /zustand@4.3.9(react@18.2.0): - resolution: {integrity: sha512-Tat5r8jOMG1Vcsj8uldMyqYKC5IZvQif8zetmLHs9WoZlntTHmIoNM8TpLRY31ExncuUvUOXehd0kvahkuHjDw==} + /zustand@4.1.1(react@18.2.0): + resolution: {integrity: sha512-h4F3WMqsZgvvaE0n3lThx4MM81Ls9xebjvrABNzf5+jb3/03YjNTSgZXeyrvXDArMeV9untvWXRw1tY+ntPYbA==} engines: {node: '>=12.7.0'} peerDependencies: immer: '>=9.0' From 9ec9fbedaa1844ce00944197d67a44448136fa6b Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Wed, 12 Jul 2023 17:02:38 +0200 Subject: [PATCH 65/87] chore: cleanup --- docs/config/index.md | 4 ++-- examples/mocks/vite.config.ts | 3 --- packages/vite-node/src/server.ts | 3 +-- packages/vite-node/src/types.ts | 3 --- packages/vitest/src/runtime/execute.ts | 12 +++++------- packages/vitest/src/runtime/mocker.ts | 2 +- packages/vitest/src/runtime/vm.ts | 2 +- 7 files changed, 10 insertions(+), 19 deletions(-) diff --git a/docs/config/index.md b/docs/config/index.md index 859dd17acf66..089974a1c798 100644 --- a/docs/config/index.md +++ b/docs/config/index.md @@ -547,7 +547,7 @@ By providing an object instead of a string you can define individual outputs whe - **Type:** `boolean` - **CLI:** `--experimentalVmThreads`, `--experimental-vm-threads` -- **Version:** Since Vitets 0.34.0 +- **Version:** Since Vitest 0.34.0 Run tests using [VM context](https://nodejs.org/api/vm.html) (inside a sandboxed environment) in a worker pool. @@ -578,7 +578,7 @@ Please, be aware of these issues when using this option. Vitest team cannot fix - **Type:** `string | number` - **CLI:** `--experimentalVmWorkerMemoryLimit`, `--experimental-vm-worker-memory-limit` - **Default:** `1 / CPU Cores` -- **Version:** Since Vitets 0.34.0 +- **Version:** Since Vitest 0.34.0 Specifies the memory limit for workers before they are recycled. This value heavily depends on your environment, so it's better to specify it manually instead of relying on default. diff --git a/examples/mocks/vite.config.ts b/examples/mocks/vite.config.ts index 6afaf98f75ff..76cb1dad1e3e 100644 --- a/examples/mocks/vite.config.ts +++ b/examples/mocks/vite.config.ts @@ -29,9 +29,6 @@ export default defineConfig({ test: { globals: true, environment: 'node', - poolMatchGlobs: [ - ['**/*', 'experimentalVmThreads'], - ], deps: { external: [/src\/external/], interopDefault: true, diff --git a/packages/vite-node/src/server.ts b/packages/vite-node/src/server.ts index 6e01f8b29a06..884ebfb250a7 100644 --- a/packages/vite-node/src/server.ts +++ b/packages/vite-node/src/server.ts @@ -1,7 +1,7 @@ import { performance } from 'node:perf_hooks' import { existsSync } from 'node:fs' import { join, normalize, relative, resolve } from 'pathe' -import { type PackageCache, type TransformResult, type ViteDevServer } from 'vite' +import { type TransformResult, type ViteDevServer } from 'vite' import createDebug from 'debug' import type { EncodedSourceMap } from '@jridgewell/trace-mapping' import type { DebuggerOptions, FetchResult, ViteNodeResolveId, ViteNodeServerOptions } from './types' @@ -27,7 +27,6 @@ export class ViteNodeServer { }>() externalizeCache = new Map>() - packageCache = new Map() debugger?: Debugger diff --git a/packages/vite-node/src/types.ts b/packages/vite-node/src/types.ts index 5ca54827de35..18d6016a5377 100644 --- a/packages/vite-node/src/types.ts +++ b/packages/vite-node/src/types.ts @@ -1,4 +1,3 @@ -import type { Context } from 'node:vm' import type { ViteHotContext } from 'vite/types/hot' import type { EncodedSourceMap } from '@jridgewell/trace-mapping' import type { ModuleCacheMap, ViteNodeRunner } from './client' @@ -77,11 +76,9 @@ export interface ViteNodeRunnerOptions { createHotContext?: CreateHotContextFunction base?: string moduleCache?: ModuleCacheMap - externalCache?: ModuleCacheMap interopDefault?: boolean requestStubs?: Record debug?: boolean - context?: Context } export interface ViteNodeResolveId { diff --git a/packages/vitest/src/runtime/execute.ts b/packages/vitest/src/runtime/execute.ts index b1268d3bda47..fe21e828a2c1 100644 --- a/packages/vitest/src/runtime/execute.ts +++ b/packages/vitest/src/runtime/execute.ts @@ -73,7 +73,7 @@ export async function startVitestExecutor(options: ContextExecutorOptions) { } function catchError(err: unknown, type: string) { - const worker = options.state + const worker = state() const error = processError(err) if (!isPrimitive(error)) { error.VITEST_TEST_NAME = worker.current?.name @@ -176,16 +176,16 @@ export class VitestExecutor extends ViteNodeRunner { } get state() { - return this.options.state + return getWorkerState() || this.options.state } shouldResolveId(id: string, _importee?: string | undefined): boolean { if (isInternalRequest(id) || id.startsWith('data:')) return false - const environment = this.options.state.environment.name + const transformMode = this.state.environment?.transformMode ?? 'ssr' // do not try and resolve node builtins in Node // import('url') returns Node internal even if 'url' package is installed - return environment === 'node' ? !isNodeBuiltin(id) : !id.startsWith('node:') + return transformMode === 'ssr' ? !isNodeBuiltin(id) : !id.startsWith('node:') } async originalResolveUrl(id: string, importer?: string) { @@ -253,10 +253,8 @@ export class VitestExecutor extends ViteNodeRunner { } prepareContext(context: Record) { - const workerState = this.state - // support `import.meta.vitest` for test entry - if (workerState.filepath && normalize(workerState.filepath) === normalize(context.__filename)) { + if (this.state.filepath && normalize(this.state.filepath) === normalize(context.__filename)) { const globalNamespace = this.options.context || globalThis // @ts-expect-error injected untyped global Object.defineProperty(context.__vite_ssr_import_meta__, 'vitest', { get: () => globalNamespace.__vitest_index__ }) diff --git a/packages/vitest/src/runtime/mocker.ts b/packages/vitest/src/runtime/mocker.ts index 837082ba5787..adfd9485e981 100644 --- a/packages/vitest/src/runtime/mocker.ts +++ b/packages/vitest/src/runtime/mocker.ts @@ -59,7 +59,7 @@ export class VitestMocker { ) { const context = this.executor.options.context if (context) - this.primitives = vm.runInContext('({ Object, Symbol, Error, Function, RegExp, Array, Map })', context) + this.primitives = vm.runInContext('({ Object, Error, Function, RegExp, Symbol, Array, Map })', context) else this.primitives = { Object, Error, Function, RegExp, Symbol: globalThis.Symbol, Array, Map } diff --git a/packages/vitest/src/runtime/vm.ts b/packages/vitest/src/runtime/vm.ts index e5ee30e32ff0..6c016c1c5919 100644 --- a/packages/vitest/src/runtime/vm.ts +++ b/packages/vitest/src/runtime/vm.ts @@ -66,7 +66,7 @@ export async function run(ctx: WorkerContext) { getSourceMap: source => moduleCache.getSourceMap(source), }) - const vm = await environment.setupVM!(ctx.environment.options || ctx.config.environmentOptions || {}) + const vm = await environment.setupVM(ctx.environment.options || ctx.config.environmentOptions || {}) state.durations.environment = performance.now() - state.durations.environment From 46ef72b0698c0535ef6751d46d2ddbd0c72c2743 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Wed, 19 Jul 2023 14:39:55 +0200 Subject: [PATCH 66/87] chore: cleanup --- packages/vitest/package.json | 2 +- .../src/integrations/env/edge-runtime.ts | 2 +- packages/web-worker/package.json | 2 +- pnpm-lock.yaml | 136 +++++++++--------- test/core/test/happy-dom.test.ts | 9 +- 5 files changed, 75 insertions(+), 76 deletions(-) diff --git a/packages/vitest/package.json b/packages/vitest/package.json index 9cc26025a1a8..a91f6c632e92 100644 --- a/packages/vitest/package.json +++ b/packages/vitest/package.json @@ -1,7 +1,7 @@ { "name": "vitest", "type": "module", - "version": "0.33.0", + "version": "0.34.0", "description": "A blazing fast unit test framework powered by Vite", "author": "Anthony Fu ", "license": "MIT", diff --git a/packages/vitest/src/integrations/env/edge-runtime.ts b/packages/vitest/src/integrations/env/edge-runtime.ts index 1ccc055d7e64..9aa3a0fb6cbf 100644 --- a/packages/vitest/src/integrations/env/edge-runtime.ts +++ b/packages/vitest/src/integrations/env/edge-runtime.ts @@ -19,7 +19,7 @@ export default ({ return vm.context }, teardown() { - // TODO + // nothing to teardown }, } }, diff --git a/packages/web-worker/package.json b/packages/web-worker/package.json index b67b6459eb2f..dd5f48322b97 100644 --- a/packages/web-worker/package.json +++ b/packages/web-worker/package.json @@ -41,7 +41,7 @@ "typecheck": "tsc --noEmit" }, "peerDependencies": { - "vitest": ">=0.33.0" + "vitest": ">=0.34.0" }, "dependencies": { "debug": "^4.3.4" diff --git a/pnpm-lock.yaml b/pnpm-lock.yaml index 4815ef2bb0fc..b667ba0e5aa6 100644 --- a/pnpm-lock.yaml +++ b/pnpm-lock.yaml @@ -325,10 +325,10 @@ importers: version: 13.3.0(react-dom@18.0.0)(react@18.0.0) '@types/node': specifier: latest - version: 20.4.1 + version: 20.4.2 '@types/react': specifier: latest - version: 18.2.14 + version: 18.2.15 '@vitejs/plugin-react': specifier: latest version: 4.0.3(vite@4.3.9) @@ -1437,7 +1437,7 @@ importers: specifier: ^4.3.4 version: 4.3.4(supports-color@8.1.1) vitest: - specifier: '>=0.33.0' + specifier: '>=0.34.0' version: link:../vitest devDependencies: '@types/debug': @@ -5842,7 +5842,7 @@ packages: engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: '@jest/types': 27.5.1 - '@types/node': 20.4.1 + '@types/node': 20.4.2 chalk: 4.1.2 jest-message-util: 27.5.1 jest-util: 27.5.1 @@ -5863,7 +5863,7 @@ packages: '@jest/test-result': 27.5.1 '@jest/transform': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.1 + '@types/node': 20.4.2 ansi-escapes: 4.3.2 chalk: 4.1.2 emittery: 0.8.1 @@ -5900,7 +5900,7 @@ packages: dependencies: '@jest/fake-timers': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.1 + '@types/node': 20.4.2 jest-mock: 27.5.1 dev: true @@ -5917,7 +5917,7 @@ packages: dependencies: '@jest/types': 27.5.1 '@sinonjs/fake-timers': 8.1.0 - '@types/node': 20.4.1 + '@types/node': 20.4.2 jest-message-util: 27.5.1 jest-mock: 27.5.1 jest-util: 27.5.1 @@ -5946,7 +5946,7 @@ packages: '@jest/test-result': 27.5.1 '@jest/transform': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.1 + '@types/node': 20.4.2 chalk: 4.1.2 collect-v8-coverage: 1.0.1 exit: 0.1.2 @@ -6059,7 +6059,7 @@ packages: dependencies: '@types/istanbul-lib-coverage': 2.0.4 '@types/istanbul-reports': 3.0.1 - '@types/node': 20.4.1 + '@types/node': 20.4.2 '@types/yargs': 15.0.14 chalk: 4.1.2 dev: true @@ -6070,7 +6070,7 @@ packages: dependencies: '@types/istanbul-lib-coverage': 2.0.4 '@types/istanbul-reports': 3.0.1 - '@types/node': 20.4.1 + '@types/node': 20.4.2 '@types/yargs': 16.0.5 chalk: 4.1.2 dev: true @@ -6082,7 +6082,7 @@ packages: '@jest/schemas': 29.4.3 '@types/istanbul-lib-coverage': 2.0.4 '@types/istanbul-reports': 3.0.1 - '@types/node': 20.4.1 + '@types/node': 20.4.2 '@types/yargs': 17.0.12 chalk: 4.1.2 dev: true @@ -6605,7 +6605,7 @@ packages: engines: {node: '>=14'} hasBin: true dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 playwright-core: 1.28.0 dev: true @@ -8620,7 +8620,7 @@ packages: /@types/cheerio@0.22.31: resolution: {integrity: sha512-Kt7Cdjjdi2XWSfrZ53v4Of0wG3ZcmaegFXjMmz9tfNrZSkzzo36G0AL1YqSdcIA78Etjt6E609pt5h1xnQkPUw==} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 dev: true /@types/codemirror@5.60.8: @@ -8659,7 +8659,7 @@ packages: resolution: {integrity: sha512-xryQlOEIe1TduDWAOphR0ihfebKFSWOXpIsk+70JskCfRfW+xALdnJ0r1ZOTo85F9Qsjk6vtlU7edTYHbls9tA==} dependencies: '@types/cheerio': 0.22.31 - '@types/react': 18.2.14 + '@types/react': 18.2.15 dev: true /@types/eslint-scope@3.7.4: @@ -8690,33 +8690,33 @@ packages: resolution: {integrity: sha512-MxObHvNl4A69ofaTRU8DFqvgzzv8s9yRtaPPm5gud9HDNvpB3GPQFvNuTWAI59B9huVGV5jXYJwbCsmBsOGYWA==} dependencies: '@types/jsonfile': 6.1.1 - '@types/node': 20.4.1 + '@types/node': 20.4.2 dev: true /@types/fs-extra@9.0.13: resolution: {integrity: sha512-nEnwB++1u5lVDM2UI4c1+5R+FYaKfaAzS4OococimjVm3nQw3TuzH5UNsocrcTBbhnerblyHj4A49qXbIiZdpA==} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 dev: true /@types/glob@7.2.0: resolution: {integrity: sha512-ZUxbzKl0IfJILTS6t7ip5fQQM/J3TJYubDm3nMbgubNNYS62eXeUpoLUC8/7fJNiFYHTrGPQn7hspDUzIHX3UA==} dependencies: '@types/minimatch': 5.1.1 - '@types/node': 20.4.1 + '@types/node': 20.4.2 dev: true /@types/glob@8.0.0: resolution: {integrity: sha512-l6NQsDDyQUVeoTynNpC9uRvCUint/gSUXQA2euwmTuWGvPY5LSDUu6tkCtJB2SvGQlJQzLaKqcGZP4//7EDveA==} dependencies: '@types/minimatch': 5.1.1 - '@types/node': 20.4.1 + '@types/node': 20.4.2 dev: true /@types/graceful-fs@4.1.5: resolution: {integrity: sha512-anKkLmZZ+xm4p8JWBf4hElkM4XR+EZeA2M9BAkkTldmcyDY4mbdIJnRghDJH3Ov5ooY7/UAoENtmdMSkaAd7Cw==} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 dev: true /@types/hast@2.3.4: @@ -8788,7 +8788,7 @@ packages: /@types/jsdom@21.1.1: resolution: {integrity: sha512-cZFuoVLtzKP3gmq9eNosUL1R50U+USkbLtUQ1bYVgl/lKp0FZM7Cq4aIHAL8oIvQ17uSHi7jXPtfDOdjPwBE7A==} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 '@types/tough-cookie': 4.0.2 parse5: 7.1.2 dev: true @@ -8800,7 +8800,7 @@ packages: /@types/jsonfile@6.1.1: resolution: {integrity: sha512-GSgiRCVeapDN+3pqA35IkQwasaCh/0YFH5dEF6S88iDvEn901DjOeH3/QPY+XYP1DFzDZPvIvfeEgk+7br5png==} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 dev: true /@types/lodash@4.14.195: @@ -8834,7 +8834,7 @@ packages: /@types/node-fetch@2.6.2: resolution: {integrity: sha512-DHqhlq5jeESLy19TYhLakJ07kNumXWjcDdxXsLUMJZ6ue8VZJj4kLPQVE/2mdHh3xZziNF1xppu5lwmS53HR+A==} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 form-data: 3.0.1 dev: true @@ -8853,8 +8853,8 @@ packages: resolution: {integrity: sha512-46yIhxSe5xEaJZXWdIBP7GU4HDTG8/eo0qd9atdiL+lFpA03y8KS+lkTN834TWJj5767GbWv4n/P6efyTFt1Dw==} dev: false - /@types/node@20.4.1: - resolution: {integrity: sha512-JIzsAvJeA/5iY6Y/OxZbv1lUcc8dNSE77lb2gnBH+/PJ3lFR1Ccvgwl5JWnHAkNHcRsT0TbpVOsiMKZ1F/yyJg==} + /@types/node@20.4.2: + resolution: {integrity: sha512-Dd0BYtWgnWJKwO1jkmTrzofjK2QXXcai0dmtzvIBhcA+RsG5h8R3xlyta0kGOZRNfL9GuRtb1knmPEhQrePCEw==} dev: true /@types/normalize-package-data@2.4.1: @@ -8883,7 +8883,7 @@ packages: /@types/prompts@2.4.4: resolution: {integrity: sha512-p5N9uoTH76lLvSAaYSZtBCdEXzpOOufsRjnhjVSrZGXikVGHX9+cc9ERtHRV4hvBKHyZb1bg4K+56Bd2TqUn4A==} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 kleur: 3.0.3 dev: true @@ -8907,19 +8907,19 @@ packages: /@types/react-dom@18.0.6: resolution: {integrity: sha512-/5OFZgfIPSwy+YuIBP/FgJnQnsxhZhjjrnxudMddeblOouIodEQ75X14Rr4wGSG/bknL+Omy9iWlLo1u/9GzAA==} dependencies: - '@types/react': 18.2.14 + '@types/react': 18.2.15 dev: true /@types/react-dom@18.0.8: resolution: {integrity: sha512-C3GYO0HLaOkk9dDAz3Dl4sbe4AKUGTCfFIZsz3n/82dPNN8Du533HzKatDxeUYWu24wJgMP1xICqkWk1YOLOIw==} dependencies: - '@types/react': 18.2.14 + '@types/react': 18.2.15 dev: true /@types/react-is@17.0.3: resolution: {integrity: sha512-aBTIWg1emtu95bLTLx0cpkxwGW3ueZv71nE2YFBpL8k/z5czEW8yYpOo8Dp+UUAFAtKwNaOsh/ioSeQnWlZcfw==} dependencies: - '@types/react': 18.2.14 + '@types/react': 18.2.15 dev: false /@types/react-test-renderer@17.0.2: @@ -8931,7 +8931,7 @@ packages: /@types/react-transition-group@4.4.5: resolution: {integrity: sha512-juKD/eiSM3/xZYzjuzH6ZwpP+/lejltmiS3QEzV/vmb/Q8+HfDmxu+Baga8UEMGBqV88Nbg4l2hY/K2DkyaLLA==} dependencies: - '@types/react': 18.2.14 + '@types/react': 18.2.15 dev: false /@types/react@17.0.49: @@ -8950,8 +8950,8 @@ packages: csstype: 3.1.0 dev: true - /@types/react@18.2.14: - resolution: {integrity: sha512-A0zjq+QN/O0Kpe30hA1GidzyFjatVvrpIvWLxD+xv67Vt91TWWgco9IvrJBkeyHm1trGaFS/FSGqPlhyeZRm0g==} + /@types/react@18.2.15: + resolution: {integrity: sha512-oEjE7TQt1fFTFSbf8kkNuc798ahTUzn3Le67/PWjE8MAfYAD/qB7O8hSTcromLFqHCt9bcdOg5GXMokzTjJ5SA==} dependencies: '@types/prop-types': 15.7.5 '@types/scheduler': 0.16.2 @@ -8960,7 +8960,7 @@ packages: /@types/resolve@1.17.1: resolution: {integrity: sha512-yy7HuzQhj0dhGpD8RLXSZWEkLsV9ibvxvi6EiJ3bkqLAO1RGo0WbkWQiwpRlSFymTJRz0d3k5LM3kkx8ArDbLw==} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 dev: true /@types/resolve@1.20.2: @@ -8977,7 +8977,7 @@ packages: /@types/set-cookie-parser@2.4.2: resolution: {integrity: sha512-fBZgytwhYAUkj/jC/FAV4RQ5EerRup1YQsXQCh8rZfiHkc4UahC192oH0smGwsXol3cL3A5oETuAHeQHmhXM4w==} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 dev: true /@types/sinonjs__fake-timers@8.1.1: @@ -9019,7 +9019,7 @@ packages: /@types/through@0.0.30: resolution: {integrity: sha512-FvnCJljyxhPM3gkRgWmxmDZyAQSiBQQWLI0A0VFL0K7W1oRUrPJSqNO0NvTnLkBcotdlp3lKvaT0JrnyRDkzOg==} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 dev: true /@types/tough-cookie@4.0.2: @@ -9057,7 +9057,7 @@ packages: /@types/webpack-sources@3.2.0: resolution: {integrity: sha512-Ft7YH3lEVRQ6ls8k4Ff1oB4jN6oy/XmU6tQISKdhfh+1mR+viZFphS6WL0IrtDOzvefmJg5a0s7ZQoRXwqTEFg==} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 '@types/source-list-map': 0.1.2 source-map: 0.7.4 dev: true @@ -9065,7 +9065,7 @@ packages: /@types/webpack@4.41.32: resolution: {integrity: sha512-cb+0ioil/7oz5//7tZUSwbrSAN/NWHrQylz5cW8G0dWTcF/g+/dSdMlKVZspBYuMAN1+WnwHrkxiRrLcwd0Heg==} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 '@types/tapable': 1.0.8 '@types/uglify-js': 3.17.0 '@types/webpack-sources': 3.2.0 @@ -9080,7 +9080,7 @@ packages: /@types/ws@8.5.5: resolution: {integrity: sha512-lwhs8hktwxSjf9UaZ9tG5M03PGogvFaH8gUgLNbN9HKIg0dvv6q+gkSuJ8HN4/VbyxkuLzCjlN7GquQ0gUJfIg==} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 dev: true /@types/yargs-parser@21.0.0: @@ -9109,7 +9109,7 @@ packages: resolution: {integrity: sha512-Cn6WYCm0tXv8p6k+A8PvbDG763EDpBoTzHdA+Q/MF6H3sapGjCm9NzoaJncJS9tUKSuCoDs9XHxYYsQDgxR6kw==} requiresBuild: true dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 dev: true optional: true @@ -9536,7 +9536,7 @@ packages: '@babel/plugin-transform-react-jsx-self': 7.22.5(@babel/core@7.22.5) '@babel/plugin-transform-react-jsx-source': 7.22.5(@babel/core@7.22.5) react-refresh: 0.14.0 - vite: 4.3.9(@types/node@20.4.1) + vite: 4.3.9(@types/node@20.4.2) transitivePeerDependencies: - supports-color dev: true @@ -10036,14 +10036,14 @@ packages: resolution: {integrity: sha512-VZ1WFHTNKjR8Ga97TtV2SZM6fvRjWbYI2i/f4pJB4PtusorKvONAMJf2LQcUBIyzbVobqr7KSrcjmSwRolI+yw==} engines: {node: ^16.13 || >=18} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 dev: true /@wdio/types@8.10.4: resolution: {integrity: sha512-aLJ1QQW+hhALeRK3bvMLjIrlUVyhOs3Od+91pR4Z4pLwyeNG1bJZCJRD5bAJK/mm7CnFa0NsdixPS9jJxZcRrw==} engines: {node: ^16.13 || >=18} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 dev: true /@wdio/utils@8.12.1: @@ -12016,7 +12016,7 @@ packages: engines: {node: '>=12.13.0'} hasBin: true dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 escape-string-regexp: 4.0.0 is-wsl: 2.2.0 lighthouse-logger: 1.3.0 @@ -13313,7 +13313,7 @@ packages: resolution: {integrity: sha512-R72raQLN1lDSqbr2DVj9SRh07JRyojzmrcLa33VBa2nw3cf5ZyHOHe0DgxlJ/5c2Dfs1+wGNJy16gWKGBq+xgg==} engines: {node: ^16.13 || >=18} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 '@wdio/config': 8.12.1 '@wdio/logger': 8.11.0 '@wdio/protocols': 8.11.0 @@ -17307,7 +17307,7 @@ packages: '@jest/environment': 27.5.1 '@jest/test-result': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.1 + '@types/node': 20.4.2 chalk: 4.1.2 co: 4.6.0 dedent: 0.7.0 @@ -17443,7 +17443,7 @@ packages: '@jest/environment': 27.5.1 '@jest/fake-timers': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.1 + '@types/node': 20.4.2 jest-mock: 27.5.1 jest-util: 27.5.1 jsdom: 16.7.0 @@ -17461,7 +17461,7 @@ packages: '@jest/environment': 27.5.1 '@jest/fake-timers': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.1 + '@types/node': 20.4.2 jest-mock: 27.5.1 jest-util: 27.5.1 dev: true @@ -17482,7 +17482,7 @@ packages: dependencies: '@jest/types': 26.6.2 '@types/graceful-fs': 4.1.5 - '@types/node': 20.4.1 + '@types/node': 20.4.2 anymatch: 3.1.2 fb-watchman: 2.0.1 graceful-fs: 4.2.10 @@ -17505,7 +17505,7 @@ packages: dependencies: '@jest/types': 27.5.1 '@types/graceful-fs': 4.1.5 - '@types/node': 20.4.1 + '@types/node': 20.4.2 anymatch: 3.1.2 fb-watchman: 2.0.1 graceful-fs: 4.2.10 @@ -17545,7 +17545,7 @@ packages: '@jest/source-map': 27.5.1 '@jest/test-result': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.1 + '@types/node': 20.4.2 chalk: 4.1.2 co: 4.6.0 expect: 27.5.1 @@ -17625,7 +17625,7 @@ packages: engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: '@jest/types': 27.5.1 - '@types/node': 20.4.1 + '@types/node': 20.4.2 dev: true /jest-pnp-resolver@1.2.3(jest-resolve@27.5.1): @@ -17686,7 +17686,7 @@ packages: '@jest/test-result': 27.5.1 '@jest/transform': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.1 + '@types/node': 20.4.2 chalk: 4.1.2 emittery: 0.8.1 graceful-fs: 4.2.10 @@ -17743,7 +17743,7 @@ packages: resolution: {integrity: sha512-S5wqyz0DXnNJPd/xfIzZ5Xnp1HrJWBczg8mMfMpN78OJ5eDxXyf+Ygld9wX1DnUWbIbhM1YDY95NjR4CBXkb2g==} engines: {node: '>= 10.14.2'} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 graceful-fs: 4.2.10 dev: true @@ -17751,7 +17751,7 @@ packages: resolution: {integrity: sha512-jZCyo6iIxO1aqUxpuBlwTDMkzOAJS4a3eYz3YzgxxVQFwLeSA7Jfq5cbqCY+JLvTDrWirgusI/0KwxKMgrdf7w==} engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 graceful-fs: 4.2.10 dev: true @@ -17790,7 +17790,7 @@ packages: engines: {node: '>= 10.14.2'} dependencies: '@jest/types': 26.6.2 - '@types/node': 20.4.1 + '@types/node': 20.4.2 chalk: 4.1.2 graceful-fs: 4.2.10 is-ci: 2.0.0 @@ -17802,7 +17802,7 @@ packages: engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: '@jest/types': 27.5.1 - '@types/node': 20.4.1 + '@types/node': 20.4.2 chalk: 4.1.2 ci-info: 3.8.0 graceful-fs: 4.2.10 @@ -17814,7 +17814,7 @@ packages: engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: '@jest/types': 29.0.1 - '@types/node': 20.4.1 + '@types/node': 20.4.2 chalk: 4.1.2 ci-info: 3.7.0 graceful-fs: 4.2.10 @@ -17839,7 +17839,7 @@ packages: dependencies: '@jest/test-result': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.1 + '@types/node': 20.4.2 ansi-escapes: 4.3.2 chalk: 4.1.2 jest-util: 27.5.1 @@ -17850,7 +17850,7 @@ packages: resolution: {integrity: sha512-KWYVV1c4i+jbMpaBC+U++4Va0cp8OisU185o73T1vo99hqi7w8tSJfUXYswwqqrjzwxa6KpRK54WhPvwf5w6PQ==} engines: {node: '>= 10.13.0'} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 merge-stream: 2.0.0 supports-color: 7.2.0 dev: true @@ -17859,7 +17859,7 @@ packages: resolution: {integrity: sha512-7vuh85V5cdDofPyxn58nrPjBktZo0u9x1g8WtjQol+jZDaE+fhN+cIvTj11GndBnMnyfrUOG1sZQxCdjKh+DKg==} engines: {node: '>= 10.13.0'} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 merge-stream: 2.0.0 supports-color: 8.1.1 dev: true @@ -24400,16 +24400,16 @@ packages: '@nuxt/kit': optional: true dependencies: - '@antfu/utils': 0.7.4 + '@antfu/utils': 0.7.5 '@rollup/pluginutils': 5.0.2(rollup@3.26.0) chokidar: 3.5.3 debug: 4.3.4(supports-color@8.1.1) fast-glob: 3.3.0 local-pkg: 0.4.3 - magic-string: 0.30.0 - minimatch: 9.0.1 + magic-string: 0.30.1 + minimatch: 9.0.3 resolve: 1.22.2 - unplugin: 1.3.1 + unplugin: 1.3.2 vue: 3.3.4 transitivePeerDependencies: - rollup @@ -24793,7 +24793,7 @@ packages: fsevents: 2.3.2 dev: false - /vite@4.3.9(@types/node@20.4.1): + /vite@4.3.9(@types/node@20.4.2): resolution: {integrity: sha512-qsTNZjO9NoJNW7KnOrgYwczm0WctJ8m/yqYAMAK9Lxt4SoySUfS5S8ia9K7JHpa3KEeMfyF8LoJ3c5NeBJy6pg==} engines: {node: ^14.18.0 || >=16.0.0} hasBin: true @@ -24818,7 +24818,7 @@ packages: terser: optional: true dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 esbuild: 0.17.18 postcss: 8.4.24 rollup: 3.23.0 @@ -25130,7 +25130,7 @@ packages: resolution: {integrity: sha512-Ca+MUYUXfl5gsnX40xAIUgfoa76qQsfX7REGFzMl09Cb7vHKtM17bEOGDaTbXIX4kbkXylyUSAuBpe3gCtDDKg==} engines: {node: ^16.13 || >=18} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 '@types/ws': 8.5.5 '@wdio/config': 8.12.1 '@wdio/logger': 8.11.0 @@ -25150,7 +25150,7 @@ packages: resolution: {integrity: sha512-lW0Qo3fy64cVbYWWAZbXxLIOK0pbTARgpY89J+0Sr6zh2K2NKtd/0D11k3WfMeYxd0b0he7E7XC1b6M6w4h75A==} engines: {node: ^16.13 || >=18} dependencies: - '@types/node': 20.4.1 + '@types/node': 20.4.2 '@wdio/config': 8.12.1 '@wdio/logger': 8.11.0 '@wdio/protocols': 8.11.0 @@ -25168,7 +25168,7 @@ packages: is-plain-obj: 4.1.0 lodash.clonedeep: 4.5.0 lodash.zip: 4.2.0 - minimatch: 9.0.1 + minimatch: 9.0.3 puppeteer-core: 20.3.0(typescript@5.1.6) query-selector-shadow-dom: 1.0.1 resq: 1.11.0 diff --git a/test/core/test/happy-dom.test.ts b/test/core/test/happy-dom.test.ts index e56e30b0f0a7..bef420b134a8 100644 --- a/test/core/test/happy-dom.test.ts +++ b/test/core/test/happy-dom.test.ts @@ -110,9 +110,8 @@ it('globals are the same', () => { expect(window.Blob).toBe(globalThis.Blob) expect(window.globalThis.Blob).toBe(globalThis.Blob) expect(Blob).toBe(globalThis.Blob) - // TODO: vm - // expect(document.defaultView).toBe(window) - // expect(document.defaultView).toBe(globalThis) - // const el = document.createElement('div') - // expect(el.ownerDocument.defaultView).toBe(globalThis) + expect(document.defaultView).toBe(window) + expect(document.defaultView).toBe(globalThis) + const el = document.createElement('div') + expect(el.ownerDocument.defaultView).toBe(globalThis) }) From 553663a8fed0b0c9cb6f52b9da2e7db5303e4b48 Mon Sep 17 00:00:00 2001 From: Vladimir Date: Wed, 19 Jul 2023 14:42:47 +0200 Subject: [PATCH 67/87] Apply suggestions from code review Co-authored-by: Anjorin Damilare --- docs/config/index.md | 6 +++--- docs/guide/cli.md | 2 +- packages/vitest/src/node/cli.ts | 2 +- 3 files changed, 5 insertions(+), 5 deletions(-) diff --git a/docs/config/index.md b/docs/config/index.md index 089974a1c798..ee35d5ecf2dd 100644 --- a/docs/config/index.md +++ b/docs/config/index.md @@ -551,7 +551,7 @@ By providing an object instead of a string you can define individual outputs whe Run tests using [VM context](https://nodejs.org/api/vm.html) (inside a sandboxed environment) in a worker pool. -This makes tests run faster, but VM module is unstable when running [ESM code](https://github.com/nodejs/node/issues/37648). Your tests will [leak memory](https://github.com/nodejs/node/issues/33439) - to battle that, consider manually editing [`experimentalVmWorkerMemoryLimit`](#experimentalvmworkermemorylimit) value. +This makes tests run faster, but the VM module is unstable when running [ESM code](https://github.com/nodejs/node/issues/37648). Your tests will [leak memory](https://github.com/nodejs/node/issues/33439) - to battle that, consider manually editing [`experimentalVmWorkerMemoryLimit`](#experimentalvmworkermemorylimit) value. ::: warning Running code in a sandbox has some advantages (faster tests), but also comes with a number of disadvantages. @@ -567,7 +567,7 @@ catch (err) { } ``` -- Importing ES modules caches them indefinetly which introduces memory leak if you have a lot of contexts (or tests). There is no API in Node.js that clears that cache. +- Importing ES modules cache them indefinitely which introduces memory leaks if you have a lot of contexts (or tests). There is no API in Node.js that clears that cache. - Accessing globals [takes longer](https://github.com/nodejs/node/issues/31658) in a sandbox environment. Please, be aware of these issues when using this option. Vitest team cannot fix any of the issues on our side. @@ -580,7 +580,7 @@ Please, be aware of these issues when using this option. Vitest team cannot fix - **Default:** `1 / CPU Cores` - **Version:** Since Vitest 0.34.0 -Specifies the memory limit for workers before they are recycled. This value heavily depends on your environment, so it's better to specify it manually instead of relying on default. +Specifies the memory limit for workers before they are recycled. This value heavily depends on your environment, so it's better to specify it manually instead of relying on the default. This option only affects workers that run tests in [VM context](#experimentalvmthreads). diff --git a/docs/guide/cli.md b/docs/guide/cli.md index 30dc90a4a678..818f793d5e9e 100644 --- a/docs/guide/cli.md +++ b/docs/guide/cli.md @@ -72,7 +72,7 @@ Run only [benchmark](https://vitest.dev/guide/features.html#benchmarking-experim | `--threads` | Enable Threads (default: `true`) | | `--single-thread` | Run tests inside a single thread, requires --threads (default: `false`) | | `--experimental-vm-threads` | Run tests in a worker pool using VM isolation (default: `false`) | -| `--experimental-vm-worker-memory-limit` | Set maximum allowed memory for a worker. When reached, new worker will be created instead | +| `--experimental-vm-worker-memory-limit` | Set the maximum allowed memory for a worker. When reached, a new worker will be created instead | | `--silent` | Silent console output from tests | | `--isolate` | Isolate environment for each test file (default: `true`) | | `--reporter ` | Select reporter: `default`, `verbose`, `dot`, `junit`, `json`, or a path to a custom reporter | diff --git a/packages/vitest/src/node/cli.ts b/packages/vitest/src/node/cli.ts index b159c8b76d5d..25872408d6b7 100644 --- a/packages/vitest/src/node/cli.ts +++ b/packages/vitest/src/node/cli.ts @@ -24,7 +24,7 @@ cli .option('--threads', 'Enabled threads (default: true)') .option('--single-thread', 'Run tests inside a single thread, requires --threads (default: false)') .option('--experimental-vm-threads', 'Run tests in a worker pool using VM isolation (default: false)') - .option('--experimental-vm-worker-memory-limit', 'Set maximum allowed memory for a worker. When reached, new worker will be created instead') + .option('--experimental-vm-worker-memory-limit', 'Set the maximum allowed memory for a worker. When reached, a new worker will be created instead') .option('--silent', 'Silent console output from tests') .option('--hideSkippedTests', 'Hide logs for skipped tests') .option('--isolate', 'Isolate environment for each test file (default: true)') From 4ccbd5c97a16ea0bc8307024251093beccd040f2 Mon Sep 17 00:00:00 2001 From: Vladimir Date: Wed, 19 Jul 2023 14:45:37 +0200 Subject: [PATCH 68/87] Update docs/config/index.md Co-authored-by: Anjorin Damilare --- docs/config/index.md | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/docs/config/index.md b/docs/config/index.md index ee35d5ecf2dd..3a2af50c0316 100644 --- a/docs/config/index.md +++ b/docs/config/index.md @@ -556,7 +556,7 @@ This makes tests run faster, but the VM module is unstable when running [ESM cod ::: warning Running code in a sandbox has some advantages (faster tests), but also comes with a number of disadvantages. -- Globals from native modules (`fs`, `path`, etc) are different from the globals in your test environment. It means that error thrown by any of the native modules will be different from the one you are using in your code: +- The globals within native modules, such as (`fs`, `path`, etc), differ from the globals present in your test environment. As a result, any error thrown by these native modules will reference a different Error constructor compared to the one used in your code: ```ts try { From 7c045b481052980f1d9fe3c0f1563ff24a594c5a Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Wed, 19 Jul 2023 15:00:40 +0200 Subject: [PATCH 69/87] chore: ignore version --- packages/vitest/package.json | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/packages/vitest/package.json b/packages/vitest/package.json index a91f6c632e92..9cc26025a1a8 100644 --- a/packages/vitest/package.json +++ b/packages/vitest/package.json @@ -1,7 +1,7 @@ { "name": "vitest", "type": "module", - "version": "0.34.0", + "version": "0.33.0", "description": "A blazing fast unit test framework powered by Vite", "author": "Anthony Fu ", "license": "MIT", From dfed0c3bd3d6907cda7bb66867768b7c343e567f Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Wed, 19 Jul 2023 15:33:53 +0200 Subject: [PATCH 70/87] chore: cleanup --- packages/vitest/src/integrations/env/happy-dom.ts | 6 ------ packages/web-worker/package.json | 2 +- pnpm-lock.yaml | 2 +- test/core/test/happy-dom.test.ts | 3 +++ 4 files changed, 5 insertions(+), 8 deletions(-) diff --git a/packages/vitest/src/integrations/env/happy-dom.ts b/packages/vitest/src/integrations/env/happy-dom.ts index e57cdb678957..3df3b2bd3b5b 100644 --- a/packages/vitest/src/integrations/env/happy-dom.ts +++ b/packages/vitest/src/integrations/env/happy-dom.ts @@ -9,12 +9,6 @@ export default ({ const { Window } = await importModule('happy-dom') as typeof import('happy-dom') const win = new Window() as any - win.global = win.window - Object.defineProperty(win.document, 'defaultView', { - value: win.window, - configurable: true, - }) - // TODO: browser doesn't expose Buffer, but a lot of dependencies use it win.Buffer = Buffer win.Uint8Array = Uint8Array diff --git a/packages/web-worker/package.json b/packages/web-worker/package.json index dd5f48322b97..b67b6459eb2f 100644 --- a/packages/web-worker/package.json +++ b/packages/web-worker/package.json @@ -41,7 +41,7 @@ "typecheck": "tsc --noEmit" }, "peerDependencies": { - "vitest": ">=0.34.0" + "vitest": ">=0.33.0" }, "dependencies": { "debug": "^4.3.4" diff --git a/pnpm-lock.yaml b/pnpm-lock.yaml index b667ba0e5aa6..8708dfa5bf68 100644 --- a/pnpm-lock.yaml +++ b/pnpm-lock.yaml @@ -1437,7 +1437,7 @@ importers: specifier: ^4.3.4 version: 4.3.4(supports-color@8.1.1) vitest: - specifier: '>=0.34.0' + specifier: '>=0.33.0' version: link:../vitest devDependencies: '@types/debug': diff --git a/test/core/test/happy-dom.test.ts b/test/core/test/happy-dom.test.ts index bef420b134a8..d234ec8ae016 100644 --- a/test/core/test/happy-dom.test.ts +++ b/test/core/test/happy-dom.test.ts @@ -110,6 +110,9 @@ it('globals are the same', () => { expect(window.Blob).toBe(globalThis.Blob) expect(window.globalThis.Blob).toBe(globalThis.Blob) expect(Blob).toBe(globalThis.Blob) +}) + +it.skipIf(import.meta.env.VITEST_VM_POOL)('default view references global object', () => { expect(document.defaultView).toBe(window) expect(document.defaultView).toBe(globalThis) const el = document.createElement('div') From f3db7d63a3cec81d04e3cc1fd8f9754f08ea4161 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Fri, 28 Jul 2023 17:03:24 +0200 Subject: [PATCH 71/87] chore: cleanup --- docs/config/index.md | 2 +- pnpm-lock.yaml | 267 +++++++++++++++++++++++++------------------ 2 files changed, 155 insertions(+), 114 deletions(-) diff --git a/docs/config/index.md b/docs/config/index.md index 3a2af50c0316..324ab4254a3e 100644 --- a/docs/config/index.md +++ b/docs/config/index.md @@ -563,7 +563,7 @@ try { fs.writeFile('/doesnt exist') } catch (err) { - consoel.log(err instanceof Error) // false + console.log(err instanceof Error) // false } ``` diff --git a/pnpm-lock.yaml b/pnpm-lock.yaml index 8708dfa5bf68..941721e0c831 100644 --- a/pnpm-lock.yaml +++ b/pnpm-lock.yaml @@ -325,10 +325,10 @@ importers: version: 13.3.0(react-dom@18.0.0)(react@18.0.0) '@types/node': specifier: latest - version: 20.4.2 + version: 20.4.5 '@types/react': specifier: latest - version: 18.2.15 + version: 18.2.17 '@vitejs/plugin-react': specifier: latest version: 4.0.3(vite@4.3.9) @@ -734,7 +734,7 @@ importers: devDependencies: '@sveltejs/vite-plugin-svelte': specifier: latest - version: 2.4.2(svelte@4.0.5)(vite@4.3.9) + version: 2.4.3(svelte@4.0.5)(vite@4.3.9) '@testing-library/svelte': specifier: ^4.0.3 version: 4.0.3(svelte@4.0.5) @@ -932,11 +932,11 @@ importers: specifier: ^3.2.0 version: 3.2.0 istanbul-lib-instrument: - specifier: ^5.2.1 - version: 5.2.1 + specifier: ^6.0.0 + version: 6.0.0 istanbul-lib-report: - specifier: ^3.0.0 - version: 3.0.0 + specifier: ^3.0.1 + version: 3.0.1 istanbul-lib-source-maps: specifier: ^4.0.1 version: 4.0.1 @@ -981,8 +981,8 @@ importers: specifier: ^3.2.0 version: 3.2.0 istanbul-lib-report: - specifier: ^3.0.0 - version: 3.0.0 + specifier: ^3.0.1 + version: 3.0.1 istanbul-lib-source-maps: specifier: ^4.0.1 version: 4.0.1 @@ -1206,6 +1206,10 @@ importers: pretty-format: specifier: ^29.5.0 version: 29.5.0 + devDependencies: + '@jridgewell/trace-mapping': + specifier: ^0.3.18 + version: 0.3.18 packages/vite-node: dependencies: @@ -1328,9 +1332,6 @@ importers: '@edge-runtime/vm': specifier: 3.0.3 version: 3.0.3 - '@jridgewell/trace-mapping': - specifier: ^0.3.18 - version: 0.3.18 '@sinonjs/fake-timers': specifier: ^11.0.0 version: 11.0.0 @@ -2111,6 +2112,7 @@ packages: dependencies: '@jridgewell/gen-mapping': 0.1.1 '@jridgewell/trace-mapping': 0.3.18 + dev: true /@ampproject/remapping@2.2.1: resolution: {integrity: sha512-lFMjJTrFL3j7L9yBxwYfCq2k6qqwHyzuUl/XBnif78PWTJYyL/dfowQHWE3sp6U6ZzqWiiIZnpTMO96zhkjwtg==} @@ -2283,6 +2285,7 @@ packages: engines: {node: '>=6.9.0'} dependencies: '@babel/highlight': 7.22.5 + dev: true /@babel/code-frame@7.22.5: resolution: {integrity: sha512-Xmwn266vad+6DAqEB2A6V/CcZVp62BbwVmcOJc2RPuwih1kw02TjQvWVWlcKGbBPd+8/0V5DEkOcizRGYsspYQ==} @@ -2339,6 +2342,7 @@ packages: semver: 6.3.0 transitivePeerDependencies: - supports-color + dev: true /@babel/core@7.20.5: resolution: {integrity: sha512-UdOWmk4pNWTm/4DlPUl/Pt4Gz4rcEMb7CY0Y3eJl5Yz1vI8ZJGmHWaVE55LoxRjdpx0z259GE9U5STA9atUinQ==} @@ -2392,6 +2396,7 @@ packages: '@babel/types': 7.22.5 '@jridgewell/gen-mapping': 0.3.2 jsesc: 2.5.2 + dev: true /@babel/generator@7.22.5: resolution: {integrity: sha512-+lcUbnTRhd0jOewtFSedLyiPsD5tswKkbgcezOqqWFUVNEwoUTlpPOBmvhG7OXWLR4jMdv0czPGH5XbflnD1EA==} @@ -2428,6 +2433,7 @@ packages: '@babel/helper-validator-option': 7.22.5 browserslist: 4.21.3 semver: 6.3.0 + dev: true /@babel/helper-compilation-targets@7.22.5(@babel/core@7.18.13): resolution: {integrity: sha512-Ji+ywpHeuqxB8WDxraCiqR0xfhYjiDE/e6k7FuIaANnoOFxAHskHChz4vA1mJC9Lbm01s1PVAGhQY4FUKSkGZw==} @@ -2657,6 +2663,7 @@ packages: '@babel/types': 7.22.5 transitivePeerDependencies: - supports-color + dev: true /@babel/helper-module-transforms@7.22.5: resolution: {integrity: sha512-+hGKDt/Ze8GFExiVHno/2dvG5IdstpzCq0y4Qc9OJ25D4q3pKfiIP/4Vp3/JvhDkLKsDK2api3q3fpIgiIF5bw==} @@ -2784,6 +2791,7 @@ packages: '@babel/types': 7.22.5 transitivePeerDependencies: - supports-color + dev: true /@babel/helpers@7.22.5: resolution: {integrity: sha512-pSXRmfE1vzcUIDFQcSGA5Mr+GxBV9oiRKDuDxXvWQQBCh8HoIjs/2DlDB7H8smac1IVrB9/xdXj2N3Wol9Cr+Q==} @@ -2809,6 +2817,7 @@ packages: hasBin: true dependencies: '@babel/types': 7.22.5 + dev: true /@babel/parser@7.22.5: resolution: {integrity: sha512-DFZMC9LJUG9PLOclRC32G63UXwzqS2koQC8dkx+PLdmt1xSePYpbT/NbsrJy8Q/muXz7o/h/d4A7Fuyixm559Q==} @@ -4854,6 +4863,7 @@ packages: '@babel/code-frame': 7.22.5 '@babel/parser': 7.22.5 '@babel/types': 7.22.5 + dev: true /@babel/template@7.22.5: resolution: {integrity: sha512-X7yV7eiwAxdj9k94NEylvbVHLiVG1nvzCV2EAowhxLTwODV1jl9UzZ48leOC0sH7OnuHrIkllaBgneUykIcZaw==} @@ -4879,6 +4889,7 @@ packages: globals: 11.12.0 transitivePeerDependencies: - supports-color + dev: true /@babel/traverse@7.22.5: resolution: {integrity: sha512-7DuIjPgERaNo6r+PZwItpjCZEa5vyw4eJGufeLxrPdBXBoLcCJCIasvK6pK/9DVNrLZTLFhUGqaC6X/PA007TQ==} @@ -4904,6 +4915,7 @@ packages: '@babel/helper-string-parser': 7.22.5 '@babel/helper-validator-identifier': 7.22.5 to-fast-properties: 2.0.0 + dev: true /@babel/types@7.22.5: resolution: {integrity: sha512-zo3MIHGOkPOfoRXitsgHLjEXmlDaD/5KU1Uzuc9GNiZPhSqVxVRtxuPaSBZDsYZ9qV88AjtMtWW7ww98loJ9KA==} @@ -5842,7 +5854,7 @@ packages: engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: '@jest/types': 27.5.1 - '@types/node': 20.4.2 + '@types/node': 20.4.5 chalk: 4.1.2 jest-message-util: 27.5.1 jest-util: 27.5.1 @@ -5863,7 +5875,7 @@ packages: '@jest/test-result': 27.5.1 '@jest/transform': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.2 + '@types/node': 20.4.5 ansi-escapes: 4.3.2 chalk: 4.1.2 emittery: 0.8.1 @@ -5900,7 +5912,7 @@ packages: dependencies: '@jest/fake-timers': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.2 + '@types/node': 20.4.5 jest-mock: 27.5.1 dev: true @@ -5917,7 +5929,7 @@ packages: dependencies: '@jest/types': 27.5.1 '@sinonjs/fake-timers': 8.1.0 - '@types/node': 20.4.2 + '@types/node': 20.4.5 jest-message-util: 27.5.1 jest-mock: 27.5.1 jest-util: 27.5.1 @@ -5946,7 +5958,7 @@ packages: '@jest/test-result': 27.5.1 '@jest/transform': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.2 + '@types/node': 20.4.5 chalk: 4.1.2 collect-v8-coverage: 1.0.1 exit: 0.1.2 @@ -5954,7 +5966,7 @@ packages: graceful-fs: 4.2.10 istanbul-lib-coverage: 3.2.0 istanbul-lib-instrument: 5.2.1 - istanbul-lib-report: 3.0.0 + istanbul-lib-report: 3.0.1 istanbul-lib-source-maps: 4.0.1 istanbul-reports: 3.1.5 jest-haste-map: 27.5.1 @@ -6059,7 +6071,7 @@ packages: dependencies: '@types/istanbul-lib-coverage': 2.0.4 '@types/istanbul-reports': 3.0.1 - '@types/node': 20.4.2 + '@types/node': 20.4.5 '@types/yargs': 15.0.14 chalk: 4.1.2 dev: true @@ -6070,7 +6082,7 @@ packages: dependencies: '@types/istanbul-lib-coverage': 2.0.4 '@types/istanbul-reports': 3.0.1 - '@types/node': 20.4.2 + '@types/node': 20.4.5 '@types/yargs': 16.0.5 chalk: 4.1.2 dev: true @@ -6082,7 +6094,7 @@ packages: '@jest/schemas': 29.4.3 '@types/istanbul-lib-coverage': 2.0.4 '@types/istanbul-reports': 3.0.1 - '@types/node': 20.4.2 + '@types/node': 20.4.5 '@types/yargs': 17.0.12 chalk: 4.1.2 dev: true @@ -6107,6 +6119,7 @@ packages: dependencies: '@jridgewell/set-array': 1.1.2 '@jridgewell/sourcemap-codec': 1.4.15 + dev: true /@jridgewell/gen-mapping@0.3.2: resolution: {integrity: sha512-mh65xKQAzI6iBcFzwv28KVWSmCkdRBWoOh+bYQGW3+6OZvbbN3TqMGo5hqYxQniRcH9F2VZIoJCm4pa3BPDK/A==} @@ -6578,7 +6591,7 @@ packages: resolution: {integrity: sha512-8KG5RD0GVP4ydEzRn/I4BNDuxDtqVbOdm8675T49OIG/NGhaK0pjPX7ZcDlvKYbA+ulvVK3ztfcF4uBdOxuJbQ==} dependencies: '@gar/promisify': 1.1.3 - semver: 7.5.2 + semver: 7.5.4 dev: true /@npmcli/move-file@1.1.2: @@ -6605,7 +6618,7 @@ packages: engines: {node: '>=14'} hasBin: true dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 playwright-core: 1.28.0 dev: true @@ -8275,7 +8288,7 @@ packages: svelte: ^3.54.0 || ^4.0.0-next.0 vite: ^4.0.0 dependencies: - '@sveltejs/vite-plugin-svelte': 2.4.2(svelte@3.59.1)(vite@4.3.9) + '@sveltejs/vite-plugin-svelte': 2.4.3(svelte@3.59.1)(vite@4.3.9) '@types/cookie': 0.5.1 cookie: 0.5.0 devalue: 4.3.2 @@ -8294,7 +8307,7 @@ packages: - supports-color dev: true - /@sveltejs/vite-plugin-svelte-inspector@1.0.3(@sveltejs/vite-plugin-svelte@2.4.2)(svelte@3.59.1)(vite@4.3.9): + /@sveltejs/vite-plugin-svelte-inspector@1.0.3(@sveltejs/vite-plugin-svelte@2.4.3)(svelte@3.59.1)(vite@4.3.9): resolution: {integrity: sha512-Khdl5jmmPN6SUsVuqSXatKpQTMIifoQPDanaxC84m9JxIibWvSABJyHpyys0Z+1yYrxY5TTEQm+6elh0XCMaOA==} engines: {node: ^14.18.0 || >= 16} peerDependencies: @@ -8302,7 +8315,7 @@ packages: svelte: ^3.54.0 || ^4.0.0 vite: ^4.0.0 dependencies: - '@sveltejs/vite-plugin-svelte': 2.4.2(svelte@3.59.1)(vite@4.3.9) + '@sveltejs/vite-plugin-svelte': 2.4.3(svelte@3.59.1)(vite@4.3.9) debug: 4.3.4(supports-color@8.1.1) svelte: 3.59.1 vite: 4.3.9(@types/node@18.16.19) @@ -8310,7 +8323,7 @@ packages: - supports-color dev: true - /@sveltejs/vite-plugin-svelte-inspector@1.0.3(@sveltejs/vite-plugin-svelte@2.4.2)(svelte@4.0.5)(vite@4.3.9): + /@sveltejs/vite-plugin-svelte-inspector@1.0.3(@sveltejs/vite-plugin-svelte@2.4.3)(svelte@4.0.5)(vite@4.3.9): resolution: {integrity: sha512-Khdl5jmmPN6SUsVuqSXatKpQTMIifoQPDanaxC84m9JxIibWvSABJyHpyys0Z+1yYrxY5TTEQm+6elh0XCMaOA==} engines: {node: ^14.18.0 || >= 16} peerDependencies: @@ -8318,7 +8331,7 @@ packages: svelte: ^3.54.0 || ^4.0.0 vite: ^4.0.0 dependencies: - '@sveltejs/vite-plugin-svelte': 2.4.2(svelte@4.0.5)(vite@4.3.9) + '@sveltejs/vite-plugin-svelte': 2.4.3(svelte@4.0.5)(vite@4.3.9) debug: 4.3.4(supports-color@8.1.1) svelte: 4.0.5 vite: 4.3.9(@types/node@18.16.19) @@ -8326,14 +8339,14 @@ packages: - supports-color dev: true - /@sveltejs/vite-plugin-svelte@2.4.2(svelte@3.59.1)(vite@4.3.9): - resolution: {integrity: sha512-ePfcC48ftMKhkT0OFGdOyycYKnnkT6i/buzey+vHRTR/JpQvuPzzhf1PtKqCDQfJRgoPSN2vscXs6gLigx/zGw==} + /@sveltejs/vite-plugin-svelte@2.4.3(svelte@3.59.1)(vite@4.3.9): + resolution: {integrity: sha512-NY2h+B54KHZO3kDURTdARqthn6D4YSIebtfW75NvZ/fwyk4G+AJw3V/i0OBjyN4406Ht9yZcnNWMuRUFnDNNiA==} engines: {node: ^14.18.0 || >= 16} peerDependencies: svelte: ^3.54.0 || ^4.0.0 vite: ^4.0.0 dependencies: - '@sveltejs/vite-plugin-svelte-inspector': 1.0.3(@sveltejs/vite-plugin-svelte@2.4.2)(svelte@3.59.1)(vite@4.3.9) + '@sveltejs/vite-plugin-svelte-inspector': 1.0.3(@sveltejs/vite-plugin-svelte@2.4.3)(svelte@3.59.1)(vite@4.3.9) debug: 4.3.4(supports-color@8.1.1) deepmerge: 4.3.1 kleur: 4.1.5 @@ -8346,14 +8359,14 @@ packages: - supports-color dev: true - /@sveltejs/vite-plugin-svelte@2.4.2(svelte@4.0.5)(vite@4.3.9): - resolution: {integrity: sha512-ePfcC48ftMKhkT0OFGdOyycYKnnkT6i/buzey+vHRTR/JpQvuPzzhf1PtKqCDQfJRgoPSN2vscXs6gLigx/zGw==} + /@sveltejs/vite-plugin-svelte@2.4.3(svelte@4.0.5)(vite@4.3.9): + resolution: {integrity: sha512-NY2h+B54KHZO3kDURTdARqthn6D4YSIebtfW75NvZ/fwyk4G+AJw3V/i0OBjyN4406Ht9yZcnNWMuRUFnDNNiA==} engines: {node: ^14.18.0 || >= 16} peerDependencies: svelte: ^3.54.0 || ^4.0.0 vite: ^4.0.0 dependencies: - '@sveltejs/vite-plugin-svelte-inspector': 1.0.3(@sveltejs/vite-plugin-svelte@2.4.2)(svelte@4.0.5)(vite@4.3.9) + '@sveltejs/vite-plugin-svelte-inspector': 1.0.3(@sveltejs/vite-plugin-svelte@2.4.3)(svelte@4.0.5)(vite@4.3.9) debug: 4.3.4(supports-color@8.1.1) deepmerge: 4.3.1 kleur: 4.1.5 @@ -8620,7 +8633,7 @@ packages: /@types/cheerio@0.22.31: resolution: {integrity: sha512-Kt7Cdjjdi2XWSfrZ53v4Of0wG3ZcmaegFXjMmz9tfNrZSkzzo36G0AL1YqSdcIA78Etjt6E609pt5h1xnQkPUw==} dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 dev: true /@types/codemirror@5.60.8: @@ -8659,7 +8672,7 @@ packages: resolution: {integrity: sha512-xryQlOEIe1TduDWAOphR0ihfebKFSWOXpIsk+70JskCfRfW+xALdnJ0r1ZOTo85F9Qsjk6vtlU7edTYHbls9tA==} dependencies: '@types/cheerio': 0.22.31 - '@types/react': 18.2.15 + '@types/react': 18.2.17 dev: true /@types/eslint-scope@3.7.4: @@ -8690,33 +8703,33 @@ packages: resolution: {integrity: sha512-MxObHvNl4A69ofaTRU8DFqvgzzv8s9yRtaPPm5gud9HDNvpB3GPQFvNuTWAI59B9huVGV5jXYJwbCsmBsOGYWA==} dependencies: '@types/jsonfile': 6.1.1 - '@types/node': 20.4.2 + '@types/node': 20.4.5 dev: true /@types/fs-extra@9.0.13: resolution: {integrity: sha512-nEnwB++1u5lVDM2UI4c1+5R+FYaKfaAzS4OococimjVm3nQw3TuzH5UNsocrcTBbhnerblyHj4A49qXbIiZdpA==} dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 dev: true /@types/glob@7.2.0: resolution: {integrity: sha512-ZUxbzKl0IfJILTS6t7ip5fQQM/J3TJYubDm3nMbgubNNYS62eXeUpoLUC8/7fJNiFYHTrGPQn7hspDUzIHX3UA==} dependencies: '@types/minimatch': 5.1.1 - '@types/node': 20.4.2 + '@types/node': 20.4.5 dev: true /@types/glob@8.0.0: resolution: {integrity: sha512-l6NQsDDyQUVeoTynNpC9uRvCUint/gSUXQA2euwmTuWGvPY5LSDUu6tkCtJB2SvGQlJQzLaKqcGZP4//7EDveA==} dependencies: '@types/minimatch': 5.1.1 - '@types/node': 20.4.2 + '@types/node': 20.4.5 dev: true /@types/graceful-fs@4.1.5: resolution: {integrity: sha512-anKkLmZZ+xm4p8JWBf4hElkM4XR+EZeA2M9BAkkTldmcyDY4mbdIJnRghDJH3Ov5ooY7/UAoENtmdMSkaAd7Cw==} dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 dev: true /@types/hast@2.3.4: @@ -8788,7 +8801,7 @@ packages: /@types/jsdom@21.1.1: resolution: {integrity: sha512-cZFuoVLtzKP3gmq9eNosUL1R50U+USkbLtUQ1bYVgl/lKp0FZM7Cq4aIHAL8oIvQ17uSHi7jXPtfDOdjPwBE7A==} dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 '@types/tough-cookie': 4.0.2 parse5: 7.1.2 dev: true @@ -8800,7 +8813,7 @@ packages: /@types/jsonfile@6.1.1: resolution: {integrity: sha512-GSgiRCVeapDN+3pqA35IkQwasaCh/0YFH5dEF6S88iDvEn901DjOeH3/QPY+XYP1DFzDZPvIvfeEgk+7br5png==} dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 dev: true /@types/lodash@4.14.195: @@ -8834,7 +8847,7 @@ packages: /@types/node-fetch@2.6.2: resolution: {integrity: sha512-DHqhlq5jeESLy19TYhLakJ07kNumXWjcDdxXsLUMJZ6ue8VZJj4kLPQVE/2mdHh3xZziNF1xppu5lwmS53HR+A==} dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 form-data: 3.0.1 dev: true @@ -8853,8 +8866,8 @@ packages: resolution: {integrity: sha512-46yIhxSe5xEaJZXWdIBP7GU4HDTG8/eo0qd9atdiL+lFpA03y8KS+lkTN834TWJj5767GbWv4n/P6efyTFt1Dw==} dev: false - /@types/node@20.4.2: - resolution: {integrity: sha512-Dd0BYtWgnWJKwO1jkmTrzofjK2QXXcai0dmtzvIBhcA+RsG5h8R3xlyta0kGOZRNfL9GuRtb1knmPEhQrePCEw==} + /@types/node@20.4.5: + resolution: {integrity: sha512-rt40Nk13II9JwQBdeYqmbn2Q6IVTA5uPhvSO+JVqdXw/6/4glI6oR9ezty/A9Hg5u7JH4OmYmuQ+XvjKm0Datg==} dev: true /@types/normalize-package-data@2.4.1: @@ -8883,7 +8896,7 @@ packages: /@types/prompts@2.4.4: resolution: {integrity: sha512-p5N9uoTH76lLvSAaYSZtBCdEXzpOOufsRjnhjVSrZGXikVGHX9+cc9ERtHRV4hvBKHyZb1bg4K+56Bd2TqUn4A==} dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 kleur: 3.0.3 dev: true @@ -8907,19 +8920,19 @@ packages: /@types/react-dom@18.0.6: resolution: {integrity: sha512-/5OFZgfIPSwy+YuIBP/FgJnQnsxhZhjjrnxudMddeblOouIodEQ75X14Rr4wGSG/bknL+Omy9iWlLo1u/9GzAA==} dependencies: - '@types/react': 18.2.15 + '@types/react': 18.2.17 dev: true /@types/react-dom@18.0.8: resolution: {integrity: sha512-C3GYO0HLaOkk9dDAz3Dl4sbe4AKUGTCfFIZsz3n/82dPNN8Du533HzKatDxeUYWu24wJgMP1xICqkWk1YOLOIw==} dependencies: - '@types/react': 18.2.15 + '@types/react': 18.2.17 dev: true /@types/react-is@17.0.3: resolution: {integrity: sha512-aBTIWg1emtu95bLTLx0cpkxwGW3ueZv71nE2YFBpL8k/z5czEW8yYpOo8Dp+UUAFAtKwNaOsh/ioSeQnWlZcfw==} dependencies: - '@types/react': 18.2.15 + '@types/react': 18.2.17 dev: false /@types/react-test-renderer@17.0.2: @@ -8931,7 +8944,7 @@ packages: /@types/react-transition-group@4.4.5: resolution: {integrity: sha512-juKD/eiSM3/xZYzjuzH6ZwpP+/lejltmiS3QEzV/vmb/Q8+HfDmxu+Baga8UEMGBqV88Nbg4l2hY/K2DkyaLLA==} dependencies: - '@types/react': 18.2.15 + '@types/react': 18.2.17 dev: false /@types/react@17.0.49: @@ -8950,8 +8963,8 @@ packages: csstype: 3.1.0 dev: true - /@types/react@18.2.15: - resolution: {integrity: sha512-oEjE7TQt1fFTFSbf8kkNuc798ahTUzn3Le67/PWjE8MAfYAD/qB7O8hSTcromLFqHCt9bcdOg5GXMokzTjJ5SA==} + /@types/react@18.2.17: + resolution: {integrity: sha512-u+e7OlgPPh+aryjOm5UJMX32OvB2E3QASOAqVMY6Ahs90djagxwv2ya0IctglNbNTexC12qCSMZG47KPfy1hAA==} dependencies: '@types/prop-types': 15.7.5 '@types/scheduler': 0.16.2 @@ -8960,7 +8973,7 @@ packages: /@types/resolve@1.17.1: resolution: {integrity: sha512-yy7HuzQhj0dhGpD8RLXSZWEkLsV9ibvxvi6EiJ3bkqLAO1RGo0WbkWQiwpRlSFymTJRz0d3k5LM3kkx8ArDbLw==} dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 dev: true /@types/resolve@1.20.2: @@ -8977,7 +8990,7 @@ packages: /@types/set-cookie-parser@2.4.2: resolution: {integrity: sha512-fBZgytwhYAUkj/jC/FAV4RQ5EerRup1YQsXQCh8rZfiHkc4UahC192oH0smGwsXol3cL3A5oETuAHeQHmhXM4w==} dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 dev: true /@types/sinonjs__fake-timers@8.1.1: @@ -9019,7 +9032,7 @@ packages: /@types/through@0.0.30: resolution: {integrity: sha512-FvnCJljyxhPM3gkRgWmxmDZyAQSiBQQWLI0A0VFL0K7W1oRUrPJSqNO0NvTnLkBcotdlp3lKvaT0JrnyRDkzOg==} dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 dev: true /@types/tough-cookie@4.0.2: @@ -9057,7 +9070,7 @@ packages: /@types/webpack-sources@3.2.0: resolution: {integrity: sha512-Ft7YH3lEVRQ6ls8k4Ff1oB4jN6oy/XmU6tQISKdhfh+1mR+viZFphS6WL0IrtDOzvefmJg5a0s7ZQoRXwqTEFg==} dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 '@types/source-list-map': 0.1.2 source-map: 0.7.4 dev: true @@ -9065,7 +9078,7 @@ packages: /@types/webpack@4.41.32: resolution: {integrity: sha512-cb+0ioil/7oz5//7tZUSwbrSAN/NWHrQylz5cW8G0dWTcF/g+/dSdMlKVZspBYuMAN1+WnwHrkxiRrLcwd0Heg==} dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 '@types/tapable': 1.0.8 '@types/uglify-js': 3.17.0 '@types/webpack-sources': 3.2.0 @@ -9080,7 +9093,7 @@ packages: /@types/ws@8.5.5: resolution: {integrity: sha512-lwhs8hktwxSjf9UaZ9tG5M03PGogvFaH8gUgLNbN9HKIg0dvv6q+gkSuJ8HN4/VbyxkuLzCjlN7GquQ0gUJfIg==} dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 dev: true /@types/yargs-parser@21.0.0: @@ -9109,7 +9122,7 @@ packages: resolution: {integrity: sha512-Cn6WYCm0tXv8p6k+A8PvbDG763EDpBoTzHdA+Q/MF6H3sapGjCm9NzoaJncJS9tUKSuCoDs9XHxYYsQDgxR6kw==} requiresBuild: true dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 dev: true optional: true @@ -9134,7 +9147,7 @@ packages: grapheme-splitter: 1.0.4 ignore: 5.2.0 natural-compare-lite: 1.4.0 - semver: 7.5.2 + semver: 7.5.4 tsutils: 3.21.0(typescript@5.1.6) typescript: 5.1.6 transitivePeerDependencies: @@ -9208,7 +9221,7 @@ packages: debug: 4.3.4(supports-color@8.1.1) globby: 11.1.0 is-glob: 4.0.3 - semver: 7.5.2 + semver: 7.5.4 tsutils: 3.21.0(typescript@5.1.6) typescript: 5.1.6 transitivePeerDependencies: @@ -9229,7 +9242,7 @@ packages: '@typescript-eslint/typescript-estree': 5.60.0(typescript@5.1.6) eslint: 8.44.0 eslint-scope: 5.1.1 - semver: 7.5.2 + semver: 7.5.4 transitivePeerDependencies: - supports-color - typescript @@ -9536,7 +9549,7 @@ packages: '@babel/plugin-transform-react-jsx-self': 7.22.5(@babel/core@7.22.5) '@babel/plugin-transform-react-jsx-source': 7.22.5(@babel/core@7.22.5) react-refresh: 0.14.0 - vite: 4.3.9(@types/node@20.4.2) + vite: 4.3.9(@types/node@20.4.5) transitivePeerDependencies: - supports-color dev: true @@ -9594,7 +9607,7 @@ packages: /@volar/typescript-faster@0.40.13: resolution: {integrity: sha512-uy+TlcFkKoNlKEnxA4x5acxdxLyVDIXGSc8cYDNXpPKjBKXrQaetzCzlO3kVBqu1VLMxKNGJMTKn35mo+ILQmw==} dependencies: - semver: 7.5.2 + semver: 7.5.4 dev: true /@volar/vue-language-core@0.40.13: @@ -10036,14 +10049,14 @@ packages: resolution: {integrity: sha512-VZ1WFHTNKjR8Ga97TtV2SZM6fvRjWbYI2i/f4pJB4PtusorKvONAMJf2LQcUBIyzbVobqr7KSrcjmSwRolI+yw==} engines: {node: ^16.13 || >=18} dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 dev: true /@wdio/types@8.10.4: resolution: {integrity: sha512-aLJ1QQW+hhALeRK3bvMLjIrlUVyhOs3Od+91pR4Z4pLwyeNG1bJZCJRD5bAJK/mm7CnFa0NsdixPS9jJxZcRrw==} engines: {node: ^16.13 || >=18} dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 dev: true /@wdio/utils@8.12.1: @@ -11600,7 +11613,7 @@ packages: /builtins@5.0.1: resolution: {integrity: sha512-qwVpFEHNfhYJIzNRBvd2C1kyo6jz3ZSMPyyuR47OPdiKWlbYnZNyDWuyR175qDnAJLiCo5fBBqPb3RiXgWlkOQ==} dependencies: - semver: 7.5.2 + semver: 7.5.4 dev: true /bumpp@9.1.1: @@ -12016,7 +12029,7 @@ packages: engines: {node: '>=12.13.0'} hasBin: true dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 escape-string-regexp: 4.0.0 is-wsl: 2.2.0 lighthouse-logger: 1.3.0 @@ -12417,6 +12430,7 @@ packages: resolution: {integrity: sha512-+OQdjP49zViI/6i7nIJpA8rAl4sV/JdPfU9nZs3VqOwGIgizICvuN2ru6fMd+4llL0tar18UYJXfZ/TWtmhUjA==} dependencies: safe-buffer: 5.1.2 + dev: true /convert-source-map@1.9.0: resolution: {integrity: sha512-ASFBup0Mz1uyiIjANan1jzLQami9z1PoYSZCiiYW2FczPbenXc45FZdBZLzOT+r6+iciuEModtmCti+hjaAk0A==} @@ -13313,7 +13327,7 @@ packages: resolution: {integrity: sha512-R72raQLN1lDSqbr2DVj9SRh07JRyojzmrcLa33VBa2nw3cf5ZyHOHe0DgxlJ/5c2Dfs1+wGNJy16gWKGBq+xgg==} engines: {node: ^16.13 || >=18} dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 '@wdio/config': 8.12.1 '@wdio/logger': 8.11.0 '@wdio/protocols': 8.11.0 @@ -14481,7 +14495,7 @@ packages: is-core-module: 2.12.1 minimatch: 3.1.2 resolve: 1.22.2 - semver: 7.5.2 + semver: 7.5.4 dev: true /eslint-plugin-no-only-tests@3.1.0: @@ -14519,7 +14533,7 @@ packages: regexp-tree: 0.1.24 regjsparser: 0.10.0 safe-regex: 2.1.1 - semver: 7.5.2 + semver: 7.5.4 strip-indent: 3.0.0 dev: true @@ -14549,7 +14563,7 @@ packages: natural-compare: 1.4.0 nth-check: 2.1.1 postcss-selector-parser: 6.0.10 - semver: 7.5.2 + semver: 7.5.4 vue-eslint-parser: 9.3.1(eslint@8.44.0) xml-name-validator: 4.0.0 transitivePeerDependencies: @@ -14658,7 +14672,7 @@ packages: optionator: 0.9.1 progress: 2.0.3 regexpp: 3.2.0 - semver: 7.5.2 + semver: 7.5.4 strip-ansi: 6.0.1 strip-json-comments: 3.1.1 text-table: 0.2.0 @@ -15504,7 +15518,7 @@ packages: memfs: 3.4.7 minimatch: 3.1.2 schema-utils: 2.7.0 - semver: 7.5.2 + semver: 7.5.4 tapable: 1.1.3 typescript: 4.8.4 webpack: 4.46.0 @@ -17226,8 +17240,8 @@ packages: resolution: {integrity: sha512-pzqtp31nLv/XFOzXGuvhCb8qhjmTVo5vjVk19XE4CRlSWz0KoeJ3bw9XsA7nOp9YBf4qHjwBxkDzKcME/J29Yg==} engines: {node: '>=8'} dependencies: - '@babel/core': 7.18.13 - '@babel/parser': 7.18.13 + '@babel/core': 7.22.5 + '@babel/parser': 7.22.5 '@istanbuljs/schema': 0.1.3 istanbul-lib-coverage: 3.2.0 semver: 6.3.0 @@ -17235,9 +17249,22 @@ packages: - supports-color dev: true - /istanbul-lib-report@3.0.0: - resolution: {integrity: sha512-wcdi+uAKzfiGT2abPpKZ0hSU1rGQjUQnLvtY5MpQ7QCTahD3VODhcu4wcfY1YtkGaDD5yuydOLINXsfbus9ROw==} - engines: {node: '>=8'} + /istanbul-lib-instrument@6.0.0: + resolution: {integrity: sha512-x58orMzEVfzPUKqlbLd1hXCnySCxKdDKa6Rjg97CwuLLRI4g3FHTdnExu1OqffVFay6zeMW+T6/DowFLndWnIw==} + engines: {node: '>=10'} + dependencies: + '@babel/core': 7.22.5 + '@babel/parser': 7.22.5 + '@istanbuljs/schema': 0.1.3 + istanbul-lib-coverage: 3.2.0 + semver: 7.5.4 + transitivePeerDependencies: + - supports-color + dev: false + + /istanbul-lib-report@3.0.1: + resolution: {integrity: sha512-GCfE1mtsHGOELCU8e/Z7YWzpmybrx/+dSTfLrvY8qRmaY6zXTKWn6WQIjaAFw069icm6GVMNkgu0NzI4iPZUNw==} + engines: {node: '>=10'} dependencies: istanbul-lib-coverage: 3.2.0 make-dir: 4.0.0 @@ -17307,7 +17334,7 @@ packages: '@jest/environment': 27.5.1 '@jest/test-result': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.2 + '@types/node': 20.4.5 chalk: 4.1.2 co: 4.6.0 dedent: 0.7.0 @@ -17443,7 +17470,7 @@ packages: '@jest/environment': 27.5.1 '@jest/fake-timers': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.2 + '@types/node': 20.4.5 jest-mock: 27.5.1 jest-util: 27.5.1 jsdom: 16.7.0 @@ -17461,7 +17488,7 @@ packages: '@jest/environment': 27.5.1 '@jest/fake-timers': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.2 + '@types/node': 20.4.5 jest-mock: 27.5.1 jest-util: 27.5.1 dev: true @@ -17482,7 +17509,7 @@ packages: dependencies: '@jest/types': 26.6.2 '@types/graceful-fs': 4.1.5 - '@types/node': 20.4.2 + '@types/node': 20.4.5 anymatch: 3.1.2 fb-watchman: 2.0.1 graceful-fs: 4.2.10 @@ -17505,7 +17532,7 @@ packages: dependencies: '@jest/types': 27.5.1 '@types/graceful-fs': 4.1.5 - '@types/node': 20.4.2 + '@types/node': 20.4.5 anymatch: 3.1.2 fb-watchman: 2.0.1 graceful-fs: 4.2.10 @@ -17545,7 +17572,7 @@ packages: '@jest/source-map': 27.5.1 '@jest/test-result': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.2 + '@types/node': 20.4.5 chalk: 4.1.2 co: 4.6.0 expect: 27.5.1 @@ -17625,7 +17652,7 @@ packages: engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: '@jest/types': 27.5.1 - '@types/node': 20.4.2 + '@types/node': 20.4.5 dev: true /jest-pnp-resolver@1.2.3(jest-resolve@27.5.1): @@ -17686,7 +17713,7 @@ packages: '@jest/test-result': 27.5.1 '@jest/transform': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.2 + '@types/node': 20.4.5 chalk: 4.1.2 emittery: 0.8.1 graceful-fs: 4.2.10 @@ -17743,7 +17770,7 @@ packages: resolution: {integrity: sha512-S5wqyz0DXnNJPd/xfIzZ5Xnp1HrJWBczg8mMfMpN78OJ5eDxXyf+Ygld9wX1DnUWbIbhM1YDY95NjR4CBXkb2g==} engines: {node: '>= 10.14.2'} dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 graceful-fs: 4.2.10 dev: true @@ -17751,7 +17778,7 @@ packages: resolution: {integrity: sha512-jZCyo6iIxO1aqUxpuBlwTDMkzOAJS4a3eYz3YzgxxVQFwLeSA7Jfq5cbqCY+JLvTDrWirgusI/0KwxKMgrdf7w==} engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 graceful-fs: 4.2.10 dev: true @@ -17780,7 +17807,7 @@ packages: jest-util: 27.5.1 natural-compare: 1.4.0 pretty-format: 27.5.1 - semver: 7.5.2 + semver: 7.5.4 transitivePeerDependencies: - supports-color dev: true @@ -17790,7 +17817,7 @@ packages: engines: {node: '>= 10.14.2'} dependencies: '@jest/types': 26.6.2 - '@types/node': 20.4.2 + '@types/node': 20.4.5 chalk: 4.1.2 graceful-fs: 4.2.10 is-ci: 2.0.0 @@ -17802,7 +17829,7 @@ packages: engines: {node: ^10.13.0 || ^12.13.0 || ^14.15.0 || >=15.0.0} dependencies: '@jest/types': 27.5.1 - '@types/node': 20.4.2 + '@types/node': 20.4.5 chalk: 4.1.2 ci-info: 3.8.0 graceful-fs: 4.2.10 @@ -17814,7 +17841,7 @@ packages: engines: {node: ^14.15.0 || ^16.10.0 || >=18.0.0} dependencies: '@jest/types': 29.0.1 - '@types/node': 20.4.2 + '@types/node': 20.4.5 chalk: 4.1.2 ci-info: 3.7.0 graceful-fs: 4.2.10 @@ -17839,7 +17866,7 @@ packages: dependencies: '@jest/test-result': 27.5.1 '@jest/types': 27.5.1 - '@types/node': 20.4.2 + '@types/node': 20.4.5 ansi-escapes: 4.3.2 chalk: 4.1.2 jest-util: 27.5.1 @@ -17850,7 +17877,7 @@ packages: resolution: {integrity: sha512-KWYVV1c4i+jbMpaBC+U++4Va0cp8OisU185o73T1vo99hqi7w8tSJfUXYswwqqrjzwxa6KpRK54WhPvwf5w6PQ==} engines: {node: '>= 10.13.0'} dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 merge-stream: 2.0.0 supports-color: 7.2.0 dev: true @@ -17859,7 +17886,7 @@ packages: resolution: {integrity: sha512-7vuh85V5cdDofPyxn58nrPjBktZo0u9x1g8WtjQol+jZDaE+fhN+cIvTj11GndBnMnyfrUOG1sZQxCdjKh+DKg==} engines: {node: '>= 10.13.0'} dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 merge-stream: 2.0.0 supports-color: 8.1.1 dev: true @@ -18203,6 +18230,7 @@ packages: resolution: {integrity: sha512-1hqLFMSrGHRHxav9q9gNjJ5EXznIxGVO09xQRrwplcS8qs28pZ8s8hupZAmqDwZUmVZ2Qb2jnyPOWcDH8m8dlA==} engines: {node: '>=6'} hasBin: true + dev: true /json5@2.2.3: resolution: {integrity: sha512-XmOWe7eyHYH14cLdVPoyg+GOH3rYX++KpzrylJwSW98t3Nk+U8XOl8FWKOgwtzdb8lXGf6zYwDUzeHMWfxasyg==} @@ -18216,7 +18244,7 @@ packages: acorn: 8.9.0 eslint-visitor-keys: 3.4.1 espree: 9.5.2 - semver: 7.5.2 + semver: 7.5.4 dev: true /jsonc-parser@3.2.0: @@ -18698,7 +18726,6 @@ packages: engines: {node: '>=10'} dependencies: yallist: 4.0.0 - dev: true /lru-cache@9.1.1: resolution: {integrity: sha512-65/Jky17UwSb0BuB9V+MyDpsOtXKmYwzhyl+cOa9XUiI4uV2Ouy/2voFP3+al0BjZbJgMBD8FojMpAf+Z+qn4A==} @@ -18760,6 +18787,13 @@ packages: engines: {node: '>=8'} dependencies: semver: 6.3.0 + dev: true + + /make-dir@4.0.0: + resolution: {integrity: sha512-hXdUTZYIVOt1Ex//jAQi+wTZZpUpwBj/0QsOzqegb3rGMMeJiSEu5xLHnYfBrRV4RH2+OCSOO95Is/7x1WJ4bw==} + engines: {node: '>=10'} + dependencies: + semver: 7.5.4 /make-error@1.3.6: resolution: {integrity: sha512-s8UhlNe7vPKomQhC1qFelMokr/Sc3AgNbso3n74mVPA5LTZwkB9NlXf4XPamLxJE8h0gh73rM94xvwRT2CVInw==} @@ -19495,7 +19529,7 @@ packages: resolution: {integrity: sha512-iwXuFrMAcFVi/ZoZiqq8BzAdsLw9kxDfTC0HMyjXfSL/6CSDAGD5UmR7azrAgWV1zKYq7dUUMj4owusBWKLsiQ==} engines: {node: '>=10'} dependencies: - semver: 7.5.2 + semver: 7.5.4 dev: true /node-addon-api@6.1.0: @@ -19598,7 +19632,7 @@ packages: dependencies: hosted-git-info: 4.1.0 is-core-module: 2.12.1 - semver: 7.5.2 + semver: 7.5.4 validate-npm-package-license: 3.0.4 dev: true @@ -20613,7 +20647,7 @@ packages: loader-utils: 2.0.2 postcss: 7.0.39 schema-utils: 3.1.1 - semver: 7.5.2 + semver: 7.5.4 webpack: 4.46.0 dev: true @@ -22060,6 +22094,7 @@ packages: /safe-buffer@5.1.2: resolution: {integrity: sha512-Gd2UZBJDkXlY7GbJxfsE8/nvKkUEU1G38c1siN6QP6a9PT9MmHB8GnpscSmMJSoF8LOIrt8ud/wPtojys4G6+g==} + dev: true /safe-buffer@5.2.1: resolution: {integrity: sha512-rp3So07KcdmmKbGvgaNxQSJr7bGVSVk5S9Eq1F+ppbRo70+YeaDxkw5Dd8NPN+GD6bjnYm2VuPuCXmpuYvmCXQ==} @@ -22241,6 +22276,13 @@ packages: lru-cache: 6.0.0 dev: true + /semver@7.5.4: + resolution: {integrity: sha512-1bCSESV6Pv+i21Hvpxp3Dx+pSD8lIPt8uVjRrxAUt/nbswYc+tK6Y2btiULjd4+fnq15PX+nqQDC7Oft7WkwcA==} + engines: {node: '>=10'} + hasBin: true + dependencies: + lru-cache: 6.0.0 + /send@0.18.0: resolution: {integrity: sha512-qqWzuOjSFOuqPjFe4NOsMLafToQQwBSOEpS+FwEt3A2V3vKubTquT3vmLTQpFgMXp8AlFWFuP1qKaJZOtPpVXg==} engines: {node: '>= 0.8.0'} @@ -22372,7 +22414,7 @@ packages: detect-libc: 2.0.1 node-addon-api: 6.1.0 prebuild-install: 7.1.1 - semver: 7.5.2 + semver: 7.5.4 simple-get: 4.0.1 tar-fs: 2.1.1 tunnel-agent: 0.6.0 @@ -24371,16 +24413,16 @@ packages: '@nuxt/kit': optional: true dependencies: - '@antfu/utils': 0.7.4 + '@antfu/utils': 0.7.5 '@rollup/pluginutils': 5.0.2(rollup@2.79.1) chokidar: 3.5.3 debug: 4.3.4(supports-color@8.1.1) fast-glob: 3.3.0 local-pkg: 0.4.3 - magic-string: 0.30.0 - minimatch: 9.0.1 + magic-string: 0.30.1 + minimatch: 9.0.3 resolve: 1.22.2 - unplugin: 1.3.1 + unplugin: 1.3.2 vue: 3.3.4 transitivePeerDependencies: - rollup @@ -24793,7 +24835,7 @@ packages: fsevents: 2.3.2 dev: false - /vite@4.3.9(@types/node@20.4.2): + /vite@4.3.9(@types/node@20.4.5): resolution: {integrity: sha512-qsTNZjO9NoJNW7KnOrgYwczm0WctJ8m/yqYAMAK9Lxt4SoySUfS5S8ia9K7JHpa3KEeMfyF8LoJ3c5NeBJy6pg==} engines: {node: ^14.18.0 || >=16.0.0} hasBin: true @@ -24818,7 +24860,7 @@ packages: terser: optional: true dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 esbuild: 0.17.18 postcss: 8.4.24 rollup: 3.23.0 @@ -24974,7 +25016,7 @@ packages: espree: 9.5.2 esquery: 1.5.0 lodash: 4.17.21 - semver: 7.5.2 + semver: 7.5.4 transitivePeerDependencies: - supports-color dev: true @@ -25130,7 +25172,7 @@ packages: resolution: {integrity: sha512-Ca+MUYUXfl5gsnX40xAIUgfoa76qQsfX7REGFzMl09Cb7vHKtM17bEOGDaTbXIX4kbkXylyUSAuBpe3gCtDDKg==} engines: {node: ^16.13 || >=18} dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 '@types/ws': 8.5.5 '@wdio/config': 8.12.1 '@wdio/logger': 8.11.0 @@ -25150,7 +25192,7 @@ packages: resolution: {integrity: sha512-lW0Qo3fy64cVbYWWAZbXxLIOK0pbTARgpY89J+0Sr6zh2K2NKtd/0D11k3WfMeYxd0b0he7E7XC1b6M6w4h75A==} engines: {node: ^16.13 || >=18} dependencies: - '@types/node': 20.4.2 + '@types/node': 20.4.5 '@wdio/config': 8.12.1 '@wdio/logger': 8.11.0 '@wdio/protocols': 8.11.0 @@ -25785,7 +25827,6 @@ packages: /yallist@4.0.0: resolution: {integrity: sha512-3wdGidZyq5PB084XLES5TpOSRA3wjXAlIWMhum2kRcv/41Sn2emQ0dycQW4uZXLejwKvg6EsvbdlVL+FYEct7A==} - dev: true /yaml-eslint-parser@1.2.2: resolution: {integrity: sha512-pEwzfsKbTrB8G3xc/sN7aw1v6A6c/pKxLAkjclnAyo5g5qOh6eL9WGu0o3cSDQZKrTNk4KL4lQSwZW+nBkANEg==} From 3342ea41ed0f38f0b960226124d8a171d4779a7d Mon Sep 17 00:00:00 2001 From: Vladimir Date: Fri, 28 Jul 2023 19:58:54 +0200 Subject: [PATCH 72/87] fix: normalize cache path --- packages/vitest/src/runtime/external-executor.ts | 4 ++-- 1 file changed, 2 insertions(+), 2 deletions(-) diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index e3213451bb9d..c1d7840a0dc7 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -6,7 +6,7 @@ import { dirname } from 'node:path' import { Module as _Module, createRequire } from 'node:module' import { readFileSync, statSync } from 'node:fs' import { readFile } from 'node:fs/promises' -import { basename, extname, join } from 'pathe' +import { basename, extname, join, normalize } from 'pathe' import { getCachedData, isNodeBuiltin, setCacheData } from 'vite-node/utils' // need to copy paste types for vm @@ -420,7 +420,7 @@ export class ExternalModulesExecutor { if (inlineCode || extension === '.mjs') return await this.createEsmModule(fileUrl, inlineCode || await readFile(pathUrl, 'utf8')) - const pkgData = await this.findNearestPackageData(pathUrl) + const pkgData = await this.findNearestPackageData(normalize(pathUrl)) if (pkgData.type === 'module') return await this.createEsmModule(fileUrl, await readFile(pathUrl, 'utf8')) From 213e7c61898586f731ffca43adb663d5e30ef0c6 Mon Sep 17 00:00:00 2001 From: Vladimir Date: Fri, 28 Jul 2023 22:24:37 +0200 Subject: [PATCH 73/87] Apply suggestions from code review --- docs/config/index.md | 4 ++-- packages/vite-node/src/server.ts | 2 +- 2 files changed, 3 insertions(+), 3 deletions(-) diff --git a/docs/config/index.md b/docs/config/index.md index 324ab4254a3e..1bf2e0afb18f 100644 --- a/docs/config/index.md +++ b/docs/config/index.md @@ -560,14 +560,14 @@ Running code in a sandbox has some advantages (faster tests), but also comes wit ```ts try { - fs.writeFile('/doesnt exist') + fs.writeFileSync('/doesnt exist') } catch (err) { console.log(err instanceof Error) // false } ``` -- Importing ES modules cache them indefinitely which introduces memory leaks if you have a lot of contexts (or tests). There is no API in Node.js that clears that cache. +- Importing ES modules caches them indefinitely which introduces memory leaks if you have a lot of contexts (test files). There is no API in Node.js that clears that cache. - Accessing globals [takes longer](https://github.com/nodejs/node/issues/31658) in a sandbox environment. Please, be aware of these issues when using this option. Vitest team cannot fix any of the issues on our side. diff --git a/packages/vite-node/src/server.ts b/packages/vite-node/src/server.ts index 884ebfb250a7..17834bb2e367 100644 --- a/packages/vite-node/src/server.ts +++ b/packages/vite-node/src/server.ts @@ -1,7 +1,7 @@ import { performance } from 'node:perf_hooks' import { existsSync } from 'node:fs' import { join, normalize, relative, resolve } from 'pathe' -import { type TransformResult, type ViteDevServer } from 'vite' +import type { TransformResult, ViteDevServer } from 'vite' import createDebug from 'debug' import type { EncodedSourceMap } from '@jridgewell/trace-mapping' import type { DebuggerOptions, FetchResult, ViteNodeResolveId, ViteNodeServerOptions } from './types' From 72f8735a5130d491f54e8ec72c93b1f3f288f432 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Sun, 30 Jul 2023 10:53:14 +0200 Subject: [PATCH 74/87] chore: move updatestyle/removestyle --- packages/vitest/src/runtime/execute.ts | 27 +++++++++++++++++++------- 1 file changed, 20 insertions(+), 7 deletions(-) diff --git a/packages/vitest/src/runtime/execute.ts b/packages/vitest/src/runtime/execute.ts index fe21e828a2c1..1617a4793051 100644 --- a/packages/vitest/src/runtime/execute.ts +++ b/packages/vitest/src/runtime/execute.ts @@ -113,18 +113,28 @@ function updateStyle(id: string, css: string) { if (typeof document === 'undefined') return - const element = document.getElementById(id) - if (element) - element.remove() + const element = document.querySelector(`[data-vite-dev-id="${id}"]`) + if (element) { + element.textContent = css + return + } const head = document.querySelector('head') const style = document.createElement('style') style.setAttribute('type', 'text/css') - style.id = id - style.innerHTML = css + style.setAttribute('data-vite-dev-id', id) + style.textContent = css head?.appendChild(style) } +function removeStyle(id: string) { + if (typeof document === 'undefined') + return + const sheet = document.querySelector(`[data-vite-dev-id="${id}"]`) + if (sheet) + document.head.removeChild(sheet) +} + export class VitestExecutor extends ViteNodeRunner { public mocker: VitestMocker public externalModules?: ExternalModulesExecutor @@ -146,7 +156,7 @@ export class VitestExecutor extends ViteNodeRunner { writable: true, configurable: true, }) - const clientStub = { ...DEFAULT_REQUEST_STUBS['@vite/client'], updateStyle } + const clientStub = { ...DEFAULT_REQUEST_STUBS['@vite/client'], updateStyle, removeStyle } this.options.requestStubs = { '/@vite/client': clientStub, '@vite/client': clientStub, @@ -162,7 +172,10 @@ export class VitestExecutor extends ViteNodeRunner { context: options.context, packageCache: options.packageCache, }) - const clientStub = vm.runInContext(`(defaultClient) => ({ ...defaultClient, updateStyle: ${updateStyle.toString()} })`, options.context)(DEFAULT_REQUEST_STUBS['@vite/client']) + const clientStub = vm.runInContext( + `(defaultClient) => ({ ...defaultClient, updateStyle: ${updateStyle.toString()}, removeStyle: ${removeStyle.toString()} })`, + options.context, + )(DEFAULT_REQUEST_STUBS['@vite/client']) this.options.requestStubs = { '/@vite/client': clientStub, '@vite/client': clientStub, From 4e083b9dc569393e788edae01213e3b6a70f1d16 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Sun, 30 Jul 2023 10:53:48 +0200 Subject: [PATCH 75/87] chore: lockfile --- pnpm-lock.yaml | 3 +++ 1 file changed, 3 insertions(+) diff --git a/pnpm-lock.yaml b/pnpm-lock.yaml index 941721e0c831..531e360a22af 100644 --- a/pnpm-lock.yaml +++ b/pnpm-lock.yaml @@ -1850,6 +1850,9 @@ importers: vite: specifier: ^4.3.9 version: 4.3.9(@types/node@18.16.19) + vite-node: + specifier: workspace:* + version: link:../../packages/vite-node vitest: specifier: workspace:* version: link:../../packages/vitest From 87abda7b659db31ddd99349689f229b00375c706 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Mon, 31 Jul 2023 12:14:39 +0200 Subject: [PATCH 76/87] chore: cleanup --- docs/config/index.md | 6 +++++- 1 file changed, 5 insertions(+), 1 deletion(-) diff --git a/docs/config/index.md b/docs/config/index.md index 1bf2e0afb18f..df930e232dc9 100644 --- a/docs/config/index.md +++ b/docs/config/index.md @@ -144,7 +144,11 @@ Handling for dependencies resolution. - **Type:** `(string | RegExp)[]` - **Default:** `[/\/node_modules\//]` -Externalize means that Vite will bypass the package to native Node. Externalized dependencies will not be applied Vite's transformers and resolvers, so they do not support HMR on reload. All packages under `node_modules` are externalized. +Externalize means that Vite will bypass the package to the native Node. Externalized dependencies will not be applied to Vite's transformers and resolvers, so they do not support HMR on reload. By default, all packages inside `node_modules` are externalized. + +These options support package names as they are written in `node_modules` or specified inside [`deps.moduleDirectories`](#deps-moduledirectories). For example, package `@company/some-name` located inside `packages/some-name` should be specified as `some-name`, and `packages` should be included in `deps.moduleDirectories`. Basically, Vitest always checks the file path, not the actual package name. + +If regexp is used, Vitest calls it on the _file path_, not the package name. #### server.deps.inline From 8ec12e313e65ce2997b27adddf95096a9a97419d Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Mon, 31 Jul 2023 12:15:54 +0200 Subject: [PATCH 77/87] chore: web-worker depends on vitest 0.34.0 --- packages/web-worker/package.json | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/packages/web-worker/package.json b/packages/web-worker/package.json index b67b6459eb2f..dd5f48322b97 100644 --- a/packages/web-worker/package.json +++ b/packages/web-worker/package.json @@ -41,7 +41,7 @@ "typecheck": "tsc --noEmit" }, "peerDependencies": { - "vitest": ">=0.33.0" + "vitest": ">=0.34.0" }, "dependencies": { "debug": "^4.3.4" From cca3e566f87e48e39dac7b25c9f97483b0952bd4 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Mon, 31 Jul 2023 12:17:33 +0200 Subject: [PATCH 78/87] chore: cleanup --- pnpm-lock.yaml | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/pnpm-lock.yaml b/pnpm-lock.yaml index 531e360a22af..df0195a81c8c 100644 --- a/pnpm-lock.yaml +++ b/pnpm-lock.yaml @@ -1438,7 +1438,7 @@ importers: specifier: ^4.3.4 version: 4.3.4(supports-color@8.1.1) vitest: - specifier: '>=0.33.0' + specifier: '>=0.34.0' version: link:../vitest devDependencies: '@types/debug': From 37b970d73d1593fd0ac37fb59d4fc5c18ad935aa Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Mon, 31 Jul 2023 12:22:55 +0200 Subject: [PATCH 79/87] chore: overwrite wrap --- packages/vitest/src/runtime/external-executor.ts | 12 ++++++++++-- 1 file changed, 10 insertions(+), 2 deletions(-) diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index c1d7840a0dc7..84cf0c6f571f 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -142,7 +142,7 @@ export class ExternalModulesExecutor { } _compile(code: string, filename: string) { - const cjsModule = _Module.wrap(code) + const cjsModule = Module.wrap(code) const script = new vm.Script(cjsModule, { filename, importModuleDynamically: executor.importModuleDynamically, @@ -167,8 +167,16 @@ export class ExternalModulesExecutor { return require(request) } + static wrap = (script: string) => { + return Module.wrapper[0] + script + Module.wrapper[1] + } + + static wrapper = [ + '(function (exports, require, module, __filename, __dirname) { ', + '\n});', + ] + static builtinModules = _Module.builtinModules - static wrap = _Module.wrap static findSourceMap = _Module.findSourceMap static SourceMap = _Module.SourceMap static syncBuiltinESMExports = _Module.syncBuiltinESMExports From eaa8ac666799989df30d8d4dd5166dd33ed61131 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Mon, 31 Jul 2023 12:26:39 +0200 Subject: [PATCH 80/87] chore: primitives --- .../vitest/src/runtime/external-executor.ts | 23 ++++++++++--------- 1 file changed, 12 insertions(+), 11 deletions(-) diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index 84cf0c6f571f..f20daef0222d 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -107,13 +107,16 @@ export class ExternalModulesExecutor { private context: vm.Context private Module: typeof _Module - private primitives: { - Object: typeof Object - } constructor(private options: ExternalModulesExecutorOptions) { this.context = options.context + const primitives = vm.runInContext('({ Object, Array, Error })', this.context) as { + Object: typeof Object + Array: typeof Array + Error: typeof Error + } + // eslint-disable-next-line @typescript-eslint/no-this-alias const executor = this @@ -131,7 +134,7 @@ export class ExternalModulesExecutor { paths: string[] = [] constructor(id: string, parent?: Module) { - this.exports = executor.primitives.Object.create(Object.prototype) + this.exports = primitives.Object.create(Object.prototype) this.require = Module.createRequire(id) // in our case the path should always be resolved already this.path = dirname(id) @@ -171,10 +174,10 @@ export class ExternalModulesExecutor { return Module.wrapper[0] + script + Module.wrapper[1] } - static wrapper = [ + static wrapper = new primitives.Array( '(function (exports, require, module, __filename, __dirname) { ', '\n});', - ] + ) static builtinModules = _Module.builtinModules static findSourceMap = _Module.findSourceMap @@ -189,7 +192,7 @@ export class ExternalModulesExecutor { } static runMain = () => { - throw new Error('[vitest] "runMain" is not implemented.') + throw new primitives.Error('[vitest] "runMain" is not implemented.') } // @ts-expect-error not typed @@ -213,8 +216,6 @@ export class ExternalModulesExecutor { this.extensions['.js'] = this.requireJs this.extensions['.json'] = this.requireJson - - this.primitives = vm.runInContext('({ Object })', this.context) } private requireJs = (m: NodeModule, filename: string) => { @@ -310,8 +311,8 @@ export class ExternalModulesExecutor { private findLongestRegisteredExtension(filename: string) { const name = basename(filename) - let currentExtension - let index + let currentExtension: string + let index: number let startIndex = 0 // eslint-disable-next-line no-cond-assign while ((index = name.indexOf('.', startIndex)) !== -1) { From 2b2a73ea8315bd918634a5c8cbd1b5af6866a093 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Mon, 31 Jul 2023 13:21:37 +0200 Subject: [PATCH 81/87] chore: have a cache for fs --- .../vitest/src/runtime/external-executor.ts | 49 +++++++++++-------- 1 file changed, 28 insertions(+), 21 deletions(-) diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index f20daef0222d..3fd523019fd9 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -5,7 +5,6 @@ import { fileURLToPath, pathToFileURL } from 'node:url' import { dirname } from 'node:path' import { Module as _Module, createRequire } from 'node:module' import { readFileSync, statSync } from 'node:fs' -import { readFile } from 'node:fs/promises' import { basename, extname, join, normalize } from 'pathe' import { getCachedData, isNodeBuiltin, setCacheData } from 'vite-node/utils' @@ -106,6 +105,8 @@ export class ExternalModulesExecutor { private esmLinkMap = new WeakMap>() private context: vm.Context + private fsCache = new Map() + private Module: typeof _Module constructor(private options: ExternalModulesExecutorOptions) { @@ -219,22 +220,22 @@ export class ExternalModulesExecutor { } private requireJs = (m: NodeModule, filename: string) => { - const content = readFileSync(filename, 'utf-8') + const content = this.readFile(filename) ;(m as PrivateNodeModule)._compile(content, filename) } private requireJson = (m: NodeModule, filename: string) => { - const code = readFileSync(filename, 'utf-8') + const code = this.readFile(filename) m.exports = JSON.parse(code) } public importModuleDynamically = async (specifier: string, referencer: VMModule) => { - const module = await this.resolveModule(specifier, referencer) + const module = await this.resolveModule(specifier, referencer.identifier) return this.evaluateModule(module) } - private resolveModule = async (specifier: string, referencer: VMModule) => { - const identifier = await this.resolveAsync(specifier, referencer.identifier) + private resolveModule = async (specifier: string, referencer: string) => { + const identifier = await this.resolveAsync(specifier, referencer) return await this.createModule(identifier) } @@ -242,6 +243,15 @@ export class ExternalModulesExecutor { return nativeResolve(specifier, parent) } + private readFile(path: string) { + const cached = this.fsCache.get(path) + if (cached) + return cached + const source = readFileSync(path, 'utf-8') + this.fsCache.set(path, source) + return source + } + private async findNearestPackageData(basedir: string) { const originalBasedir = basedir const packageCache = this.options.packageCache @@ -253,7 +263,7 @@ export class ExternalModulesExecutor { const pkgPath = join(basedir, 'package.json') try { if (statSync(pkgPath, { throwIfNoEntry: false })?.isFile()) { - const pkgData = JSON.parse(readFileSync(pkgPath, 'utf-8')) + const pkgData = JSON.parse(this.readFile(pkgPath)) if (packageCache) setCacheData(packageCache, pkgData, basedir, originalBasedir) @@ -272,18 +282,15 @@ export class ExternalModulesExecutor { return null } - private async wrapSynteticModule(identifier: string, format: 'esm' | 'builtin' | 'cjs', exports: Record) { - // TODO: technically module should be parsed to find static exports, implement for #2854 - const moduleKeys = Object.keys(exports) - if (format !== 'esm' && !moduleKeys.includes('default')) - moduleKeys.push('default') + private async wrapSynteticModule(identifier: string, exports: Record) { + // TODO: technically module should be parsed to find static exports, implement for strict mode in #2854 + const moduleKeys = Object.keys(exports).filter(key => key !== 'default') const m: any = new SyntheticModule( - moduleKeys, + [...moduleKeys, 'default'], () => { for (const key of moduleKeys) m.setExport(key, exports[key]) - if (format !== 'esm') - m.setExport('default', exports) + m.setExport('default', exports) }, { context: this.context, @@ -297,7 +304,7 @@ export class ExternalModulesExecutor { if (m.status === 'unlinked') { this.esmLinkMap.set( m, - m.link(this.resolveModule), + m.link((identifier, referencer) => this.resolveModule(identifier, referencer.identifier)), ) } @@ -411,7 +418,7 @@ export class ExternalModulesExecutor { if (extension === '.node' || isNodeBuiltin(identifier)) { const exports = this.requireCoreModule(identifier) - return await this.wrapSynteticModule(identifier, 'builtin', exports) + return await this.wrapSynteticModule(identifier, exports) } const isFileUrl = identifier.startsWith('file://') @@ -421,22 +428,22 @@ export class ExternalModulesExecutor { if (extension === '.cjs') { const module = this.createCommonJSNodeModule(pathUrl) const exports = this.loadCommonJSModule(module, pathUrl) - return this.wrapSynteticModule(fileUrl, 'cjs', exports) + return this.wrapSynteticModule(identifier, exports) } const inlineCode = this.getIdentifierCode(identifier) if (inlineCode || extension === '.mjs') - return await this.createEsmModule(fileUrl, inlineCode || await readFile(pathUrl, 'utf8')) + return await this.createEsmModule(fileUrl, inlineCode || this.readFile(pathUrl)) const pkgData = await this.findNearestPackageData(normalize(pathUrl)) if (pkgData.type === 'module') - return await this.createEsmModule(fileUrl, await readFile(pathUrl, 'utf8')) + return await this.createEsmModule(fileUrl, this.readFile(pathUrl)) const module = this.createCommonJSNodeModule(pathUrl) const exports = this.loadCommonJSModule(module, pathUrl) - return this.wrapSynteticModule(fileUrl, 'cjs', exports) + return this.wrapSynteticModule(identifier, exports) } async import(identifier: string) { From 36dbf7f9023d59d1d9b2ce000a197f63e6a67f4a Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Mon, 31 Jul 2023 13:23:46 +0200 Subject: [PATCH 82/87] chore: cleanup --- examples/mocks/vite.config.ts | 6 +++++- examples/vitesse/src/auto-import.d.ts | 1 + test/web-worker/vitest.config.ts | 10 ++++++---- 3 files changed, 12 insertions(+), 5 deletions(-) diff --git a/examples/mocks/vite.config.ts b/examples/mocks/vite.config.ts index 76cb1dad1e3e..ee914b24aaac 100644 --- a/examples/mocks/vite.config.ts +++ b/examples/mocks/vite.config.ts @@ -29,8 +29,12 @@ export default defineConfig({ test: { globals: true, environment: 'node', + server: { + deps: { + external: [/src\/external/], + }, + }, deps: { - external: [/src\/external/], interopDefault: true, moduleDirectories: ['node_modules', 'projects'], }, diff --git a/examples/vitesse/src/auto-import.d.ts b/examples/vitesse/src/auto-import.d.ts index 4259e89c6d15..9959df651b1b 100644 --- a/examples/vitesse/src/auto-import.d.ts +++ b/examples/vitesse/src/auto-import.d.ts @@ -1,6 +1,7 @@ /* eslint-disable */ /* prettier-ignore */ // @ts-nocheck +// noinspection JSUnusedGlobalSymbols // Generated by unplugin-auto-import export {} declare global { diff --git a/test/web-worker/vitest.config.ts b/test/web-worker/vitest.config.ts index 69f70c696d4d..dbb48563fd62 100644 --- a/test/web-worker/vitest.config.ts +++ b/test/web-worker/vitest.config.ts @@ -6,10 +6,12 @@ export default defineConfig({ setupFiles: [ './setup.ts', ], - deps: { - external: [ - /packages\/web-worker/, - ], + server: { + deps: { + external: [ + /packages\/web-worker/, + ], + }, }, onConsoleLog(log) { if (log.includes('Failed to load')) From 315bbab5c3bac4207767486d21a3251db0fc244b Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Mon, 31 Jul 2023 13:42:05 +0200 Subject: [PATCH 83/87] chore: identifier->fileUrl --- packages/vitest/src/runtime/external-executor.ts | 4 ++-- 1 file changed, 2 insertions(+), 2 deletions(-) diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index 3fd523019fd9..128a9d0cd16b 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -428,7 +428,7 @@ export class ExternalModulesExecutor { if (extension === '.cjs') { const module = this.createCommonJSNodeModule(pathUrl) const exports = this.loadCommonJSModule(module, pathUrl) - return this.wrapSynteticModule(identifier, exports) + return this.wrapSynteticModule(fileUrl, exports) } const inlineCode = this.getIdentifierCode(identifier) @@ -443,7 +443,7 @@ export class ExternalModulesExecutor { const module = this.createCommonJSNodeModule(pathUrl) const exports = this.loadCommonJSModule(module, pathUrl) - return this.wrapSynteticModule(identifier, exports) + return this.wrapSynteticModule(fileUrl, exports) } async import(identifier: string) { From f6c5aeeada3f39255b22a409c25f0a2cbd260b0d Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Mon, 31 Jul 2023 16:27:05 +0200 Subject: [PATCH 84/87] chore: support data uri --- packages/utils/src/source-map.ts | 24 +-- .../vitest/src/runtime/external-executor.ts | 150 ++++++++++++++++-- test/core/src/add.wasm | Bin 0 -> 41 bytes test/core/src/wasm-bindgen/index.js | 13 ++ test/core/src/wasm-bindgen/index_bg.js | 148 +++++++++++++++++ test/core/src/wasm-bindgen/index_bg.wasm | Bin 0 -> 59838 bytes test/core/src/wasm-bindgen/package.json | 3 + test/core/test/vm-wasm.test.ts | 64 ++++++++ test/core/vitest.config.ts | 7 +- 9 files changed, 382 insertions(+), 27 deletions(-) create mode 100644 test/core/src/add.wasm create mode 100644 test/core/src/wasm-bindgen/index.js create mode 100644 test/core/src/wasm-bindgen/index_bg.js create mode 100644 test/core/src/wasm-bindgen/index_bg.wasm create mode 100644 test/core/src/wasm-bindgen/package.json create mode 100644 test/core/test/vm-wasm.test.ts diff --git a/packages/utils/src/source-map.ts b/packages/utils/src/source-map.ts index 542ada2721fe..b89a4c3309a3 100644 --- a/packages/utils/src/source-map.ts +++ b/packages/utils/src/source-map.ts @@ -16,18 +16,18 @@ const CHROME_IE_STACK_REGEXP = /^\s*at .*(\S+:\d+|\(native\))/m const SAFARI_NATIVE_CODE_REGEXP = /^(eval@)?(\[native code])?$/ const stackIgnorePatterns = [ - 'node:internal', - /\/packages\/\w+\/dist\//, - /\/@vitest\/\w+\/dist\//, - '/vitest/dist/', - '/vitest/src/', - '/vite-node/dist/', - '/vite-node/src/', - '/node_modules/chai/', - '/node_modules/tinypool/', - '/node_modules/tinyspy/', - '/deps/chai.js', - /__vitest_browser__/, + // 'node:internal', + // /\/packages\/\w+\/dist\//, + // /\/@vitest\/\w+\/dist\//, + // '/vitest/dist/', + // '/vitest/src/', + // '/vite-node/dist/', + // '/vite-node/src/', + // '/node_modules/chai/', + // '/node_modules/tinypool/', + // '/node_modules/tinyspy/', + // '/deps/chai.js', + // /__vitest_browser__/, ] function extractLocation(urlLike: string) { diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index 128a9d0cd16b..0e03fe94a77a 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -90,6 +90,9 @@ const _require = createRequire(import.meta.url) const nativeResolve = import.meta.resolve! +const dataURIRegex + = /^data:(?text\/javascript|application\/json|application\/wasm)(?:;(?charset=utf-8|base64))?,(?.*)$/ + interface ExternalModulesExecutorOptions { context: vm.Context packageCache: Map @@ -99,15 +102,21 @@ interface ExternalModulesExecutorOptions { export class ExternalModulesExecutor { private requireCache: Record = Object.create(null) private builtinCache: Record = Object.create(null) - private moduleCache = new Map() + private moduleCache = new Map>() private extensions: Record unknown> = Object.create(null) private esmLinkMap = new WeakMap>() private context: vm.Context private fsCache = new Map() + private fsBufferCache = new Map() private Module: typeof _Module + private primitives: { + Object: typeof Object + Array: typeof Array + Error: typeof Error + } constructor(private options: ExternalModulesExecutorOptions) { this.context = options.context @@ -117,6 +126,7 @@ export class ExternalModulesExecutor { Array: typeof Array Error: typeof Error } + this.primitives = primitives // eslint-disable-next-line @typescript-eslint/no-this-alias const executor = this @@ -252,7 +262,16 @@ export class ExternalModulesExecutor { return source } - private async findNearestPackageData(basedir: string) { + private readBuffer(path: string) { + const cached = this.fsBufferCache.get(path) + if (cached) + return cached + const buffer = readFileSync(path) + this.fsBufferCache.set(path, buffer) + return buffer + } + + private findNearestPackageData(basedir: string) { const originalBasedir = basedir const packageCache = this.options.packageCache while (basedir) { @@ -304,7 +323,9 @@ export class ExternalModulesExecutor { if (m.status === 'unlinked') { this.esmLinkMap.set( m, - m.link((identifier, referencer) => this.resolveModule(identifier, referencer.identifier)), + m.link((identifier, referencer) => + this.resolveModule(identifier, referencer.identifier), + ), ) } @@ -408,12 +429,109 @@ export class ExternalModulesExecutor { return moduleExports } - private getIdentifierCode(code: string) { - if (code.startsWith('data:text/javascript')) - return code.match(/data:text\/javascript;.*,(.*)/)?.[1] + private async loadWebAssemblyModule(source: Buffer, identifier: string) { + const cached = this.moduleCache.get(identifier) + if (cached) + return cached + + const wasmModule = await WebAssembly.compile(source) + + const exports = WebAssembly.Module.exports(wasmModule) + const imports = WebAssembly.Module.imports(wasmModule) + + const moduleLookup: Record = {} + for (const { module } of imports) { + if (moduleLookup[module] === undefined) { + const resolvedModule = await this.resolveModule( + module, + identifier, + ) + + moduleLookup[module] = await this.evaluateModule(resolvedModule) + } + } + + const syntheticModule = new SyntheticModule( + exports.map(({ name }) => name), + () => { + const importsObject: WebAssembly.Imports = {} + for (const { module, name } of imports) { + if (!importsObject[module]) + importsObject[module] = {} + + importsObject[module][name] = moduleLookup[module].namespace[name] + } + const wasmInstance = new WebAssembly.Instance( + wasmModule, + importsObject, + ) + for (const { name } of exports) + syntheticModule.setExport(name, wasmInstance.exports[name]) + }, + { context: this.context, identifier }, + ) + + return syntheticModule + } + + private async createDataModule(identifier: string): Promise { + const cached = this.moduleCache.get(identifier) + if (cached) + return cached + + const Error = this.primitives.Error + const match = identifier.match(dataURIRegex) + + if (!match || !match.groups) + throw new Error('Invalid data URI') + + const mime = match.groups.mime + const encoding = match.groups.encoding + + if (mime === 'application/wasm') { + if (!encoding) + throw new Error('Missing data URI encoding') + + if (encoding !== 'base64') + throw new Error(`Invalid data URI encoding: ${encoding}`) + + const module = await this.loadWebAssemblyModule( + Buffer.from(match.groups.code, 'base64'), + identifier, + ) + this.moduleCache.set(identifier, module) + return module + } + + let code = match.groups.code + if (!encoding || encoding === 'charset=utf-8') + code = decodeURIComponent(code) + + else if (encoding === 'base64') + code = Buffer.from(code, 'base64').toString() + else + throw new Error(`Invalid data URI encoding: ${encoding}`) + + if (mime === 'application/json') { + const module = new SyntheticModule( + ['default'], + () => { + const obj = JSON.parse(code) + module.setExport('default', obj) + }, + { context: this.context, identifier }, + ) + this.moduleCache.set(identifier, module) + return module + } + + return this.createEsmModule(identifier, code) } private async createModule(identifier: string): Promise { + if (identifier.startsWith('data:')) + return this.createDataModule(identifier) + const extension = extname(identifier) if (extension === '.node' || isNodeBuiltin(identifier)) { @@ -425,25 +543,31 @@ export class ExternalModulesExecutor { const fileUrl = isFileUrl ? identifier : pathToFileURL(identifier).toString() const pathUrl = isFileUrl ? fileURLToPath(identifier) : identifier + // TODO: support wasm in the future + // if (extension === '.wasm') { + // const source = this.readBuffer(pathUrl) + // const wasm = this.loadWebAssemblyModule(source, fileUrl) + // this.moduleCache.set(fileUrl, wasm) + // return wasm + // } + if (extension === '.cjs') { const module = this.createCommonJSNodeModule(pathUrl) const exports = this.loadCommonJSModule(module, pathUrl) - return this.wrapSynteticModule(fileUrl, exports) + return await this.wrapSynteticModule(fileUrl, exports) } - const inlineCode = this.getIdentifierCode(identifier) - - if (inlineCode || extension === '.mjs') - return await this.createEsmModule(fileUrl, inlineCode || this.readFile(pathUrl)) + if (extension === '.mjs') + return await this.createEsmModule(fileUrl, this.readFile(pathUrl)) - const pkgData = await this.findNearestPackageData(normalize(pathUrl)) + const pkgData = this.findNearestPackageData(normalize(pathUrl)) if (pkgData.type === 'module') return await this.createEsmModule(fileUrl, this.readFile(pathUrl)) const module = this.createCommonJSNodeModule(pathUrl) const exports = this.loadCommonJSModule(module, pathUrl) - return this.wrapSynteticModule(fileUrl, exports) + return await this.wrapSynteticModule(fileUrl, exports) } async import(identifier: string) { diff --git a/test/core/src/add.wasm b/test/core/src/add.wasm new file mode 100644 index 0000000000000000000000000000000000000000..357f72da7a0db8add83699082fd51d46bf3352fb GIT binary patch literal 41 wcmZQbEY4+QU|?WmXG~zKuV<`hW@2PuXJ=$iOi5v2;NoOtXHZ~JV9eqM0DJxgJ^%m! literal 0 HcmV?d00001 diff --git a/test/core/src/wasm-bindgen/index.js b/test/core/src/wasm-bindgen/index.js new file mode 100644 index 000000000000..835dc8671064 --- /dev/null +++ b/test/core/src/wasm-bindgen/index.js @@ -0,0 +1,13 @@ +/** + * Copyright (c) Meta Platforms, Inc. and affiliates. + * + * This source code is licensed under the MIT license found in the + * LICENSE file in the root directory of this source tree. + */ + +// folder source: https://github.com/rustwasm/wasm-bindgen/tree/4f865308afbe8d2463968457711ad356bae63b71/examples/hello_world +// docs: https://rustwasm.github.io/docs/wasm-bindgen/examples/hello-world.html + +// eslint-disable-next-line unused-imports/no-unused-imports, import/newline-after-import +import * as wasm from './index_bg.wasm' +export * from './index_bg.js' diff --git a/test/core/src/wasm-bindgen/index_bg.js b/test/core/src/wasm-bindgen/index_bg.js new file mode 100644 index 000000000000..45b649d8bfbb --- /dev/null +++ b/test/core/src/wasm-bindgen/index_bg.js @@ -0,0 +1,148 @@ +/* eslint-disable no-alert */ +/* eslint-disable prefer-rest-params */ + +/** + * Copyright (c) Meta Platforms, Inc. and affiliates. + * + * This source code is licensed under the MIT license found in the + * LICENSE file in the root directory of this source tree. + */ + +import * as wasm from './index_bg.wasm' + +const LTextDecoder + = typeof TextDecoder === 'undefined' + ? (0, module.require)('util').TextDecoder + : TextDecoder + +const cachedTextDecoder = new LTextDecoder('utf-8', { + fatal: true, + ignoreBOM: true, +}) + +cachedTextDecoder.decode() + +let cachedUint8Memory0 = new Uint8Array() + +function getUint8Memory0() { + if (cachedUint8Memory0.byteLength === 0) + cachedUint8Memory0 = new Uint8Array(wasm.memory.buffer) + + return cachedUint8Memory0 +} + +function getStringFromWasm0(ptr, len) { + return cachedTextDecoder.decode(getUint8Memory0().subarray(ptr, ptr + len)) +} + +function logError(f, args) { + try { + return f.apply(this, args) + } + catch (e) { + const error = (function () { + try { + return e instanceof Error + ? `${e.message}\n\nStack:\n${e.stack}` + : e.toString() + } + catch (_) { + return '' + } + })() + console.error( + 'wasm-bindgen: imported JS function that was not marked as `catch` threw an error:', + error, + ) + throw e + } +} + +let WASM_VECTOR_LEN = 0 + +const LTextEncoder + = typeof TextEncoder === 'undefined' + ? (0, module.require)('util').TextEncoder + : TextEncoder + +const cachedTextEncoder = new LTextEncoder('utf-8') + +const encodeString + = typeof cachedTextEncoder.encodeInto === 'function' + ? function (arg, view) { + return cachedTextEncoder.encodeInto(arg, view) + } + : function (arg, view) { + const buf = cachedTextEncoder.encode(arg) + view.set(buf) + return { + read: arg.length, + written: buf.length, + } + } + +function passStringToWasm0(arg, malloc, realloc) { + if (typeof arg !== 'string') + throw new Error('expected a string argument') + + if (realloc === undefined) { + const buf = cachedTextEncoder.encode(arg) + const ptr = malloc(buf.length) + getUint8Memory0() + .subarray(ptr, ptr + buf.length) + .set(buf) + WASM_VECTOR_LEN = buf.length + return ptr + } + + let len = arg.length + let ptr = malloc(len) + + const mem = getUint8Memory0() + + let offset = 0 + + for (; offset < len; offset++) { + const code = arg.charCodeAt(offset) + if (code > 0x7F) + break + mem[ptr + offset] = code + } + + if (offset !== len) { + if (offset !== 0) + arg = arg.slice(offset) + + ptr = realloc(ptr, len, (len = offset + arg.length * 3)) + const view = getUint8Memory0().subarray(ptr + offset, ptr + len) + const ret = encodeString(arg, view) + if (ret.read !== arg.length) + throw new Error('failed to pass whole string') + offset += ret.written + } + + WASM_VECTOR_LEN = offset + return ptr +} +/** + * @param {string} name + */ +export function greet(name) { + const ptr0 = passStringToWasm0( + name, + wasm.__wbindgen_malloc, + wasm.__wbindgen_realloc, + ) + const len0 = WASM_VECTOR_LEN + wasm.greet(ptr0, len0) +} + +export function __wbg_alert_9ea5a791b0d4c7a3() { + return logError((arg0, arg1) => { + alert(getStringFromWasm0(arg0, arg1)) + }, arguments) +} + +export function __wbindgen_throw(arg0, arg1) { + throw new Error(getStringFromWasm0(arg0, arg1)) +} diff --git a/test/core/src/wasm-bindgen/index_bg.wasm b/test/core/src/wasm-bindgen/index_bg.wasm new file mode 100644 index 0000000000000000000000000000000000000000..e545fdfd14d352f0612be501c397c367013def38 GIT binary patch literal 59838 zcmeFae|TKincsKsof!pUdR(Ls66o)Pw#T2xvnW0~tNc@Q5Y@!NA5KGcYi~R5BVo zL+!u-eP;NN5e5ebd1?=+2!d=j6NZ_gjf2!>={5U{0$_MPyzRE!FIYCXVc_$Yxf~`} zu3QZY`M;`ScHnIL?84G#q9Av2soh=9`OIkEMK0$uF5BsxNq+e5&vue$7n7gsj7E+pM|Qa2vEhimvmM_< zlmuhZJ71hRI2_W~Amc{Km56bZUGX6Kci(+Ce{?t?H^ATErIVw$Q9ZoQOb7duJOkM+n7J=hUvd7|N5FdP(E zQdX15#=%fjaGBwV3CEcvbc4&q-(=Oc{zc6+EhgXlBH)fQdRv3N{l%G4Ai%TCrRC9q zMJ+!w77fM&L!ovn=LVLlYUMKV0JCt}YBb2aNQUS+oTGSoFhRn*p0rs1E}5yg@w=)S*N{JrC{*7QpNB1<}p`EL}v~fl! z$)KeJF5`D|G;_#s#Wo}3(#>G=vdL#%^z5STpEgH5u{pLkY;fL&vd!PMI65E{r_sRj zqTo3SMl6qJuN@XBrNd@5tYJio3c>+cj9(yQ5A=^M+!UyOFBIVETttyGRP6!{BA~++ zpuw*^&?3R43%EQp&KTe_hOPqwT*jko-eppB9f;uqV587Aqhtu)0%()~C}Tw+FD2$Q$jbYKQ!56*xS;_aQ3wRg!0?%Y8@WqDNm`Ot+zkpW}T14A2FiHBei!4L%T zE&|(VNsvOoxK12t^HNYS>I$Z8FzgZQ0euBU)<_0e06)MWj$@mvJ%;c>uEBz)G8hkf zgt+ph8I`l6xy~p|DgC+!b1{D z^eny!wb%;3LNCUYX>w#Z17_3ouZLh$Q2cM;-j66JP|#)ZOW|-PMN@l^etAu!QzV;% zJ*I>DxiB=ZGRH&1EU!CsR9G_zPi-=c(bqwS1*NY`IBEqh!{+jG+7mCuNB}*7-n`r% z-Eby3-H8n@Jb{(wZS!6J4Db`YQa;o z3|6C;g(o7mFIWc5;}vQ)R@FKKWRt8GE!6l2bPs2VSs=p3Ws!*m5$qvE1j!j5q?pDV z#a|D#FR6&6zPMW`8}u^Tu<66`m7#o`VGF@f=2kEsIkym}e2ja~Ob1 z!%Hy9ga-8itr!3uL@@HZ;)z^Jg7zrq!Hlk>xwH4su+|I7kuhnXcR9lexLfB;9NDVq zl)V&t4pIhi2yqk?|I2VVr)7~vo64rE4~n<55_@sTBn#S5Dr55MgAufpoN+r_a|#w% zd={YexI9w36GNTMU5Gf81GNPP!z;ZbG>VJ?D94ICLfOhqAkiLv2bVIG^DKh5N5ure zQQsFY4x}%teud{4PQ*6@2PtRn48b}8C=_$wb#MVSB%nfOR z7@^7#C+Z<#V#IKLIx#^FD8C3InaV=4HeaxM-{y+t zU$pv{E$`dBX!)0{{wsZLUb6g`t^U=%Hea^SDW%b|f%YVo6-?934`tomE{%x!O zeqa83mj9mB|AFOyVEG^Q)&IcqKeYN6e%0V_`5#*S6$~TbZ}q;-70bV9^)FlAw|UX> zFIoLp`r5o?`7c}jt9@<0Z24EL{`I~#uUP&ytN&_Wo7XJ=hSh()ugx2l|C-f*v#-t9 zEPvJNztz{~s^#Cb`fvBOdDHT5S^anW+Pr1??^yjieQmyD`M0h9`+aTR?yLXaug*wL zWjq7z%GEgEl~d>?T|wwsF6?!5qnHdpH%`-X02Dmv;v&_evJyJnsh2#2efO zo^9~#WrMfiHi)$ssbpzeNf4p0grsnrSLqC`VgoCW3$73kksU&Fi`<5>s2C4>-N>ZL zFhYXL!FZFBp?JiFu*ywtq&O}XHyCS#Vh2%wL%f;nW)wZ^W+>i5aSKwNqSEKp!SnG} zhQ5)S8$0nfw=KSj>`jn@y|XpmPH{U5fZid!!i2~8H@?|zjc;)`$2;6DZpWc`XA;J@ zx}EOU#rQUx=53m$8;0-cO_urx)?qQ;r4F{nj#`-N5B1c61QGiatEJoJoQsR-EfU_N zO0w~8p6sqhpCTEpM$fQNa&-Q3#De#b-_wb2celrPki7%NN4)~pucYZKqypKUN`~Sw zp59rFN+e^|s6s+luSQ8J-b;ROC;pK8P<$8JyQ(Hk0%^aX>`3t>FY*6efRZn*eb7*FtUq8fcQauda8;xeUjHF{W6dN{7I z{7F}FlaItzzuB(3DGI_scw3`sjcQxATGy$lSEH|KIMNxQF&53lQ*P>DJe|Hi?O*p# z?xo?q)#&Sbf%Je0!}tKD1C;Fb1Mz+CzJu}owtM%lynG;jfMyR=qpNzE^qXn=rcwa+ zt+f1BntnU2|4v%|ZkoQG*1waMUlQ(X4-Hr^h4GB$`f?a2)X#vXdY*uZ_WZ>#eo)W9 z5XKKt|6n!xp89#H8hu|W<-@*sOsx*b2G?WpK`I}vM#AEQ)o7=wA@Lzfhp3dELE~rQ zN8BR^@(HqEsU!8r^x?Q zC;o){MEpszpR7jTW)fl#qV!Kyqwi==q%GC9;!jihbT#^}YDwR=#&2ihpQilN)#x47 zlkQXNeerQh$H5cTl72r;e~_kskf!HZ?g^Tls7A|r@qFA+vK-G+*{DXRNM@_iyedz{ zO(pX&6LL-1m-=YIzLZiHSEIN`ja=MTvL~LSvh5)<2Sf^h#86~=d{PZ|#;1@&r(~1_ z?j(ka#K>vh!6xlEM9fIx=Ql?4mm^%!aVB{sl1tKM&)`SRA!Bl4uBhcX;mX&QQof4C zhqw!488i9C7zc7R;|68nUq&|N+y*AeJj_ji;K|9z+k-Kx`4(J+04l^7ly3Mjtk}y4 z83fFQxJZvTU~Jy77;m;7H`C!;0fHsxwshjH$b=i+jV>&1(YB8vPjYTs2a$49yghmK z3a*8l>EV{-b!B%j#hq@uyIB&%?JUN;a4Rp|+KF#-x5c}XAF7p;JSe^hBh=)ciDTXx zrIX!mw;Ofwj(87++ua^m|LySiJKUXz;xVfBx-qwRG5%0We;?A)2jjbvw}W^egY4_T z&G);z;O1JuJyhM(fsL0`HSWg8kUbObZt-hCyf^biyg-wMTIK}3loKXaposXau^Lmk-S z!|p+c_9=!4|E-qcn#NzO5O;7T-}yS&O8& ztVZYKqe_x?3Ib@R@Y;pGlc7wTPFW($g=8 zaGjj{DfAOf`V;6UN+~0|t^A@$=#%8(N>@VWq}O=;Q|arU<`JCfduk3Z`o2=iuchVJ zNyjL`n@C>|;YK;}ChHz4%yh+~`M2DZi4IU$yzZ62h$*?9~w7lyk7F zE9xAsgbr!t7t=EOp_Sjz`#k@uz5hlCGvocQhH$W)m>Ov2PN$gYakE2BM|@BXx5sCc z?2PAOe)FCOo)Hg(&7Gy;*-m`Uof8lIn;XJ`%eVyoRv1ffH>XM{*GH7XEGS+L<%AK@ zWmHF-zpR>!3p;VhJDK8t9}?rB1zw0p@GnN_mV`W#%p=255{Pli7eNLP{(3l4@GfCq zJY$`p@Q((?e;g7)@ZJ(RS_7s_IwGG==6X&ZSbOT^$;rusjUq<_z9>1Wpjw+0zAv0S z^0s%KJhqCc_}h#a^rl67)%$0ut3{nMr|!a7OJMF|-?0`Ic1Bm0hpUCfS)*0%BHu{v zB4E(<`lQ|BaaCL^k~7Og)Mn6Ka@6%}MTz%o;h##E9NFx;ONNvExFu_3b8z=o!@AO) zG3_mNnrmgYMAiX0%j5m{aA?kZZ-s_kZ)wyu5;MHh7m<~?Wg$4BR!3yz5KLZ=|1<{{(K3{d*Tg9y4{XR_UjFez~G{9?>3tk*c~`Moo2rs1s%dv0rT z@=w7KEoKQXf+6Cw0;%O|PchTOIteco|7VXQa&TsF#`?a)jP0bn@S#NrMtQZ1)zFFh z&yMm43@`p8>%qc8{sEN`q(>oPx{9RfI+=gE5OxAkn&X@;Cp03bqPY;+A#dF?0B|OZ zZmvdJr`RR9`gee08b$9J_4t{=1&n&a1nfz4tx@kXa^givP`u*|^qkI22?+6+Dw50Q z1|N~ReuXeE+d`ka{i0rBF_+ClN=`xP;vKh)6s&D8cx&86J<2nkNr07k7DMwa!aoLM z$p#<*Dy5#qD2AW2QSwYPo+usa^a%hMEc{+R9E6og{2HT*7+f2T<6ES{C@jYF6LL%# z*ePo6!|Vy%3{M8CT^J8WGi)&tIlLsSL?K`%0*|q2yUe~I7~POuKIVJnP=MQzyc;gY z8zdhx`-3of0OgR%U5oKXrm-P8E)3k53@p3BB{aoM!q66O9#kE#M7*-3foXhRhXMv^ zKD6u`XVx^%s4>qsFN6F)2o{%^&6O+P3=R>~&k#7^lmh+|*y~`2_4sG37)B!xuy`fo z*eV8-%a3ZX2%VWX)&6Ks{O!&TI|Z;>Cm2kI-jtjc2O zD&b7(0Ka7BFq;9aF&1gyGCLqbJtbqClw~4p-*&3l^kk>J`lvHE3?j5B8#j#e(F|k3 ziZpE+775lFBX<$R8h8-nv}SA4mX|w8#^Q$T4})vNq6Ge-t+yI&yul{Qo} zQ7@OV9B&x7g(uI0CvX8w5CE{c6Ke)~Va*7gHmI3_Xi#iSj;&F`=9*vx8*st?z#$8e zSci5n_0i0xOcaEX_!MpZoQb?&qCb+3as&%ALf}jnQs7vSY!}QFSArc0wU|{#6Mz|s z`aw`=<%R*BDj+O|=mH>g=`o2|j3BBu0=i^#dXfdq68R93I>J_@2J#KAzlrPa zt`H(q_|{-}RL;L#ay4QF9N{>_;`110Ad5HvlMv}cty1({>LHvC{%D9oyn*@+9SpFI zv9POPmRw$3WynKW|GFWwU505e+`;X)33Dv(2qC@{(M6Gb&)t`oyAQpPF68dZ%gu*+ zXz5d`eF`Hj@3xw2%+gn^@hcIATi)F$H<&OjFYhD9WH#PrGuS3DYFan>uD8~;#kh&ju=zlRb&z}Ey{ zQhb4y;smr5KcA&1z()ZJzhFx*p1{5&X<=XH-8kM%63om`sZwr1l22h>=H(s4!s| z*JGHw*V`IAI6zYjPxCWc>-(s{0{xCQhZH{})iW5O_aBTONMC;-HC61%3=L<@B(*g4 zGbYp~=4YhQ0sMFm9*iF{yn1Nmfr0MsRf{x!$%NT6-9D~j3v1qJ} zMPum|!Ho7;ELMKb7oXSMpTpiIc^-Q=FGKe{31;uID$ir@k}SuEseHuT*_us$6fTZ#G`VY#7(hdbmQh9k2GS(fI*>KM zCADQj9T3Z3a$z!XX({>K&%ZFZ$TNR3Z2f0hi|w!b3{f|_-UIBAjz#p%%(QbfrUl{Y z(;5*IXptQCOy2$6kMfITE$!g($<8OmOK2+y9zoU2Lx+rKIe~UMUEe6`YJmOg*AlF( zg^p9G%OGBNavWn+BX7z{SB=tcqLpr(8cF4`IqnpQu9>2l$+BOh9HB}tdh?y^ioTQA zoI_zJ3cPJ>-UU6(B$r|)xfCvIvZkVaI*_B#1i5C08Zrp^4tA9`DOA*%J9RpEgk{i5s^gGLy{U)r zriR{|x`^b?xgzawgzOIprv?-{tNa z7UdTIsN95~Gnc1%brGW;>ig+yf6oPJ4#DO4o@6_cIOj^{;>EjrPw|}Qy%SMPvK`@@ zlhl2NL=xFNRLJ6Vgw^r6bc@m`owo2EN!(3Q7^M?apNEmZB*zfEg9zT7o9@K-q7Z3M z4s>w!-ir^k?xu>k2c=)(-<9f?x_0s1$=iFvHdmd^_|6g>x)1W~!A|@TojpwU;SQqh zA$QQtxTI)4$D*9Nk~)v@7Z6rWv@D%huk(n)oJ07%san!+rRno}`h092V#Qo2 zokBR~6iWhxB06aksz2;K#m5L-J?@?;eghm(bzRP4=@(BTR-W`y_9K$A5VQG?JA|#C zl9YWlk1Mf@$*_P8W=mp}ZG#oSb4CjCOQ4_YbpJYj38*?sR{4_9?%}do&M>U@B}pYg z2)T@$5k*AOs)N~??!jyvPV#Gp^kPTvbMk8rbZ6L2d1n4hoFTZnu;egUaIff$rsZ*J z%B~*3U&txE0e^;{BcQZDLIueg@hkI#=m6a9oEfw6@Gbb`X$+}m%u*213!whskzvky zz0JWTO-~|Z;0(_OI+9Zy`A>Fr>}m0T34xamxEH_6dAEbZcHkQ(tj6dt$$2;}+rrsF z@n^t|YbVe?Nmeg+D9WYR=Wxo|2~5l<^Ezp{Izt)(XS_k_8B+FvdXBPEuQOx76xEM2 zX&j@~0+>(t5V;0Q4=^h8vbHSOO-6>YaO>`YHNosLPVuetg8IZ!vt%=sQxl(G!Z8qY zb(x3KpKa>`KBMjPQ|UVnOwSq`Ok(TeoG{yu#mG9yf`m%vs4}FNFTNphB9E~hp-T@2 zW0uhSK&q#3v?SF^2BZX{G|2R{11D>Jt~w3B;$}vX>q1FeV^D(TJd|==69HICM*KuI zbtcTwUVQ42_L`=SH^I5&x#W4n)E#WM-;yIc2q2@x1Vv7EBlpo!>DzoL_UINpp;{^d zD1Hn7ek&~e=0KSDy09FR$z5jd%S8YJa$0{h++jfC1hM(2z&mpG9GLFM(_nz-cq&&K zM6pcWYVg|%yO|qK7&*cKV8)twub7k)d||5XQ%VTMo2QRT6cY({tI6O7b74<8A(tvA z8 zx`CWIo<_0LZE3$Cm+uC#B!R?xqqHdhKbm_leZiS)2eerP-6@?J-GClU&-()h>7t@} z-%hwGlL;eEalYrU*|oz0D?B(JdK=^fVqz>%IUQX0Yfa~m^3-()p-D=K!5;>Yr5}!h z2f&W*H(uioQkUKxq!v1#t^GA1U?%_sUNP^GNG?>D>@RLK`G*FX8gArtB5V4$k>$|k zWcv}n2AdYnssxK3tOro>PzsiCI&j?u^leJtd;$Zqt$EGDHYBC>7q)8tfeYM_jUo;J zvlP)3{!A`<@bYGVK!B*}$^ik%%@Zu2q=oil4l3CRdA0-H7(YTo9V%3x7i({sSEYoG>=+lJ7a7? zPca3yV@CuyEwGK3QB>Vc9Te5=IzMo;yLoRWKrPwk4*TJ5;jJCC+0j8a-6@^*R^Gae zn%g>@B-^DL=bYX;;%;?EG&0fp?NVXfqqR(lk>k}`r;9uB9=bJc)BHuMxzpXLPL8@g z?x-JnOt0;w8}Bx9W1aXeUh6wNKn+L1^x83Zmphh@UGh3iErZg#H***rCU76t8T%p* zqrgrXsONEd9`B%dPN=Hv%IfEFS8|W5?H~@Iz>XKFZI!mwj6vyyX$a#U)+@1iM3PxiTe+J~oTx}T>0w4ol{|m2F=*?s zJK`R7kGV$~ghn6cnfIT?Pb4pEE+63($VcqNkWlSOo#0A^5VL_5wHWvPd#1+`(J{9lg~OqxECriU%X$KwCPZGn#; zr!yoh_NM>?HF&~wuiJ4LLY-r9Wx7LRE9xCMrUKzu6h081G9_3}&Mu#6mH^#26@D8< z-{HfOU-XDS;fRjr~Ut`{9ysOgczagI`eQFdm z4j~?9s|o zZem)=n}7Ujkd&zy>m)x?{?$KmH7I@(SVhKo3jZ<_m9M9qg~dlu732y4cHCtZ7UUC$ zK*`D?<(i8g5Wf~v21}%zO!929mT|mTKx5W9w;^vtU{Y-2K|I%sW085vwuQLmdh zV!T;>pwi$wrb$)$`(V5UwPq{Dt$mh53Ckh7+Hz1Iw_rKklJ-$TU(UK3aN&J@fWq4l zIJdLzR>FAH-bU8j5wYoT_`1QTIHnqtVAPGqyU7w}eoB)ndNoOhcR_`jc#o2Y(ebi! zVoR05dHpG0I^jz#UpnPW($ViAdxx1DUKPYeP3>N4d(r8vqSMc*^X;gESp}z`2Mm4c zAWEg%S45eW%6yNKK@`6%#=||uvWi*E3lbe+4isV*V&TvZq!7_Sr<2hKr4aqSOjNr( z=oRy~hutr)Y<;5 zyTKcd9AntR%YB+NnA+fA>w-Kg&9;?!`VNF(2YK7WTF`A**I)8Ow! zgXgWg=;tm|-5oU?E7!>Pq1xY+r7UMAXWU#^KG>EYc?U9q-G;ynp2W~p=C zII+}F>Ws3d1Mle*DwzR>{|2`TTU>BMhvH${>B9M@MNi8#hd=HQM%dBSHw2;?#~lGl zk1S?cR_9SFG_ftlu}?O&$=DnD?iI&kayJ1McH5kmA?|^!+YV`ODYET?iX~adJu7lo zXE#eF`TYIoZCf-Gb&H`1nO5w z6iy-vCxJ3`$HZ_*=TIn(!8zjM9|_}87E$~k6qd;9@QS9-fI?6P^2?qwj zy1*NZ+l`rE7jlS2H8>@-+A+{^3>+{sY=u>beE+|`)7h1s&c63fD`NQ{c6$At{y#F| zF2$y^3TL5U@gV}qW9)_j>5iy7I&Stb2^z#PUwO(`&ihi)mvr6JZUxC(t`le$C6E-_ zNVa$XbU;UFo|C}m`Y8{%81}qRt|)Fo@dc#}_F`K8LRu#HYtJpdLOa5{*6u55z4OIA z>f6CaNcO-+2HYl*%76~G?Np^)izGXd5Cg7gamWF8gT*1O{F?fs{JQSWZYIAO@!__B zaRUmIe^u2tlJDJX9S}?5TNq=Y*?@!u{ziDnfOrVOO6&A$+UYmb@|$UyFr_`OlQ8B1 z&8!ZuAvu8P8PI{Z5()A0iYj&Fjids%84&U7GfoiykSYi9T#^jIJObyubcUl?pfaYN z*F8kue^#2gXJw{ch8C(!Lp3@RWRB~g7!lowxM!E1e7Eo=YVJ=EzSId5aB5BX62+R+ zWRqh{9fCq;HDv6%Mml$$v~c!;slYqZDRmNr!jY87S;X40MbHtl4LSgeXMX7_LyJ3X!!DozoOLS7N+s zXH3kDO(V{A2A`Kdzrsa+xABa*w}zc5Ol%eRC=bP}wItJ!hFo|K_Lb4Tz_zx!8;=qp z3DJbMxtkU}$MTa%e(<@gx=0D{O1`744)Jh>viMmrd_YRr+ROOSjMH^|=wV*0N9v3C z7zun#Ye=OBoLMYc3>vm1SweEyCx{dsV~M?fHcI6v#6^i59Z9&vQpIRhM57_u8Vjbo zK@<`!Bur>(19TjcYhFUGt1iQ(uk={u|H0UumCg%6=&W2rip|@f0{KCJx8}?h7 z@K#Y+q>Gu?GD7&N7-7~JA>?OTGdfIGflO1UjR^`jWP{*OkVQm@vH}qrX)U9oWOY-y zE_J&OTO?#HB+hy#gDLf%IhtZGY}=%!S>uuD7gF=lFOET2m(DBEjCp>dBLti~U z!!xA3ST_l*TL}zXr=m7fqKRI|U4iYPQ7~;ZiYyT2YBXviK)LjN{MCvZ^2@=_X@VrHt`*yT1 z`KDqyHzl`W?!Tj~EyLX`F2`JSf-!Wr6giLSMG{Gt<=TnGArb_XS&x69cWugu6$qZ%4d4nsK}3=#!?lN6ApEU@6d+B!Nw4zMw{@5`8n@xFQ)7xW;9 zD_CEfby32WAS041MV>dvoraSH?s~B3T@Dtg536F5{ z13#B+SJ7LUZtu0Xt;yP6hm#C35hjsF$85r*nKQcHX=^}(s;{gfoxA*=JkVzGIXR6SjC2CVd%VKXeo~u4<_Dcv0-EM=3vD2^nyg_CeVCDv0-E5>DP`Rxh?Wap#j5I z_@IQ2oOB(>Xj8lgw@lr}FqCbulSMJigbzvZp#PLfsb8PhXEeRNe?x`LUzJ#ruJcDEOiAz~o-eMNY9bYK+oG#aB(pK|-hLV4=$qSAX3#hl+3KtlSDa0`~Y_2#5sn~avWqaV!%gliPXn_ILtZ;+8_M&tc0ig;V zC4-;KvdMFfZB&sE8v&W3I4ONv*aU5sTaSciX|quwl#ns)Bel_)WcwoGVxyp;(eNO; zh^rBl35R5tIT#thDD)1o5_%=#!oU`owr&HR1+y3R&ibvHCIMV72VnRxM`H*&#?RU! z*38>1HeF<>MWWlTT4Yf8yHS+$pYQg;{^ZU$YfB9teCclopD=KmgrHviB^x?|K@RH` z9%7BIj1H>pXMgTDIB}=|R`O184#0)W$)Efc0#Ek@!M#8^mwdJZ5b`{oKjYi2X~88I z#r}f_-~H=<|DKOQ2ZJ%MrNQID-(b*xYWB6C1l_T-PWANN8#i~|{$ZD3K`z-SNwKOA zoV=^%D)dPkV2v|Kjt~%-0Gse`?gUMW1*rx;K%Fi8tti|rje*OKY`(UB z<+39*u3K(q7}=diT|CQ5JBy^xc~#+vKguIjVbNc4w9AcB8Pb3OWX%Of)C5;Ny6Q>< zy=_SiAo-8Eyl7tMybPWjp?ou27vr0N#7(Ad=&l^MAI8{C=Ejz4Zs?VA)N)%<-djlv zJja71_<)8;u>EjxXx>}3M!U*rXU{~Cu(1A%jLDaOo+e&@_=2*ds1dt4l;&KFGO-&5 zRE+m93u6Yi$9E*(S1bESjh#>V58zw{&Nro>d2qg^>{@V+t_9~;erXjrzY&GG%WOdu z&4A2T6hcpS!9wgliG3{}{e_agmLK`AE1|Kz%kufi%L#?s|3X?tKUfny~QoiKig1gr+f zr9y5eP&3dS8WU{0L~GhuuNMAFO5!2H6VN$1+?<`2(p!5_z0FjBuE;V~h$V*>u86)Q zjkIv6U)GyW>R{P%>p}L3`A66sg^J3gXVl zOxTC(q>9hvGQ`aX3@>0QgqR5!35zkLtTSEKZV1*XQ7*M&lq&DQLS>IrP2TWN+S7KO zFxLM-oZk;!VA?mIw~+I6D^5^tX=aBGGmK_+-vqHP{42i2wF!G=RNvIs*0GdXT80go4|3En#0<>v()dI&y>Y7+Qsqd0hz zt&-(T_0SH+664HxH?yIUN+4270DP{7hsx8Ba_7ARSfBaM;}VVsb?s+^cS3Juzs!N&bE^+=2ZL`q>wrB6 zFo>GqE|(zd;Cwx!3o`~;j=0!Ycy#|FZ{Ni6XN&p|8L<_9euz*$C*-^2o7f?tPrc4{ z7s5Ms?FH~b!#b-iB}bUd(HcRKVxVtF=$q^m-`!>Z=<=dg{dQ}7Y#?8=M&cP+a|pOC#nJjS^nvrLCIQfJMFi2 zl5fJ8?akt*TR=(LVntj3EQbg<4q;hm)(t4H7U}a)2UvVdoh5)>Ga;llSDZLU9?c}2 z5Y)*UfM(fmU_rZ3oo=U77O8oqeFe!YzkHRxpee5bME<xGfAF$yD)RED{F4*Dvc*uc zvNtWmH}O34X;>M?);|~P^xix(AsLjTTNDjk1`CX zMY1zu++0&K?hXMXO(b$)`4TyHM$_DP<{}&Ncdv~^bWK*9G}KiF0nGaMV~Z*0(GbiJ zUTJ!kTyQ!n#5&V61z9mry4;FL*y?*9?0VCPQ3#gkhnlwxK%8mfI79>Gz@``3s7MM> zNw|ZYAd!#B)Iy;TN+PiNqfvOHV3S1xTpK}9h!2<&;u9~E4?c|?5G7Oqfk>m6l`ff^ zH}esH%g8{o(T6j5B=KCB4t6kTrudKu-rlmn;SdO6aalzvK!|;`Cw}TSS?5A6x#4+` zy5R|`3M5i!QKyTS=#B372e+(JtRwCjvm^Fo$0}DGPqyg^%e{$?{Y4ES$*)D>HcvrU z*P|e@D?tJfq%?D13K4(?fwBiKuO?DN_Ij3Ir#&Md{a?d3a)E|Z=e>Bu3XBg5f3|MW7JU7)b=*i9MDM{p3ODsP zWp=Wfor=(L(vB?GaJJI1-7mMpSE}Iyo&wu;T(lw+E&OIW@!xyV!hbQPjEuY(*Rs?e zLhw^ZyhmWO?*`K0#6b{zlGMVT5PIGnc8HaGBV^?VWE{!_HU zxBmvVLBjs zzCXAPi5RiwcS9D2Pm&21NR37MUHG+Q+&Rv=_BJ;4jr+Dl6Z(ZNjz4n zurVv$1HN5*z6hKZa5s8shdWS$P0jcDq~xDd=~=yDxCjPTuM2jTKs%P$^FM+c#|hy zzQEX1axnmmWTnM|nMB))f046xT`eX(Ckw&lWj+=8#;uv<%0JF2S$+5gp2g*G-baPg zXKbh(a)U<5Da+E&H|UMug{*mM2SW5I7=qFM6?;lRnup!5!SE2*r~32MnO~))K>#aJ z4c4%2r0~yDb{r-BN_=;HU6#ZMM$^*)g1>l@{q1V++E)x&_7+>Wr>C*Vexl0GhKVouUvZt*V(da)ePtLQd7pavJ^Wi zY)T1B**a2qJM?Pk`o1c~sSTecUvP-*VYLK7BtI>|JtRdD7S?l9$)1tfUSj2ZU{JPR zMz-Dt*sE>sBXV0A4=eOEc6n*Ik-dpE`PQpWM`zp!Ukw7(MNF~cBD^Z&ZlJZb-Ly*Q zM9sdDr~bU+zb`BNyP*$%JG+r-pbd%fa8l6X-rYNrAct1^$CU%kep@ zU6<0>j=#Q`n7}n(l$?+uNfj@=#2vSa= zE1LSReFffvu^*>H?7|2G`v8r7iHKJEUVq`=`kEg2;Mep{7~bGbKDSm%03#jXNKL&h z-c6AAbOKcKJxW1Th^VA@Ma7RvZpaiSF`tQ)S?OX(1LLdaX27|VngOd#JX3jTjCvsb z4&6=cqo48^d4wHGwK~)MhoHWGZ8u1qbiwrCu=Los!Z5=s6RdyzKJB87|@*#=*zj#-qYjF`w@59B&q=Kj@$#$BQFesNXhu)J!&7k?<-h&K z8AE#30EXR=Q=fQyxHKv&ji0t8m;=u7AnlhAXj-3_nI}DRe8IjkN6Ls7)EKe~o* zv%B7~2f`v8Iy7p+*zVFCmsbSkMq_=w%ewwffxD3l0z3d# zeHS;kQPVqzfzQD^jJD}6K~7znl>t7{%Sj z^oZTU+RR&FP$(K8_^Z|{WX}z0X=Sh*#H2{tLZuMDHHDf(R0)XRZhV`>1$JE`zCL*i zr_2YzZgpE57w8f8H&U}WVqt4Iv6M+B#EY_|L@9R(`sN|gCal;|X-veMQ{KDXZ&LNl zDOtRjQ})|`f}OgoDRvhY)1c(Np?`7D0*c@p)6W`zZn)V#9Noo<#6Ft*tS$j!Cf1UT_Jy z0KPuIzF~cCWLl(eu0Tq$xJ*RYn{g)hwO_v(hFioXLy$%4-0DLUoPa=O22+aM@6fQs zT2tOAM_F!%KOEtmo??rxaA?grYNwn0MhR?rMthB6qXpUN3aKF(?YvGrm`5A`2R^PF ziW3E9w3%9eH|{5ys}1mPd9J_FlRnoN9Z+9a-4mxbjnC7W9O>5tO#UR8+Q;t9eT3gA z6;%A7HgL`Pj}jnT+@>PmY88ADHNp`2#8WT11s=uhx<7d)puV0eZW(zLg`cZK%3aSl zb6Dd<+wa8`Gxqps%ITQqZ$S$gL+ElURY)k+ed&NNNj&l_6^|BpR+zvd0%A?5V-~HE zUFG9M>1;Q6bY-^J;;XO-`qDRXNSts#U6grJbYMd+6cV&eshLJgsdJ^|pHzHOCqXMc z;7cH@N`_gIQ(*8`qfwL^Q6}oqkN{{@Y5}hge73cJ-Lw7mo;$T)VZxhZ5kE(Q=s|Ta z{zs|ByrMgSg!)P=-|_Yrb9FVBgBZn+fHoEsMLy7`x0ieZt!Vf;05Jt^sA3-oustMH5}Ht@?$}YO=mV8AzVxs! z9rnpFpKMpSLWkms?TS7ucp<$V+Ezj@b^ySxYm3Xt)RK)wl3HAhH#k!G3n>t}OcDyJ zP%geQ`;d)4=pA7?m`N^GLLcM^=*1H@^B~8vjZd4hg!*{`c0jKJi|fmV!^F6Q!2w z7=qV$DW2@&ZBUYK*7icph2rzYUy=J5OSX?e{)r!}{HbR)RBi?{zU{*}8rE-~DP~fV zSB+$s#!%2qvD09}9ZOK&e9P_0#;wB{JJ#2i*xfJz;vS6T4mITz3R7w#M15|=w12~tW z9%z{zDXi?DTf2XPl3y~$s9r|;`Oz5GYte@9R+9Eg$sz^Y85F4OG#GNJw%AfpZbA~d zY1!tM~7hQgNK+$qKXpr7c+rP+`z6{8$L^>jJ^(Pf}=r;qB`PMxPqp;_sq) zs4j($<}!#Gn~`-g#DFWIN(LO_+m|6H8cjJ|PnqRhE~ihkD62Nn3oAx*?^j!8;4>5Z z{GF+?CYKde708on)3!84_Bf zE%7~g^|xAEl5)l9X?W0dpq*=nGz{rifi7d5;^)1}Ck1*3|0Gy}sI*5A0-Z{;U^2NXHf@Cw)!c7t`agn$VbDL@NFa zzw=@|?>aPtg1|R}gz}(;r<@+imV17~|t6x)4(6O(e?`#|k5oK6NP?@)x$Q zwXQ&hZ1GRP>GdIjVLBN02ZMl%|Na;FVP|(Vqb^&pT{oT}Q%sTxL{wNFTui+S8uo&H zc@s=uk0iym05NnX(A(KLcHc%YJy4Q_-tzn`JWNRP&p6Y1e1IbZDboLhV{-fWgBbJY zxP-vYu09DPPAj}(jlweH*B;4zN$Mfb@YhN~HdO9omYkT9ieav7`P+;tt+dZ?vi6!v zp#1E5c%|{gAT_L!x%q{C%%+P+UjMK*hEBpGlbrIsfJf$F5*teSaE}2?7QCNvGoHbT zt~1c}2Q=>U{)?IG{P<)H*A&`xe{_-(l**?ifmP_g-{1G^lboXW$Gth{>@&i7`}Ilj zWqcOb{`zEL!2_ExqUWNkjuH2^n>iHuxnZ3-|1YYUZbHENJXlxl zcLkA9s~0Nu-W>blJ2DrKFINt{ABUsbx+Tzc%6QifRegS%z#bB`(z19^++>QlLYL^_ zXFX^1m*!{z(rEp_PBy^Kloe*g6oqmwBUT8%PhR?>SRt}N^~ex1`kh}{lNnr}UXnoF zjw0UZ$oSv_R~(_1)s7PlCR>pNd835mQ-V`An$iDUwilyGMV9%1<#~e+#GuTUlmQFo zcJFOqRE-o)u1B4$+h}rSQ?zQy6=)J-R7vDVN#sXq%$G!d+TJlV$Q4ngt!jEG`ZyxI zOVbx11#h+o47_HK*72n&$jx_kzKMd~-6?Ie?NnHp@9mVuDwAM;@Y)w=FV{R@6~BELJ#NHSgL{QV{=w~tM7q)hSKG`9_+sISw0unS7RP-&>wx1i(R%wkGw z6-g%B)w-cZ5$2=oNk^%W#y{DNVn8>hl$$-RP5Go3K@o&?txLDpzhN5GFX3yO%4mNB z!c9V0B31;y_GFZ~;;?laMhZXW=l&kN0OSE(e%5QjbS|XUkrODUC$IbcSDN+XJ|?)D zM2IyFdZwdKn)2CFxXY)hGSu%n5D?16%|OAF!=7{b6Q1N&Ls>}u{#13@DyE!oMHraa z@A9jW!biJZUjyKPG9|E){czW)ik8~y4HGTFYMY?Igw^&)FLepQr z`Xe52!iVg@j}@y zQV4v8Uf|U&K-{c4)8T~)kDxvwej_Hj!V&d)j~jxe62_(&TDVJsv0qJOJ4XtKd*aTn zis}v+uSsFhopO`r{vMa<6RBs}YX;ldEgGi!z*HQm3+ViwplV(M&S9a^+0fZ!i%2z|{4WEdOkuW*I7I#HUrBUj#0f4~<5cjDVL~q{gySF(^D}6cEio1!}9G z$_|h`TB=P+KZC4O3|z_-(hEk^`EBIA z-+PSrzOdeV`g}M#+;x~!@d{oB9-6LZTnU8>V9)fBCXnVSoyCwQNUr>GK@+7Ih+O@vt zJN#1PTDVTU*EolN@>h;r^U8b9>=&<{*?Ye8%h$eBXEk76D0F-MmuBD{LU9=U8x$nd zAPja>;UV35G*JZhj}$6F1ZRg}x7l&J$lrl2zHMjgLcRcLA7@m&fY*!vU3d%G!iPNU zWDA9Q`3!`~W*7fcP0U!9KCF=y`tJ9{zgh$9=dH}f3V`@zY@|U@~+`e>SghtDmv9a3%Vf zPG;mip1KsoUO7mi40L4E8*F!6xAT$0&ffkMb%U7w@Szd-X;`?0hc<1%`>ii><|L!`pqp-~{(S8T8Z{<6g2-bM=3Yt!WEQhHvxs)+)G5a0I zL>HNF;mZNmPe(r!!>eZ&3tQ4@0Od?^qZdotgbA*IG#Kk3bVO`JpCzH5Pz&n0qV52=L{g{Wv|NSq0{%`!9A08{9i}?Q+e*248 zt^}c)Tn!3;e#=u!r`s*Jyx=aJS~`91jB*V(-&i`?UUJRG`9|~f@@Imeh)fTHdzLO< zSZ>}^pQ^RXwaLly>};bxTbZa$jyJ2d>STSYTC3NmTI1vGW@~(+bkF?h*`>zPXYOgt z&o4CZxv27Gix*Bo2@4nJTW+@PPM@3O zt<#$BxrJwY^L&&E?c}dJ?~jrf4llKrod#T(bF&K<&$TYhEw$T@MYfkNvF;1=3(LKC zK0*7f{PnHp!o}I;rABjk&3brib+3&JbhzAIN4quc#x&6JCSxwU#szor0x;O?4!8^L z`MJAWjpfGO^X+qEd%N>J!??n~Zh3x9d5N;t6Y;k^f5A1H&Gv;0T^OA{C!}c1yY|x3 z!qT)hvc1IeE`lhH<|*6U=0dAI?IyCt;6wCr_Vk4dr_Y^qt@d1lJ#$dm#WwXVp5I8i z7S&#$UU+teKhcB!QyX@|5b-shZ=~+=0YA@c0kSaPIxZl%`&}sry6tnc*SfE5f3E%P zI_(G2_FcYk)=-EIUA)-7u-vT`x8MVPxF|npe(?l-_VbIZ0KtDsyMHJ&!C+rm`zF{F z_-is>Hs-|R=Y=iP(-+S@yVN*8w)cdC1{&_fhat`remBmx&n_%|rc0#4Esz-2xZL*p z-fq!pe!%b7PSQ>E-{tQYmRl<oL6^X)u;n$6RE*0wv}ICr{v28^I>i?*VrM?kg_ z(r)=sS{6+8r}b*@wASu=H3z*TT+wr-H}KcrW;5k2{E61OFcZ#g__9A zCmov;uNsaEUf0eA;Q@@kz*u_TVl2T^*G@srHS#0iHY(=WnyxoI#HXbPfV3dQ4C(G4xtz0ip zRZ5ld%0#7HsZ=H_)k>{WuS`vrCdVfyCd-qR$;rv;WNorOIaMuH$Ey?7aeZ=QsWx7lsFiD#+GMR-tJUhYsd}kCUZ1F!>y`Rsy;?`*sZUKY#VLlLqU$MMo1$u| zaqeW>U07}`fePnZ?dM#Vjr%9y3nJlkvn^7CKc7T$2Eivbc-YUAjslN^VzR+kesJYV zkUiHp+YWz4*?%4e51o?saQxYYrTNzMbYmWoFg<}TO zz*GA)iQaot>}9o4YRr~dc&pyZ)!%aglBOE5!p6_m=D?R)3FT&BpPwZ}IX!*IQ+s=9 zdis2W4LDVA)+WpC%2Z{pHal6JYURu8tuH>c|L*{Ruy!LlFX z!ZQ7uJO|1PUa}uYwk}=ZrE;q|2`bJu=4RV-bEUZr_x@N&*h3VrR=4?9Vpm z7cQW>{oK!K%!#R1W1>Dc*`AoFwM)%SyZfg4?9%CFjo5D0=i0SaX=<{1m$=lXF6WQw{8%TC*|H zY)v)i+KsszrqVsZ+L@kSK}%q`aC~;*xi%G)s$ONvoA2`LYC_-B z(+~0Qfu}%dR1}Rf-mbRbTCE9ac&bw0a{rIr`{u=^B?QoMFWz~7e6rMp-_6a|nk|@J zZR=0?{v4aotk-5+Q{_gb)ttJq{$t1QE|-z#s_@Nb9k$zOO~EU-l~#6UefCi*P1edR zvmuIa&DC!@jG{3;4QFbL;>05W(0t=(J~KUijDL@|KXXLeVc&*&+;+DPXsA&Q+98Vd}c(pz^F8qPd&9)~SJ2v+*s)B&TXo;E%`J=;Ec z`rL7=IDV>euEmZ{Pd_1T{fWkB<`)|1u3b@Wji#p`TzKxW_S5G+ zYHkv|tW>Lar2-JE9a9yh!cvrqgUnB_V)gRcBpT^NwOOrHkibyNz7Ka7C&_(4;=Q}v z*#%TMc=uBak3TE*-}Js^={78PK~?Gx=HH&1oGnexR_5vxll!~cjmZjwbE?=FOTBpR zG&U&jq4iFVH=2{Y)Gn82C+~iL)1RGfHQFUqvhn8RY@=Md=Yb!~5a*T_&YFFUYKdco zai`|cfDs|(atn+aFP9$j9h}$l;ZMgcBbg42>WUuZqHskX-IUjJONOx>8U9sYrWK(nrq;SEjMbD)9cAfjFIKj5FL`zNC7=d zlc?44*-q7)7z$GpwMO;6_pz6!FC0I2Q3}c_Y_M8;90}Jd*XomvdhI8BeX3Hcl_zFV ze`=)?I%T~}N$czNsW;8k;xvC8PL;ANrUOf_%(0j$w7BuvW_jul*&l)k+oe3&C{4^Z z;YZTTWvi^iS-gLxkGZta8ph!*ILzy4Tod=sr0DZw*LEBZaXgjCv*ReDQ*8t-vuMq= z5B$VEluL8WyxeS0)m!y?Y4*NrG(OMiu>j0ZxmN9Nv%6C`^{eB}S_O7-f6s_prP{7Y zhK2Kp(-!5WyDn|h$Dkn{jD2W4D1bzDwa;Z_YTpp3FV z*P5!f#^+{gYekkq5~;+J@A>$tg#{_`7;L5X_|)WFr8PUzn3zfq`dv%mzgFX0VQ>}! z=&?B&jO}W3yo#;W#29?=$7wnjjG88AvE-)eh`@=t*@@ERLlfzkMyOr$VYO*fYSiW? z*r68uU=9KO@OyxzHqoSgt=24;r{f)2lHo zP09@f;Q97-8kv8PMn|v)KaK|`nLTYB{SK5F7GWa3F?(9vtUgt$*V|LIxl*N7o|`)Q zV7k+N0?0c&>?MKA$iQ03g(4zqR_0Kp>vPR|10UJ=vBO<4yJ}nB4_K=xqK!FN!sJ}D zSsH)rU%4l^(JYjOJ=K_O&(+Hx{(N{HSp7r*J%pmt5729Y^~sC%Pv0-GDV4^pT)!Y^aE*w_2?HOX`6y* zf*U8h_%)u|))a1C>?nM&lOOwq4+J0HlfYK5x(#Qn;2EjlY@V8}ls-PTdY!2a&V0uk zWp-JH`rI7OqVZ=^d&AV;a|`EE<%kH&htZNu+42sY+0yJJ%6@yU+?YfnSAVL@BG-qM z%vt-hfHe z<~ZOmTN|&=9e?a!y;l$kGQ&$h*(N?QSD&rUo$#k6u*Kyh>^J&-pcsz8$UiBc6+ zVV0NsJ+@uP$j9)A2zBJ!MAu=Q>RhePj^ISa(~Os5_Wiv!UV$nJmel#DS#FIt53Kkd zR&uL65Hf8L?V{>xsWMR?XQDm~FxPr^^~QZbQqy?)DzRBF^g2tuUAROE49!Mr|_#2EI9QEWnk$$_V( zJ4n?Mdd!Yjh{Dtm6pBO6E!?*nyZhMEs^~`7_OH&?s<;)SFy31v#n;k(OxR81D5}{mh<|tBdNmp z7Qr%LApvhlNPa@LB@Z2{yQ?2C>qXkd0YwjbattuA%I z-DBxH4_{!yLy~XFK?~PJQB}2Yyk>W++h89uC2!~Uta#=q+|>gWb~uiK6`8x+5(Li4 zK~3T^1$mZ86gzEgd288?;%n4)cfIO_5jU>iye?df2qsoGd~?z?1hJf=59+xh2fyvy z-0$r>-N0Qgs+87Tfi}e#)Xh_G?;~2Zfq=yC5sBq3TYJkLMBq8;!FNt?h@=vW zbbU0&)92uP-`Ey5(zH>EtT5Nv)5cihe!~a`H;RptuE3#fpnm$?WeYLpOc?_nkv_qI`3%BqI^;QWZt4@Wpj^PCEj7}9db zOsk)*!m)eLb>lvI9na8H&mF(DNq)L2R6`!Q*kxEwp0}Wg@pIJmqm7$sJk#oF*Lcf8 z#Tv6J?kciXF6(pqiOg_JVe-QeA~N%%h=YNiF5;x3`fBv^)Phlja>oGsfKvd7C8d78 z(%~!9IMC~mR(fHj*t??$uRtT>$N?Xj7pP$H2Q7Fd1nn$#5Sc}RUr3f^{0Ef>% ziRm6Kclb~^QwvmTop3ZxJA%$jRH(y`Fw*pB#h)f{QO-hmlxh3YLk2s1r&uF!CfQF* zv0G#PN&7P8=5EyZ93H>EP3h&;0Ed4=HnM6>Mx~Zn8X9cvOW1ik`_3 zh{<2xq(b&_RTv(=1lWRlQ>O;qXPcy0*bZt|qG@dPEc0g21Kt0ICW+ z>$}u(e?K-h*50iiF^n;^WQgs_YP;h}wjGhphcbSm8{|gF0N`JUVLE@0x_Rg~v_^&~ zMn5v4l?}nnM2H`hWE31Fbw7jwC|D9j?^WlQ$MN}jeI1P(d1gF-z_p65u%O6@^3b3*(I1dkg&}(FQgvNyOyZwN= ze{i`0G5w%A0NL>~*hr_2@mL8eKL$z>!*P}fzjO*{l6^>xRAR%YCk0pg>Uw~Tv8j@g~GXpkWy8jPz#_d5>n%=YHd@rn$Lbxna(vF%=2r(A69ragp6#` zNOB($`?NC>o*OvD;!}rr-4!AwbgiR`kdV1N0U$L={OPGh2EoW@=2@1-zhGK?UR0nC zg;8zQxRVQE%sclPZ^cU1o#Dj<~H8SxA;vIIz=`X4yfG244 zYf$FAwPJavdnP^9bpE9$}f?s>o}JKft?RWcma(CQDZOLur+K=^S@DriER>#rSpb*Hy4 zcBHJ}QY1?*Ep7RARSsVmTGP`+Ytz+S>`E!ZWK?l=mXmBH#W$|eS2E)EioGP6ASniP zq9fHuzD?tss+Ts0tS+bqy2Rga2ffHX5kcTvk;+A}*56V+?srHpa_qi;T$3I*AaE6u zPQu~0)p54{(h5QPJ1WJeZVeDf7XuH#@U5XfZ)=n23P|6Y@2X>nt++Se^9=;1-&glz z$i8Ix!R##wN4I%pcbiDv(x1iEDbG2;O&FH!M;AXl)QhgktsFW-!<5K%Ys#m%iL>lS zhaNu}m)D3*blM=;t0O#kUh7)_Smnc^53Mj?pC)!4U22LZae0y9kGPdTQ9-;PeA-WE z4>Zc4*0Cd2ZHg%2p-h?(I+0rHpIx&ffXl6PECGbGn21F&th2WMxjNTfya1N@|Bz9& z;N!lSx!{{?JRh`|B*0e{%6vf}VkS^D)h|>~9v(h`e-Gl{uz}oFxhY-kqSnPt6#ue! zEr*X#*>!Yz0$Vc+3I%G=$nZ3%0%6U6)mJwY(jdXxNL#v>jP#-GtS)=UUO6DWCQ6Lv z3T0{g>jk?(B2k+(r9%rAH~Kd!9uo|99e(co`W{Kx&fX^ZsLW8aPpG5{muMbrRLyS} z=u;XlNJgN|I94c$-}ypb3g3>L@*DJfH3ICeHns-vo7WIKgi-&h1(Ldktj?(rn#$<( z4{GM~nP97!>2N!^_DJmuC>!*RkxBnJyRIHtXBDCyQkTTWC`{O9d1LaYqoa&l4dGY} z7U!&y?ZvL(`IssGtR6F3|3ZMJPw7Qm!EivWC^Zq?A`^iW(0@@k-JRhWiFzFVAB_@D zk@PMO_;el;#^8R$gn#uI#>`sQNSB0H ze>_UeQeE>tv2p)a8}p~v{laSvW=?J_b77aOjZOX`2GPUIe?yrV5Ss39FUX_?-;^&# z+;h&lpo+;U+KcP{a|h1?@3XnJQSVj^c#q>(cz(FcwyS$B;{vWb!B6svyQ$B*y?fqU z%H--H@lu{GMJG>9|3!zBJgQ92#_`!GIeqLldxbwc7A?i)QglKJ&$Hom-~*$jWXYr_ NPhl0nivUHZ{|gw(GKl~H literal 0 HcmV?d00001 diff --git a/test/core/src/wasm-bindgen/package.json b/test/core/src/wasm-bindgen/package.json new file mode 100644 index 000000000000..3dbc1ca591c0 --- /dev/null +++ b/test/core/src/wasm-bindgen/package.json @@ -0,0 +1,3 @@ +{ + "type": "module" +} diff --git a/test/core/test/vm-wasm.test.ts b/test/core/test/vm-wasm.test.ts new file mode 100644 index 000000000000..a4a866acb438 --- /dev/null +++ b/test/core/test/vm-wasm.test.ts @@ -0,0 +1,64 @@ +import { readFileSync } from 'node:fs' +import { resolve } from 'node:url' +import { expect, test, vi } from 'vitest' + +// TODO: currently not supported + +// @ts-expect-error wasm is not typed +import { add } from '../src/add.wasm' + +const wasmFileBuffer = readFileSync(resolve(__dirname, './src/add.wasm')) + +test('supports native wasm imports', () => { + expect(add(1, 2)).toBe(3) + + // because arguments are i32 (signed), fractional part is truncated + expect(add(0.99, 1.01)).toBe(1) + + // because return value is i32 (signed), (2^31 - 1) + 1 overflows and becomes -2^31 + expect(add(2 ** 31 - 1, 1)).toBe(-(2 ** 31)) + + // invalid or missing arguments are treated as 0 + expect(add('hello', 'world')).toBe(0) + expect(add()).toBe(0) + expect(add(null)).toBe(0) + expect(add({}, [])).toBe(0) + + // redundant arguments are silently ignored + expect(add(1, 2, 3)).toBe(3) +}) + +test('supports dynamic wasm imports', async () => { + // @ts-expect-error wasm is not typed + const { add: dynamicAdd } = await import('../src/add.wasm') + expect(dynamicAdd(1, 2)).toBe(3) +}) + +test('supports imports from "data:application/wasm" URI with base64 encoding', async () => { + const importedWasmModule = await import( + `data:application/wasm;base64,${wasmFileBuffer.toString('base64')}` + ) + expect(importedWasmModule.add(0, 42)).toBe(42) +}) + +test('imports from "data:application/wasm" URI without explicit encoding fail', async () => { + await expect(() => + import(`data:application/wasm,${wasmFileBuffer.toString('base64')}`), + ).rejects.toThrow('Missing data URI encoding') +}) + +test('imports from "data:application/wasm" URI with invalid encoding fail', async () => { + await expect(() => + // @ts-expect-error import is not typed + import('data:application/wasm;charset=utf-8,oops'), + ).rejects.toThrow('Invalid data URI encoding: charset=utf-8') +}) + +test('supports wasm files that import js resources (wasm-bindgen)', async () => { + globalThis.alert = vi.fn() + + const { greet } = await import('../src/wasm-bindgen/index.js') + greet('World') + + expect(globalThis.alert).toHaveBeenCalledWith('Hello, World!') +}) diff --git a/test/core/vitest.config.ts b/test/core/vitest.config.ts index 9da89210a05d..03a6bec0c909 100644 --- a/test/core/vitest.config.ts +++ b/test/core/vitest.config.ts @@ -43,7 +43,7 @@ export default defineConfig({ }, test: { name: 'core', - exclude: ['**/fixtures/**', ...defaultExclude], + exclude: ['**/fixtures/**', '**/vm-wasm.test.ts', ...defaultExclude], slowTestThreshold: 1000, testTimeout: 2000, setupFiles: [ @@ -57,6 +57,9 @@ export default defineConfig({ env: { CUSTOM_ENV: 'foo', }, + poolMatchGlobs: [ + ['**/vm-wasm.test.ts', 'experimentalVmThreads'], + ], resolveSnapshotPath: (path, extension) => { if (path.includes('moved-snapshot')) return path + extension @@ -70,7 +73,7 @@ export default defineConfig({ }, server: { deps: { - external: ['tinyspy', /src\/external/, /esm\/esm/], + external: ['tinyspy', /src\/external/, /esm\/esm/, /\.wasm$/], inline: ['inline-lib'], }, }, From 68b2db9788b85674271e88cf1f5099ff297b2f4f Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Mon, 31 Jul 2023 17:01:24 +0200 Subject: [PATCH 85/87] chore: allow import .json, throw error on importing .css --- packages/utils/src/source-map.ts | 24 +++--- packages/vite-node/package.json | 5 ++ packages/vite-node/rollup.config.js | 1 + packages/vite-node/src/constants.ts | 38 +++++++++ packages/vite-node/src/externalize.ts | 36 +------- .../vitest/src/runtime/external-executor.ts | 84 ++++++++++++++----- 6 files changed, 122 insertions(+), 66 deletions(-) create mode 100644 packages/vite-node/src/constants.ts diff --git a/packages/utils/src/source-map.ts b/packages/utils/src/source-map.ts index b89a4c3309a3..542ada2721fe 100644 --- a/packages/utils/src/source-map.ts +++ b/packages/utils/src/source-map.ts @@ -16,18 +16,18 @@ const CHROME_IE_STACK_REGEXP = /^\s*at .*(\S+:\d+|\(native\))/m const SAFARI_NATIVE_CODE_REGEXP = /^(eval@)?(\[native code])?$/ const stackIgnorePatterns = [ - // 'node:internal', - // /\/packages\/\w+\/dist\//, - // /\/@vitest\/\w+\/dist\//, - // '/vitest/dist/', - // '/vitest/src/', - // '/vite-node/dist/', - // '/vite-node/src/', - // '/node_modules/chai/', - // '/node_modules/tinypool/', - // '/node_modules/tinyspy/', - // '/deps/chai.js', - // /__vitest_browser__/, + 'node:internal', + /\/packages\/\w+\/dist\//, + /\/@vitest\/\w+\/dist\//, + '/vitest/dist/', + '/vitest/src/', + '/vite-node/dist/', + '/vite-node/src/', + '/node_modules/chai/', + '/node_modules/tinypool/', + '/node_modules/tinyspy/', + '/deps/chai.js', + /__vitest_browser__/, ] function extractLocation(urlLike: string) { diff --git a/packages/vite-node/package.json b/packages/vite-node/package.json index f0f31f22ef74..641969e2864b 100644 --- a/packages/vite-node/package.json +++ b/packages/vite-node/package.json @@ -46,6 +46,11 @@ "require": "./dist/source-map.cjs", "import": "./dist/source-map.mjs" }, + "./constants": { + "types": "./dist/constants.d.ts", + "require": "./dist/constants.cjs", + "import": "./dist/constants.mjs" + }, "./*": "./*" }, "main": "./dist/index.mjs", diff --git a/packages/vite-node/rollup.config.js b/packages/vite-node/rollup.config.js index 9fb7fb22a736..258770c42e10 100644 --- a/packages/vite-node/rollup.config.js +++ b/packages/vite-node/rollup.config.js @@ -15,6 +15,7 @@ const entries = { 'client': 'src/client.ts', 'utils': 'src/utils.ts', 'cli': 'src/cli.ts', + 'constants': 'src/constants.ts', 'hmr': 'src/hmr/index.ts', 'source-map': 'src/source-map.ts', } diff --git a/packages/vite-node/src/constants.ts b/packages/vite-node/src/constants.ts new file mode 100644 index 000000000000..9d098cb66fc4 --- /dev/null +++ b/packages/vite-node/src/constants.ts @@ -0,0 +1,38 @@ +export const KNOWN_ASSET_TYPES = [ + // images + 'apng', + 'png', + 'jpe?g', + 'jfif', + 'pjpeg', + 'pjp', + 'gif', + 'svg', + 'ico', + 'webp', + 'avif', + + // media + 'mp4', + 'webm', + 'ogg', + 'mp3', + 'wav', + 'flac', + 'aac', + + // fonts + 'woff2?', + 'eot', + 'ttf', + 'otf', + + // other + 'webmanifest', + 'pdf', + 'txt', +] + +export const KNOWN_ASSET_RE = new RegExp(`\\.(${KNOWN_ASSET_TYPES.join('|')})$`) +export const CSS_LANGS_RE + = /\.(css|less|sass|scss|styl|stylus|pcss|postcss|sss)(?:$|\?)/ diff --git a/packages/vite-node/src/externalize.ts b/packages/vite-node/src/externalize.ts index ba7bc1c124f0..7dcf090e3e92 100644 --- a/packages/vite-node/src/externalize.ts +++ b/packages/vite-node/src/externalize.ts @@ -3,41 +3,7 @@ import { isValidNodeImport } from 'mlly' import { join } from 'pathe' import type { DepsHandlingOptions } from './types' import { isNodeBuiltin, slash } from './utils' - -const KNOWN_ASSET_TYPES = [ - // images - 'apng', - 'png', - 'jpe?g', - 'jfif', - 'pjpeg', - 'pjp', - 'gif', - 'svg', - 'ico', - 'webp', - 'avif', - - // media - 'mp4', - 'webm', - 'ogg', - 'mp3', - 'wav', - 'flac', - 'aac', - - // fonts - 'woff2?', - 'eot', - 'ttf', - 'otf', - - // other - 'webmanifest', - 'pdf', - 'txt', -] +import { KNOWN_ASSET_TYPES } from './constants' const ESM_EXT_RE = /\.(es|esm|esm-browser|esm-bundler|es6|module)\.js$/ const ESM_FOLDER_RE = /\/(es|esm)\/(.*\.js)$/ diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index 0e03fe94a77a..370f9a969bd6 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -7,6 +7,8 @@ import { Module as _Module, createRequire } from 'node:module' import { readFileSync, statSync } from 'node:fs' import { basename, extname, join, normalize } from 'pathe' import { getCachedData, isNodeBuiltin, setCacheData } from 'vite-node/utils' +import { CSS_LANGS_RE, KNOWN_ASSET_RE } from 'vite-node/contants' +import { getColors } from '@vitest/utils' // need to copy paste types for vm // because they require latest @types/node which we don't bundle @@ -30,28 +32,28 @@ declare class VMModule { } interface SyntheticModuleOptions { /** - * String used in stack traces. - * @default 'vm:module(i)' where i is a context-specific ascending index. - */ + * String used in stack traces. + * @default 'vm:module(i)' where i is a context-specific ascending index. + */ identifier?: string | undefined /** - * The contextified object as returned by the `vm.createContext()` method, to compile and evaluate this module in. - */ + * The contextified object as returned by the `vm.createContext()` method, to compile and evaluate this module in. + */ context?: vm.Context | undefined } declare class VMSyntheticModule extends VMModule { /** - * Creates a new `SyntheticModule` instance. - * @param exportNames Array of names that will be exported from the module. - * @param evaluateCallback Called when the module is evaluated. - */ + * Creates a new `SyntheticModule` instance. + * @param exportNames Array of names that will be exported from the module. + * @param evaluateCallback Called when the module is evaluated. + */ constructor(exportNames: string[], evaluateCallback: (this: VMSyntheticModule) => void, options?: SyntheticModuleOptions) /** - * This method is used after the module is linked to set the values of exports. - * If it is called before the module is linked, an `ERR_VM_MODULE_STATUS` error will be thrown. - * @param name - * @param value - */ + * This method is used after the module is linked to set the values of exports. + * If it is called before the module is linked, an `ERR_VM_MODULE_STATUS` error will be thrown. + * @param name + * @param value + */ setExport(name: string, value: any): void } @@ -301,7 +303,7 @@ export class ExternalModulesExecutor { return null } - private async wrapSynteticModule(identifier: string, exports: Record) { + private wrapSynteticModule(identifier: string, exports: Record) { // TODO: technically module should be parsed to find static exports, implement for strict mode in #2854 const moduleKeys = Object.keys(exports).filter(key => key !== 'default') const m: any = new SyntheticModule( @@ -396,6 +398,50 @@ export class ExternalModulesExecutor { const cached = this.moduleCache.get(fileUrl) if (cached) return cached + const [urlPath] = fileUrl.split('?') + if (CSS_LANGS_RE.test(urlPath) || KNOWN_ASSET_RE.test(urlPath)) { + const path = normalize(urlPath) + let name = path.split('/node_modules/').pop() || '' + if (name?.startsWith('@')) + name = name.split('/').slice(0, 2).join('/') + else + name = name.split('/')[0] + const ext = extname(path) + let error = `[vitest] Cannot import ${fileUrl}. At the moment, importing ${ext} files inside external dependencies is not allowed. ` + if (name) { + const c = getColors() + error += 'As a temporary workaround you can try to inline the package by updating your config:' ++ `\n\n${ +c.gray(c.dim('// vitest.config.js')) +}\n${ +c.green(`export default { + test: { + deps: { + optimizer: { + web: { + include: [ + ${c.yellow(c.bold(`"${name}"`))} + ] + } + } + } + } +}\n`)}` + } + throw new this.primitives.Error(error) + } + // TODO: should not be allowed in strict mode, implement in #2854 + if (fileUrl.endsWith('.json')) { + const m = new SyntheticModule( + ['default'], + () => { + const result = JSON.parse(code) + m.setExport('default', result) + }, + ) + this.moduleCache.set(fileUrl, m) + return m + } const m = new SourceTextModule( code, { @@ -536,12 +582,12 @@ export class ExternalModulesExecutor { if (extension === '.node' || isNodeBuiltin(identifier)) { const exports = this.requireCoreModule(identifier) - return await this.wrapSynteticModule(identifier, exports) + return this.wrapSynteticModule(identifier, exports) } const isFileUrl = identifier.startsWith('file://') const fileUrl = isFileUrl ? identifier : pathToFileURL(identifier).toString() - const pathUrl = isFileUrl ? fileURLToPath(identifier) : identifier + const pathUrl = isFileUrl ? fileURLToPath(identifier.split('?')[0]) : identifier // TODO: support wasm in the future // if (extension === '.wasm') { @@ -554,7 +600,7 @@ export class ExternalModulesExecutor { if (extension === '.cjs') { const module = this.createCommonJSNodeModule(pathUrl) const exports = this.loadCommonJSModule(module, pathUrl) - return await this.wrapSynteticModule(fileUrl, exports) + return this.wrapSynteticModule(fileUrl, exports) } if (extension === '.mjs') @@ -567,7 +613,7 @@ export class ExternalModulesExecutor { const module = this.createCommonJSNodeModule(pathUrl) const exports = this.loadCommonJSModule(module, pathUrl) - return await this.wrapSynteticModule(fileUrl, exports) + return this.wrapSynteticModule(fileUrl, exports) } async import(identifier: string) { From 710e2911ef94b8da847a0cb4eababb7ae11e5898 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Mon, 31 Jul 2023 18:30:10 +0200 Subject: [PATCH 86/87] chore: typo --- packages/vitest/src/runtime/external-executor.ts | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index 370f9a969bd6..64c94247b724 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -7,7 +7,7 @@ import { Module as _Module, createRequire } from 'node:module' import { readFileSync, statSync } from 'node:fs' import { basename, extname, join, normalize } from 'pathe' import { getCachedData, isNodeBuiltin, setCacheData } from 'vite-node/utils' -import { CSS_LANGS_RE, KNOWN_ASSET_RE } from 'vite-node/contants' +import { CSS_LANGS_RE, KNOWN_ASSET_RE } from 'vite-node/constants' import { getColors } from '@vitest/utils' // need to copy paste types for vm From 82ae1a6d1d4fc1823796186837853b4f8792c8e8 Mon Sep 17 00:00:00 2001 From: Vladimir Sheremet Date: Mon, 31 Jul 2023 19:24:49 +0200 Subject: [PATCH 87/87] chore: types --- packages/vitest/rollup.config.js | 1 + packages/vitest/src/runtime/external-executor.ts | 2 +- test/core/test/vm-wasm.test.ts | 1 + 3 files changed, 3 insertions(+), 1 deletion(-) diff --git a/packages/vitest/rollup.config.js b/packages/vitest/rollup.config.js index b0af2e32aa04..3f7ab46a8b43 100644 --- a/packages/vitest/rollup.config.js +++ b/packages/vitest/rollup.config.js @@ -63,6 +63,7 @@ const external = [ 'vite-node/source-map', 'vite-node/client', 'vite-node/server', + 'vite-node/constants', 'vite-node/utils', '@vitest/utils/diff', '@vitest/utils/error', diff --git a/packages/vitest/src/runtime/external-executor.ts b/packages/vitest/src/runtime/external-executor.ts index 64c94247b724..dcb903b7a15b 100644 --- a/packages/vitest/src/runtime/external-executor.ts +++ b/packages/vitest/src/runtime/external-executor.ts @@ -505,7 +505,7 @@ c.green(`export default { if (!importsObject[module]) importsObject[module] = {} - importsObject[module][name] = moduleLookup[module].namespace[name] + importsObject[module][name] = (moduleLookup[module].namespace as any)[name] } const wasmInstance = new WebAssembly.Instance( wasmModule, diff --git a/test/core/test/vm-wasm.test.ts b/test/core/test/vm-wasm.test.ts index a4a866acb438..ec1d851bc697 100644 --- a/test/core/test/vm-wasm.test.ts +++ b/test/core/test/vm-wasm.test.ts @@ -57,6 +57,7 @@ test('imports from "data:application/wasm" URI with invalid encoding fail', asyn test('supports wasm files that import js resources (wasm-bindgen)', async () => { globalThis.alert = vi.fn() + // @ts-expect-error not typed const { greet } = await import('../src/wasm-bindgen/index.js') greet('World')